reference, declarationdefinition
definition → references, declarations, derived classes, virtual overrides
reference to multiple definitions → definitions
unreferenced

References

include/llvm/ADT/DenseMap.h
  852           SmallDenseMap<KeyT, ValueT, InlineBuckets, KeyInfoT, BucketT>, KeyT,
include/llvm/ADT/DenseSet.h
  269           ValueT, SmallDenseMap<ValueT, detail::DenseSetEmpty, InlineBuckets,
  273       ValueT, SmallDenseMap<ValueT, detail::DenseSetEmpty, InlineBuckets,
include/llvm/ADT/MapVector.h
  233     : MapVector<KeyT, ValueT, SmallDenseMap<KeyT, unsigned, N>,
include/llvm/ADT/PriorityWorklist.h
  258                               SmallDenseMap<T, ptrdiff_t>> {
include/llvm/Analysis/AliasAnalysis.h
  300   using AliasCacheT = SmallDenseMap<LocPair, AliasResult, 8>;
  303   using IsCapturedCacheT = SmallDenseMap<const Value *, bool, 8>;
include/llvm/Analysis/BlockFrequencyInfoImpl.h
  617   SmallDenseMap<uint32_t, IrrNode *, 4> Lookup;
include/llvm/Analysis/CGSCCPassManager.h
  587       SmallDenseMap<Function *, CallCount> CallCounts;
include/llvm/Analysis/LazyCallGraph.h
  557     SmallDenseMap<SCC *, int, 4> SCCIndices;
include/llvm/Analysis/MemorySSAUpdater.h
   65 using PhiToDefMap = SmallDenseMap<MemoryPhi *, MemoryAccess *>;
include/llvm/Analysis/OrderedBasicBlock.h
   36   SmallDenseMap<const Instruction *, unsigned, 32> NumberedInsts;
include/llvm/Analysis/ScalarEvolution.h
 1538     SmallDenseMap<PointerIntPair<Value *, 1>, ExitLimit> TripCountMap;
include/llvm/CodeGen/GlobalISel/InstructionSelector.h
  437     SmallDenseMap<LLT, unsigned, 64> TypeIDMap;
include/llvm/IR/CFGDiff.h
   81   using UpdateMapType = SmallDenseMap<NodePtr, SmallVector<NodePtr, 2>>;
include/llvm/IR/LegacyPassManagers.h
  250   SmallDenseMap<AnalysisID, ImmutablePass *, 8> ImmutablePassMap;
include/llvm/IR/Metadata.h
  287   SmallDenseMap<void *, std::pair<OwnerTy, uint64_t>, 4> UseMap;
include/llvm/IR/PassManager.h
  719     Invalidator(SmallDenseMap<AnalysisKey *, bool, 8> &IsResultInvalidated,
  723     SmallDenseMap<AnalysisKey *, bool, 8> &IsResultInvalidated;
  870     SmallDenseMap<AnalysisKey *, bool, 8> IsResultInvalidated;
 1216     const SmallDenseMap<AnalysisKey *, TinyPtrVector<AnalysisKey *>, 2> &
 1226     SmallDenseMap<AnalysisKey *, TinyPtrVector<AnalysisKey *>, 2>
include/llvm/MCA/HardwareUnits/ResourceManager.h
  355   SmallDenseMap<ResourceRef, unsigned> BusyResources;
include/llvm/ProfileData/InstrProfWriter.h
   35   using ProfilingData = SmallDenseMap<uint64_t, InstrProfRecord>;
include/llvm/Support/CFGUpdate.h
   71   SmallDenseMap<std::pair<NodePtr, NodePtr>, int, 4> Operations;
include/llvm/Transforms/Utils/UnrollLoop.h
   37 using NewLoopsMap = SmallDenseMap<const Loop *, Loop *, 4>;
lib/Analysis/BasicAliasAnalysis.cpp
  121     SmallDenseMap<const Value *, bool, 8> *IsCapturedCache = nullptr) {
  122   SmallDenseMap<const Value *, bool, 8>::iterator CacheIt;
lib/Analysis/BlockFrequencyInfoImpl.cpp
  688   SmallDenseMap<const IrreducibleGraph::IrrNode *, bool, 8> InSCC;
lib/Analysis/ConstantFolding.cpp
 1078                          SmallDenseMap<Constant *, Constant *> &FoldedOps) {
 1124     SmallDenseMap<Constant *, Constant *> FoldedOps;
 1155   SmallDenseMap<Constant *, Constant *> FoldedOps;
 1191   SmallDenseMap<Constant *, Constant *> FoldedOps;
lib/Analysis/GlobalsModRef.cpp
   62   typedef SmallDenseMap<const GlobalValue *, ModRefInfo, 16> GlobalInfoMapType;
lib/Analysis/LazyValueInfo.cpp
  162       SmallDenseMap<PoisoningVH<BasicBlock>, ValueLatticeElement, 4> BlockVals;
lib/Analysis/MemorySSAUpdater.cpp
  912   SmallDenseMap<BasicBlock *, PredInfo> PredMap;
  921   SmallDenseMap<std::pair<BasicBlock *, BasicBlock *>, int> EdgeCountMap;
  980     SmallDenseMap<BasicBlock *, MemoryAccess *> LastDefAddedPred;
lib/AsmParser/LLParser.cpp
 7328   SmallDenseMap<const Use *, unsigned, 16> Order;
lib/Bitcode/Reader/BitcodeReader.cpp
 2880       SmallDenseMap<const Use *, unsigned, 16> Order;
lib/Bitcode/Reader/MetadataLoader.cpp
  125     SmallDenseMap<MDString *, TempMDTuple, 1> Unknown;
  126     SmallDenseMap<MDString *, DICompositeType *, 1> Final;
  127     SmallDenseMap<MDString *, DICompositeType *, 1> FwdDecls;
  459   SmallDenseMap<Function *, DISubprogram *, 16> FunctionsWithSPs;
lib/Bitcode/Writer/ValueEnumerator.h
  105   SmallDenseMap<unsigned, MDRange, 1> FunctionMDInfo;
lib/CodeGen/AsmPrinter/DbgEntityHistoryCalculator.cpp
  165     SmallDenseMap<unsigned, bool, 4> TrackedRegs;
lib/CodeGen/AsmPrinter/DwarfCompileUnit.cpp
  722   SmallDenseMap<const DILocalVariable *, DbgVariable *> DbgVar;
lib/CodeGen/AsmPrinter/DwarfDebug.cpp
 1266   SmallDenseMap<InlinedEntity, DbgVariable *> MFVars;
lib/CodeGen/CodeGenPrepare.cpp
 2861   using MapType = SmallDenseMap<PHINode *, size_t, 32>;
lib/CodeGen/LiveDebugValues.cpp
  372   using DebugParamMap = SmallDenseMap<const DILocalVariable *, MachineInstr *>;
  375   using VarLocInMBB = SmallDenseMap<const MachineBasicBlock *, VarLocSet>;
  401     SmallDenseMap<DebugVariable, unsigned, 8> Vars;
lib/CodeGen/PeepholeOptimizer.cpp
  181     using RewriteMapTy = SmallDenseMap<RegSubRegPair, ValueTrackerResult>;
lib/CodeGen/PrologEpilogInserter.cpp
  173     SmallDenseMap<MachineBasicBlock *, SmallVector<MachineInstr *, 4>, 4>;
lib/CodeGen/SafeStackColoring.cpp
   68   DenseMap<BasicBlock *, SmallDenseMap<Instruction *, Marker>> BBMarkerSet;
lib/CodeGen/SelectionDAG/LegalizeTypes.h
   93   SmallDenseMap<SDValue, TableId, 8> ValueToIdMap;
   94   SmallDenseMap<TableId, SDValue, 8> IdToValueMap;
   98   SmallDenseMap<TableId, TableId, 8> PromotedIntegers;
  102   SmallDenseMap<TableId, std::pair<TableId, TableId>, 8> ExpandedIntegers;
  106   SmallDenseMap<TableId, TableId, 8> SoftenedFloats;
  110   SmallDenseMap<TableId, TableId, 8> PromotedFloats;
  114   SmallDenseMap<TableId, std::pair<TableId, TableId>, 8> ExpandedFloats;
  118   SmallDenseMap<TableId, TableId, 8> ScalarizedVectors;
  122   SmallDenseMap<TableId, std::pair<TableId, TableId>, 8> SplitVectors;
  126   SmallDenseMap<TableId, TableId, 8> WidenedVectors;
  130   SmallDenseMap<TableId, TableId, 8> ReplacedValues;
lib/CodeGen/SelectionDAG/LegalizeVectorOps.cpp
   64   SmallDenseMap<SDValue, SDValue, 64> LegalizedNodes;
lib/CodeGen/SelectionDAG/SelectionDAGBuilder.cpp
 9426   SmallDenseMap<const AllocaInst *, StaticAllocaInfo, 8> StaticAllocas;
lib/CodeGen/TwoAddressInstructionPass.cpp
  169   using TiedOperandMap = SmallDenseMap<unsigned, TiedPairList>;
lib/Support/ItaniumManglingCanonicalizer.cpp
  155   llvm::SmallDenseMap<Node*, Node*, 32> Remappings;
lib/Target/AArch64/AArch64PromoteConstant.cpp
   99   using PromotionCacheTy = SmallDenseMap<Constant *, PromotedConstant, 16>;
lib/Target/AMDGPU/AMDGPUMachineFunction.h
   22   SmallDenseMap<const GlobalValue *, unsigned, 4> LocalMemoryObjects;
lib/Target/Hexagon/HexagonISelDAGToDAG.cpp
 1951   SmallDenseMap<SDValue, int> NodeHeights;
lib/Target/Hexagon/HexagonISelDAGToDAG.h
  147   SmallDenseMap<SDNode *,int> RootWeights;
  148   SmallDenseMap<SDNode *,int> RootHeights;
  149   SmallDenseMap<const Value *,int> GAUsesInFunction;
lib/Target/Mips/MipsDelaySlotFiller.cpp
  108   using BB2BrMap = SmallDenseMap<MachineBasicBlock *, MachineInstr *, 2>;
lib/Target/PowerPC/PPCExpandISEL.cpp
   58   typedef SmallDenseMap<int, BlockISELList> ISELInstructionList;
lib/Target/X86/X86ISelLowering.cpp
14249       SmallDenseMap<int, int, 8> LaneMap;
lib/Target/X86/X86SpeculativeLoadHardening.cpp
  198                  SmallDenseMap<unsigned, unsigned, 32> &AddrRegToHardenedReg);
  211       SmallDenseMap<unsigned, unsigned, 32> &AddrRegToHardenedReg);
  716     SmallDenseMap<MachineBasicBlock *, int> SuccCounts;
 1646   SmallDenseMap<unsigned, unsigned, 32> AddrRegToHardenedReg;
 1948     SmallDenseMap<unsigned, unsigned, 32> &AddrRegToHardenedReg) {
 2589     SmallDenseMap<unsigned, unsigned, 32> &AddrRegToHardenedReg) {
lib/Transforms/InstCombine/InstCombineCasts.cpp
 2221   SmallDenseMap<PHINode *, PHINode *> NewPNodes;
lib/Transforms/InstCombine/InstCombinePHI.cpp
  233   SmallDenseMap<Value *, Instruction *> Casts;
lib/Transforms/Scalar/GVN.cpp
 2018     SmallDenseMap<BasicBlock *, unsigned, 16> SwitchEdges;
lib/Transforms/Scalar/LICM.cpp
 1456     SmallDenseMap<BasicBlock *, Instruction *, 32> &SunkCopies,
 1635   SmallDenseMap<BasicBlock *, Instruction *, 32> SunkCopies;
lib/Transforms/Scalar/LoopIdiomRecognize.cpp
  667   SmallDenseMap<StoreInst *, StoreInst *> ConsecutiveChain;
lib/Transforms/Scalar/LoopSink.cpp
  176                             const SmallDenseMap<BasicBlock *, int, 16> &LoopBlockNumber,
  283   SmallDenseMap<BasicBlock *, int, 16> LoopBlockNumber;
lib/Transforms/Scalar/RewriteStatepointsForGC.cpp
 1996   SmallDenseMap<Value *, BasicBlock *, 8> CurrentIncomingValues;
lib/Transforms/Scalar/SROA.cpp
  656   SmallDenseMap<Instruction *, unsigned> MemTransferSliceMap;
  657   SmallDenseMap<Instruction *, uint64_t> PHIOrSelectSizes;
  876       SmallDenseMap<Instruction *, unsigned>::iterator MTPI =
  899     SmallDenseMap<Instruction *, unsigned>::iterator MTPI;
 3646   SmallDenseMap<Instruction *, SplitOffsets, 8> SplitOffsetsMap;
 3833   SmallDenseMap<LoadInst *, std::vector<LoadInst *>, 1> SplitLoadsMap;
lib/Transforms/Scalar/SimpleLoopUnswitch.cpp
  686   SmallDenseMap<BasicBlock *, BasicBlock *, 2> SplitExitBBMap;
  973     const SmallDenseMap<BasicBlock *, BasicBlock *, 16> &DominatingSucc,
 1217   SmallDenseMap<BasicBlock *, Loop *, 16> ExitLoopMap;
 2000   SmallDenseMap<BasicBlock *, BasicBlock *, 16> DominatingSucc;
 2026   SmallDenseMap<BasicBlock *, BasicBlock *, 4> ClonedPHs;
 2328                       const SmallDenseMap<BasicBlock *, int, 4> &BBCostMap,
 2329                       SmallDenseMap<DomTreeNode *, int, 4> &DTCostMap) {
 2626   SmallDenseMap<BasicBlock *, int, 4> BBCostMap;
 2669   SmallDenseMap<DomTreeNode *, int, 4> DTCostMap;
lib/Transforms/Scalar/SpeculateAroundPHIs.cpp
  203     PHINode &PN, SmallDenseMap<PHINode *, int, 16> &CostSavingsMap,
  216   SmallDenseMap<ConstantInt *, CostsAndCount, 16> CostsAndCounts;
  430   SmallDenseMap<Instruction *, TinyPtrVector<PHINode *>, 16> UserToPNMap;
  431   SmallDenseMap<PHINode *, int, 16> PNUserCountMap;
  446   SmallDenseMap<Instruction *, int, 16> SpecCostMap;
  621   SmallDenseMap<Instruction *, SmallVector<Value *, 2>, 16> SpeculatedValueMap;
  643       SmallDenseMap<BasicBlock *, Value *, 16> IncomingValueMap;
  738   SmallDenseMap<PHINode *, int, 16> CostSavingsMap;
lib/Transforms/Scalar/StructurizeCFG.cpp
  335   SmallDenseMap<Loop*, unsigned, 8> LoopBlocks;
lib/Transforms/Utils/LCSSA.cpp
   86   SmallDenseMap<Loop*, SmallVector<BasicBlock *,1>> LoopExitBlocks;
lib/Transforms/Utils/Local.cpp
 2149       SmallDenseMap<CatchPadInst *, detail::DenseSetEmpty, 4,
lib/Transforms/Utils/LoopUnroll.cpp
  603     SmallDenseMap<const Loop *, Loop *, 4> NewLoops;
lib/Transforms/Utils/LoopUnrollPeel.cpp
  127     SmallDenseMap<PHINode *, unsigned> &IterationsToInvariance) {
  303     SmallDenseMap<PHINode *, unsigned> IterationsToInvariance;
lib/Transforms/Utils/ModuleUtils.cpp
  194   SmallDenseMap<Comdat *, int, 16> ComdatEntriesCovered;
lib/Transforms/Utils/PredicateInfo.cpp
  468   SmallDenseMap<BasicBlock *, unsigned, 16> SwitchEdges;
lib/Transforms/Utils/SSAUpdater.cpp
   79                         SmallDenseMap<BasicBlock *, Value *, 8> &ValueMapping) {
  152     SmallDenseMap<BasicBlock *, Value *, 8> ValueMapping(PredValues.begin(),
lib/Transforms/Utils/SimplifyCFG.cpp
 1980   SmallDenseMap<Instruction *, unsigned, 4> SinkCandidateUseCounts;
 2032   for (SmallDenseMap<Instruction *, unsigned, 4>::iterator
 4633                const SmallDenseMap<Value *, Constant *> &ConstantPool) {
 4645              const SmallDenseMap<Value *, Constant *> &ConstantPool) {
 4687   SmallDenseMap<Value *, Constant *> ConstantPool;
 5167                        const SmallDenseMap<PHINode *, Type *> &ResultTypes) {
 5325   SmallDenseMap<PHINode *, ResultListTy> ResultLists;
 5327   SmallDenseMap<PHINode *, Constant *> DefaultResults;
 5328   SmallDenseMap<PHINode *, Type *> ResultTypes;
lib/Transforms/Utils/SimplifyIndVar.cpp
  206   SmallDenseMap<const SCEV*, Value*> CheapExpansions;
lib/Transforms/Utils/ValueMapper.cpp
  202     SmallDenseMap<const Metadata *, Data, 32> Info; // Node properties.
  219   SmallDenseMap<const Metadata *, Data, 32> InfoStorage;
lib/Transforms/Vectorize/LoopVectorize.cpp
 3201   SmallDenseMap<Instruction *, Instruction *, 4, CSEDenseMapInfo> CSEMap;
lib/Transforms/Vectorize/SLPVectorizer.cpp
 1454   SmallDenseMap<Value*, TreeEntry *> ScalarToTreeEntry;
 1871     DenseMap<Value *, SmallDenseMap<Value *, ScheduleData *>>
 5396   SmallDenseMap<StoreInst *, StoreInst *> ConsecutiveChain;
lib/Transforms/Vectorize/VPlan.h
  296     SmallDenseMap<VPBasicBlock *, BasicBlock *> VPBB2IRBB;
 1274   SmallDenseMap<const VPBlockBase *, unsigned> BlockID;
tools/clang/include/clang/AST/ASTImporter.h
  213       llvm::SmallDenseMap<Decl *, int, 32> Aux;
  229         llvm::SmallDenseMap<Decl *, SavedImportPathsForOneDecl, 32>;
tools/clang/include/clang/AST/ASTImporterLookupTable.h
   54   using NameMap = llvm::SmallDenseMap<DeclarationName, DeclList, 4>;
tools/clang/include/clang/AST/CXXInheritance.h
  138   llvm::SmallDenseMap<QualType, IsVirtBaseAndNumberNonVirtBases, 8>
tools/clang/include/clang/AST/DeclContextInternals.h
  239     : public llvm::SmallDenseMap<DeclarationName, StoredDeclsList, 4> {
tools/clang/include/clang/Parse/Parser.h
  164   llvm::SmallDenseMap<IdentifierInfo *, tok::TokenKind> RevertibleTypeTraits;
tools/clang/include/clang/Sema/ScopeInfo.h
  352       llvm::SmallDenseMap<WeakObjectProfileTy, WeakUseVector, 8,
tools/clang/include/clang/Sema/Sema.h
 9513       llvm::SmallDenseMap<const ValueDecl *, const Expr *, 4>;
tools/clang/include/clang/Sema/Template.h
  238         llvm::SmallDenseMap<const Decl *,
tools/clang/include/clang/Serialization/ASTReader.h
  602                       llvm::SmallDenseMap<Decl *, unsigned, 4>,
 1106   llvm::SmallDenseMap<CXXRecordDecl *, llvm::SmallVector<DataPointers, 2>, 2>
 1110   llvm::SmallDenseMap<FunctionDecl *, llvm::SmallVector<FunctionDecl *, 2>, 2>
 1114   llvm::SmallDenseMap<EnumDecl *, llvm::SmallVector<EnumDecl *, 2>, 2>
tools/clang/lib/AST/ASTContext.cpp
 8398   llvm::SmallDenseMap<const ObjCInterfaceDecl *, const ObjCObjectType *, 4>
tools/clang/lib/AST/Linkage.h
   87   llvm::SmallDenseMap<QueryType, LinkageInfo, 8> CachedLinkageInfo;
tools/clang/lib/AST/MicrosoftCXXABI.cpp
   68   llvm::SmallDenseMap<CXXRecordDecl *, CXXConstructorDecl *> RecordToCopyCtor;
   70   llvm::SmallDenseMap<TagDecl *, DeclaratorDecl *>
   72   llvm::SmallDenseMap<TagDecl *, TypedefNameDecl *>
tools/clang/lib/Basic/SourceManager.cpp
 2022   using LocSet = llvm::SmallDenseMap<FileID, unsigned, 16>;
tools/clang/lib/CodeGen/CGDebugInfo.h
   86   llvm::SmallDenseMap<llvm::StringRef, llvm::StringRef> DebugPrefixMap;
   90   llvm::SmallDenseMap<QualType, llvm::Metadata *> SizeExprCache;
tools/clang/lib/CodeGen/CGOpenMPRuntime.cpp
 8301     llvm::SmallDenseMap<
tools/clang/lib/CodeGen/CGOpenMPRuntimeNVPTX.cpp
  232     llvm::SmallDenseMap<const ValueDecl *, const FieldDecl *>
  316   llvm::SmallDenseMap<const ValueDecl *, const FieldDecl *> MappedDeclsFields;
 2040   llvm::SmallDenseMap<const ValueDecl *, const FieldDecl *> MappedDeclsFields;
 2062     llvm::SmallDenseMap<const ValueDecl *, const FieldDecl *>
 2068         llvm::SmallDenseMap<const ValueDecl *, const FieldDecl *>
 3625     const llvm::SmallDenseMap<const ValueDecl *, const FieldDecl *>
 3730     const llvm::SmallDenseMap<const ValueDecl *, const FieldDecl *>
 3825     const llvm::SmallDenseMap<const ValueDecl *, const FieldDecl *>
 3930     const llvm::SmallDenseMap<const ValueDecl *, const FieldDecl *>
 4351     llvm::SmallDenseMap<const ValueDecl *, const FieldDecl *> VarFieldMap;
tools/clang/lib/CodeGen/CGOpenMPRuntimeNVPTX.h
  469   llvm::SmallDenseMap<llvm::Function *, FunctionData> FunctionGlobalizedDecls;
tools/clang/lib/CodeGen/CodeGenFunction.h
  402     llvm::SmallDenseMap<const VarDecl *, FieldDecl *> CaptureFields;
 1235   llvm::SmallDenseMap<const ParmVarDecl *, const ImplicitParamDecl *, 2>
tools/clang/lib/CodeGen/CoverageMappingGen.cpp
  138   llvm::SmallDenseMap<FileID, std::pair<unsigned, SourceLocation>, 8>
tools/clang/lib/CodeGen/CoverageMappingGen.h
   52   llvm::SmallDenseMap<const FileEntry *, unsigned, 8> FileEntries;
tools/clang/lib/CodeGen/ItaniumCXXABI.cpp
 2560   llvm::SmallDenseMap<const VarDecl *, llvm::Function *> UnorderedInits;
tools/clang/lib/Frontend/DiagnosticRenderer.cpp
  376     llvm::SmallDenseMap<FileID, SourceLocation> BeginLocsMap;
tools/clang/lib/Parse/ParseDeclCXX.cpp
 4076   llvm::SmallDenseMap<IdentifierInfo*, SourceLocation, 4> SeenAttrs;
tools/clang/lib/Parse/ParseExpr.cpp
  948         llvm::SmallDenseMap<IdentifierInfo *, tok::TokenKind>::iterator Known
tools/clang/lib/Sema/SemaAttr.cpp
  671     llvm::SmallDenseMap<int, std::pair<int, SourceRange>, 2>
tools/clang/lib/Sema/SemaChecking.cpp
12573   using UsageInfoMap = llvm::SmallDenseMap<Object, UsageInfo, 16>;
tools/clang/lib/Sema/SemaDeclObjC.cpp
  783   llvm::SmallDenseMap<IdentifierInfo *, ObjCTypeParamDecl *> knownParams;
tools/clang/lib/Sema/SemaExprCXX.cpp
 7618   llvm::SmallDenseMap<TypoExpr *, ExprResult, 2> TransformCache;
 7619   llvm::SmallDenseMap<OverloadExpr *, Expr *, 4> OverloadResolution;
tools/clang/lib/Sema/SemaLookup.cpp
  499   llvm::SmallDenseMap<NamedDecl*, unsigned, 16> Unique;
  500   llvm::SmallDenseMap<QualType, unsigned, 16> UniqueTypes;
tools/clang/lib/Sema/SemaOpenMP.cpp
   87   using DeclSAMapTy = llvm::SmallDenseMap<const ValueDecl *, DSAInfo, 8>;
   88   using AlignedMapTy = llvm::SmallDenseMap<const ValueDecl *, const Expr *, 8>;
   91       llvm::SmallDenseMap<const ValueDecl *, LCDeclInfo, 8>;
  117       llvm::SmallDenseMap<const ValueDecl *, ReductionData, 4>;
tools/clang/lib/Sema/SemaTemplate.cpp
 8402   llvm::SmallDenseMap<FunctionDecl *, TemplateArgumentListInfo, 8>
tools/clang/lib/Sema/SemaTemplateDeduction.cpp
 3393     llvm::SmallDenseMap<std::pair<unsigned, QualType>, QualType> DeducedATypes;
tools/clang/lib/Serialization/ASTWriter.cpp
 3102   llvm::SmallDenseMap<const DiagnosticsEngine::DiagState *, unsigned, 64>
tools/clang/lib/StaticAnalyzer/Checkers/BasicObjCFoundationChecks.cpp
  101     mutable llvm::SmallDenseMap<Selector, unsigned, 16> StringSelectors;
tools/clang/tools/extra/clang-tidy/fuchsia/RestrictSystemIncludesCheck.cpp
   53   llvm::SmallDenseMap<FileID, FileIncludes> IncludeDirectives;
tools/clang/tools/extra/clangd/FindTarget.cpp
   88   llvm::SmallDenseMap<const Decl *, RelSet> Decls;
tools/dsymutil/CompileUnit.h
  285   SmallDenseMap<uint64_t, uint64_t, 1> Labels;
tools/lld/COFF/Writer.cpp
  799   SmallDenseMap<std::pair<StringRef, uint32_t>, OutputSection *> sections;
tools/lld/wasm/Writer.cpp
  101   llvm::SmallDenseMap<StringRef, OutputSegment *> segmentMap;
tools/polly/include/polly/ZoneAlgo.h
  154   llvm::SmallDenseMap<llvm::PHINode *, isl::union_map> PerPHIMaps;
tools/polly/lib/CodeGen/BlockGenerators.cpp
 1703   SmallDenseMap<MemoryAccess *, Value *> NewExitScalars;
tools/polly/lib/Transform/Simplify.cpp
  229       SmallDenseMap<Value *, isl::set> ValueSets;
  396       SmallDenseMap<Value *, isl::set> ValueSets;
tools/verify-uselistorder/verify-uselistorder.cpp
  401   SmallDenseMap<const Use *, short, 16> Order;
unittests/ADT/DenseMapTest.cpp
  103                          SmallDenseMap<uint32_t, uint32_t>,
  104                          SmallDenseMap<uint32_t *, uint32_t *>,
  105                          SmallDenseMap<CtorTester, CtorTester, 4,
  562   SmallDenseMap<unsigned, unsigned, 32, ContiguousDenseMapInfo> map;
unittests/ProfileData/CoverageMappingTest.cpp
  110   SmallDenseMap<unsigned, unsigned> ReverseVirtualFileMapping;
utils/TableGen/AsmMatcherEmitter.cpp
 1816   SmallDenseMap<StringRef, int> OperandRefs;