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

Declarations

usr/include/c++/7.4.0/bits/stl_multiset.h
   69     class set;

References

include/llvm/ADT/DAGDeltaAlgorithm.h
   46   using changeset_ty = std::set<change_ty>;
include/llvm/ADT/DeltaAlgorithm.h
   39   using changeset_ty = std::set<change_ty>;
   45   std::set<changeset_ty> FailedTestsCache;
include/llvm/ADT/EquivalenceClasses.h
  119   std::set<ECValue> TheMapping;
  144   using iterator = typename std::set<ECValue>::const_iterator;
include/llvm/ADT/SmallSet.h
   37   using SetIterTy = typename std::set<T, C>::const_iterator;
  139   std::set<T, C> Set;
include/llvm/Analysis/DominanceFrontier.h
   43   using DomSetType = std::set<BlockT *>;                // Dom set for a bb
include/llvm/Analysis/DominanceFrontierImpl.h
   76   std::set<BlockT *> tmpSet;
  138     const std::set<BlockT *> &BBs = I->second;
include/llvm/Analysis/IntervalIterator.h
   91   std::set<BasicBlock *> Visited;
include/llvm/Analysis/RegionInfo.h
  298   void verifyWalk(BlockT *BB, std::set<BlockT *> *visitedBB) const;
include/llvm/Analysis/RegionInfoImpl.h
  279 void RegionBase<Tr>::verifyWalk(BlockT *BB, std::set<BlockT *> *visited) const {
  301   std::set<BlockT *> visited;
include/llvm/Analysis/SparsePropagation.h
  133   std::set<Edge> KnownFeasibleEdges;
include/llvm/CodeGen/LiveInterval.h
  208     using SegmentSet = std::set<Segment>;
include/llvm/CodeGen/RegAllocPBQP.h
  494   using NodeSet = std::set<NodeId>;
include/llvm/DebugInfo/DWARF/DWARFVerifier.h
   45     std::set<DieRangeInfo> Children;
   56     typedef std::set<DieRangeInfo>::const_iterator die_range_info_iterator;
   97   std::map<uint64_t, std::set<uint64_t>> ReferenceToDIEOffsets;
include/llvm/ExecutionEngine/JITSymbol.h
  327   using LookupSet = std::set<StringRef>;
include/llvm/ExecutionEngine/Orc/CompileOnDemandLayer.h
   73   using GlobalValueSet = std::set<const GlobalValue *>;
  200       std::set<Function*> StubsToClone;
  224     std::set<Function*>& getStubsToClone(SourceModuleHandle H) {
  258   using PartitioningFtor = std::function<std::set<Function*>(Function&)>;
include/llvm/ExecutionEngine/Orc/Core.h
  508     std::set<std::shared_ptr<AsynchronousSymbolQuery>>;
include/llvm/ExecutionEngine/Orc/Legacy.h
  102   std::set<SymbolStringPtr> ResolvedStrings;
include/llvm/ExecutionEngine/Orc/RPCSerialization.h
  183 template <typename T> class RPCTypeName<std::set<T>> {
  614 class SerializationTraits<ChannelT, std::set<T>, std::set<T2>> {
  614 class SerializationTraits<ChannelT, std::set<T>, std::set<T2>> {
  617   static Error serialize(ChannelT &C, const std::set<T2> &S) {
  629   static Error deserialize(ChannelT &C, std::set<T2> &S) {
include/llvm/ExecutionEngine/Orc/RTDyldObjectLinkingLayer.h
  121                   std::set<StringRef> &InternalSymbols);
include/llvm/IR/ModuleSummaryIndex.h
  967   std::set<std::string> CfiFunctionDefs;
  968   std::set<std::string> CfiFunctionDecls;
 1133   std::set<std::string> &cfiFunctionDefs() { return CfiFunctionDefs; }
 1134   const std::set<std::string> &cfiFunctionDefs() const { return CfiFunctionDefs; }
 1136   std::set<std::string> &cfiFunctionDecls() { return CfiFunctionDecls; }
 1137   const std::set<std::string> &cfiFunctionDecls() const { return CfiFunctionDecls; }
include/llvm/LTO/LTO.h
   76     const std::set<GlobalValue::GUID> &CfiFunctionDefs = {},
   77     const std::set<GlobalValue::GUID> &CfiFunctionDecls = {});
include/llvm/MCA/Pipeline.h
   58   std::set<HWEventListener *> Listeners;
include/llvm/MCA/Stages/Stage.h
   29   std::set<HWEventListener *> Listeners;
   35   const std::set<HWEventListener *> &getListeners() const { return Listeners; }
include/llvm/ProfileData/SampleProf.h
  218   using SortedCallTargetSet = std::set<CallTarget, CallTargetComparator>;
include/llvm/ProfileData/SampleProfWriter.h
  127   inline void stablizeNameTable(std::set<StringRef> &V);
include/llvm/TextAPI/ELF/ELFStub.h
   59   std::set<ELFSymbol> Symbols;
include/llvm/Transforms/IPO/DeadArgumentElimination.h
  109   using LiveSet = std::set<RetOrArg>;
  110   using LiveFuncSet = std::set<const Function *>;
include/llvm/Transforms/IPO/LowerTypeTests.h
   35   std::set<uint64_t> Bits;
  140   void addFragment(const std::set<uint64_t> &F);
  192   void allocate(const std::set<uint64_t> &Bits, uint64_t BitSize,
include/llvm/Transforms/IPO/WholeProgramDevirt.h
  247     ModuleSummaryIndex &Summary, std::set<GlobalValue::GUID> &ExportedGUIDs,
lib/Bitcode/Reader/BitcodeReader.cpp
 6151       std::set<std::string> &CfiFunctionDefs = TheIndex.cfiFunctionDefs();
 6159       std::set<std::string> &CfiFunctionDecls = TheIndex.cfiFunctionDecls();
lib/Bitcode/Writer/BitcodeWriter.cpp
 3554                      std::set<GlobalValue::GUID> &ReferencedTypeIds) {
 3973   std::set<GlobalValue::GUID> ReferencedTypeIds;
 3985   std::set<GlobalValue::GUID> DefOrUseGUIDs;
lib/CodeGen/AggressiveAntiDepBreaker.cpp
  200   std::set<unsigned> PassthruRegs;
  249     MachineInstr &MI, std::set<unsigned> &PassthruRegs) {
  355     MachineInstr &MI, unsigned Count, std::set<unsigned> &PassthruRegs) {
  824     std::set<unsigned> PassthruRegs;
lib/CodeGen/AggressiveAntiDepBreaker.h
  166     void GetPassthruRegs(MachineInstr &MI, std::set<unsigned> &PassthruRegs);
  173                             std::set<unsigned> &PassthruRegs);
lib/CodeGen/CalcSpillWeights.cpp
  204   std::set<CopyHint> CopyHints;
  268     std::set<unsigned> HintedRegs;
lib/CodeGen/InterleavedLoadCombinePass.cpp
   93   LoadInst *findFirstLoad(const std::set<LoadInst *> &LIs);
  663   std::set<LoadInst *> LIs;
  666   std::set<Instruction *> Is;
 1101 InterleavedLoadCombineImpl::findFirstLoad(const std::set<LoadInst *> &LIs) {
 1128   std::set<LoadInst *> LIs;
 1129   std::set<Instruction *> Is;
 1130   std::set<Instruction *> SVIs;
lib/CodeGen/RegAllocPBQP.cpp
  150   using RegSet = std::set<unsigned>;
  325     using IntervalSet = std::set<IntervalInfo, decltype(&lowestEndPoint)>;
lib/CodeGen/SelectionDAG/SelectionDAG.cpp
 8868 static ManagedStatic<std::set<EVT, EVT::compareRawBits>> EVTs;
lib/DebugInfo/DWARF/DWARFVerifier.cpp
  643   for (const std::pair<uint64_t, std::set<uint64_t>> &Pair :
lib/ExecutionEngine/Orc/OrcMCJITReplacement.h
  490   using SectionAddrSet = std::set<const void *>;
lib/ExecutionEngine/Orc/RTDyldObjectLinkingLayer.cpp
  108   auto InternalSymbols = std::make_shared<std::set<StringRef>>();
  153     std::set<StringRef> &InternalSymbols) {
lib/ExecutionEngine/Orc/ThreadSafeModule.cpp
   30       std::set<GlobalValue *> ClonedDefsInSrc;
lib/LTO/LTO.cpp
   77     const std::set<GlobalValue::GUID> &CfiFunctionDefs,
   78     const std::set<GlobalValue::GUID> &CfiFunctionDecls) {
  175   std::set<GlobalValue::GUID> UsedCfiDefs;
  176   std::set<GlobalValue::GUID> UsedCfiDecls;
  179   std::set<GlobalValue::GUID> UsedTypeIds;
  640                           std::set<const Comdat *> &NonPrevailingComdats) {
  709   std::set<const Comdat *> NonPrevailingComdats;
 1055   std::set<GlobalValue::GUID> CfiFunctionDefs;
 1056   std::set<GlobalValue::GUID> CfiFunctionDecls;
 1297   std::set<GlobalValue::GUID> ExportedGUIDs;
lib/LTO/ThinLTOCodeGenerator.cpp
  977   std::set<GlobalValue::GUID> ExportedGUIDs;
lib/ProfileData/SampleProfWriter.cpp
  304 void SampleProfileWriterBinary::stablizeNameTable(std::set<StringRef> &V) {
  315   std::set<StringRef> V;
  353   std::set<StringRef> V;
lib/Support/CachePruning.cpp
  204   std::set<FileInfo> FileInfos;
lib/Support/DAGDeltaAlgorithm.cpp
   60   typedef std::set<change_ty>::iterator pred_closure_iterator_ty;
   61   typedef std::set<change_ty>::iterator succ_closure_iterator_ty;
   71   mutable std::set<changeset_ty> FailedTestsCache;
   77   std::map<change_ty, std::set<change_ty> > PredClosure;
   78   std::map<change_ty, std::set<change_ty> > SuccClosure;
  206     std::set<change_ty> &ChangeSuccs = SuccClosure[Change];
lib/Support/TrigramIndex.cpp
   34   std::set<unsigned> Was;
lib/Target/AArch64/AArch64A57FPLoadBalancing.cpp
  193   std::set<MachineInstr*> Insts;
lib/Target/AMDGPU/R600ControlFlowFinalizer.cpp
  297                               std::set<unsigned> &DstRegs) const {
  338     std::set<unsigned> DstRegs;
  495   void CounterPropagateAddr(const std::set<MachineInstr *> &MIs,
  520       std::vector<std::pair<unsigned, std::set<MachineInstr *>>> LoopStack;
  574           std::pair<unsigned, std::set<MachineInstr *>> Pair(CfCount,
  584           std::pair<unsigned, std::set<MachineInstr *>> Pair =
lib/Target/AMDGPU/SIMachineScheduler.cpp
  685   std::set<unsigned> FormingGroup;
  805   std::map<std::set<unsigned>, unsigned> ColorCombinations;
  818     std::set<unsigned> SUColors;
  842       std::map<std::set<unsigned>, unsigned>::iterator Pos =
  860     std::set<unsigned> SUColors;
  884       std::map<std::set<unsigned>, unsigned>::iterator Pos =
  943     std::set<unsigned> SUColors;
  944     std::set<unsigned> SUColorsPending;
  978   std::set<unsigned> SeenColors;
 1013     std::set<unsigned> SUColors;
 1039     std::set<unsigned> SUColors;
 1060     std::set<unsigned> SUColors;
 1089     std::set<unsigned> SUColors;
 1472         std::set<unsigned> PredOutRegs = Pred->getOutRegs();
 1473         std::set<unsigned>::iterator RegPos = PredOutRegs.find(Reg);
 1508   std::set<unsigned> InRegs = DAG->getInRegs();
 1519       const std::set<unsigned> &OutRegs = Block->getOutRegs();
 1536         std::set<unsigned> PredOutRegs = Pred->getOutRegs();
 1537         std::set<unsigned>::iterator RegPos = PredOutRegs.find(Reg);
 1690 void SIScheduleBlockScheduler::addLiveRegs(std::set<unsigned> &Regs) {
 1701                                        std::set<unsigned> &Regs) {
 1704     std::set<unsigned>::iterator Pos = LiveRegs.find(Reg);
 1746 SIScheduleBlockScheduler::checkRegUsageImpact(std::set<unsigned> &InRegs,
 1747                                      std::set<unsigned> &OutRegs) {
lib/Target/AMDGPU/SIMachineScheduler.h
   87   std::set<unsigned> LiveInRegs;
   88   std::set<unsigned> LiveOutRegs;
  163   std::set<unsigned> &getInRegs() { return LiveInRegs; }
  164   std::set<unsigned> &getOutRegs() { return LiveOutRegs; }
  328   std::set<unsigned> LiveRegs;
  396   void addLiveRegs(std::set<unsigned> &Regs);
  397   void decreaseLiveRegs(SIScheduleBlock *Block, std::set<unsigned> &Regs);
  403   std::vector<int> checkRegUsageImpact(std::set<unsigned> &InRegs,
  404                                        std::set<unsigned> &OutRegs);
  472   std::set<unsigned> getInRegs() {
  473     std::set<unsigned> InRegs;
  480   std::set<unsigned> getOutRegs() {
  481     std::set<unsigned> OutRegs;
lib/Target/ARM/A15SDOptimizer.cpp
  126     std::set<MachineInstr *> DeadInstr;
  359    std::set<MachineInstr *> Reached;
lib/Target/ARM/ARMCodeGenPrepare.cpp
  152   std::set<Value*> AllVisited;
lib/Target/ARM/ARMParallelDSP.cpp
  372   using InstSet = std::set<Instruction*>;
lib/Target/Hexagon/BitTracker.h
   68   using EdgeSetType = std::set<CFGEdge>;
   69   using InstrSetType = std::set<const MachineInstr *>;
lib/Target/Hexagon/HexagonBlockRanges.h
   40   using RegisterSet = std::set<RegisterRef>;
lib/Target/Hexagon/HexagonCommonGEP.cpp
   70   using NodeSet = std::set<GepNode *>;
  467   using NodeSymRel = std::set<NodeSet>;
  469   using NodePairSet = std::set<NodePair>;
lib/Target/Hexagon/HexagonConstExtenders.cpp
 1354   std::set<int32_t> CandSet;
lib/Target/Hexagon/HexagonConstPropagation.cpp
  267     using SetOfCFGEdge = std::set<CFGEdge>;
  268     using SetOfInstr = std::set<const MachineInstr *>;
lib/Target/Hexagon/HexagonExpandCondsets.cpp
  208     void updateLiveness(std::set<unsigned> &RegSet, bool Recalc,
  216     bool split(MachineInstr &MI, std::set<unsigned> &UpdRegs);
  230     bool predicate(MachineInstr &TfrI, bool Cond, std::set<unsigned> &UpdRegs);
  232         std::set<unsigned> &UpdRegs);
  238                           std::set<unsigned> &UpdRegs);
  468   std::set<RegisterRef> DefRegs;
  550 void HexagonExpandCondsets::updateLiveness(std::set<unsigned> &RegSet,
  663                                   std::set<unsigned> &UpdRegs) {
  935                                       std::set<unsigned> &UpdRegs) {
 1069       std::set<unsigned> &UpdRegs) {
 1190       std::set<unsigned> &UpdRegs) {
 1264   std::set<unsigned> CoalUpd, PredUpd;
 1281   std::set<unsigned> KillUpd;
lib/Target/Hexagon/HexagonGenPredicate.cpp
  103     using SetOfReg = std::set<RegisterSubReg>;
lib/Target/Hexagon/HexagonHardwareLoops.cpp
 1618   using RegisterInductionSet = std::set<RegisterInduction>;
lib/Target/Hexagon/HexagonISelDAGToDAGHVX.cpp
  127   std::set<Node> Needed;
  129   using NodeSet = std::set<Node>;
 1825   std::set<CycleType> Cycles;
 1826   std::set<unsigned> All;
lib/Target/Hexagon/HexagonLoopIdiomRecognition.cpp
  192       std::set<Value*> S;
  195     using ValueSetType = std::set<Value *>;
lib/Target/Hexagon/HexagonSplitDouble.cpp
   89     using USet = std::set<unsigned>;
 1127   using MISet = std::set<MachineInstr *>;
lib/Target/Hexagon/HexagonVectorLoopCarriedReuse.cpp
  288     std::set<Instruction *> ReplacedInsts;
lib/Target/Hexagon/MCTargetDesc/HexagonMCChecker.h
   52   using SoftDefsIterator = std::set<unsigned>::iterator;
   53   std::set<unsigned> SoftDefs;
   56   using TmpDefsIterator = std::set<unsigned>::iterator;
   57   std::set<unsigned> TmpDefs;
   60   using NewPredsIterator = std::set<unsigned>::iterator;
   61   std::set<unsigned> NewPreds;
   68   using UsesIterator = std::set<unsigned>::iterator;
   69   std::set<unsigned> Uses;
   72   using ReadOnlyIterator = std::set<unsigned>::iterator;
   73   std::set<unsigned> ReadOnly;
lib/Target/Hexagon/RDFGraph.cpp
 1032   std::set<RegisterId> Defined;
 1077   std::set<RegisterId> Defined;
lib/Target/Hexagon/RDFGraph.h
  412   using RegisterSet = std::set<RegisterRef>;
  513   using NodeSet = std::set<NodeId>;
lib/Target/Hexagon/RDFLiveness.h
   50     using NodeRefSet = std::set<NodeRef>;
  124     std::map<MachineBasicBlock*,std::set<MachineBasicBlock*>> IIDF;
lib/Target/Hexagon/RDFRegisters.cpp
  101 std::set<RegisterId> PhysicalRegisterInfo::getAliasSet(RegisterId Reg) const {
  103   std::set<RegisterId> AS;
lib/Target/Hexagon/RDFRegisters.h
  121     std::set<RegisterId> getAliasSet(RegisterId Reg) const;
lib/Target/RISCV/RISCVMergeBaseOffset.cpp
   62   std::set<MachineInstr *> DeadInstrs;
lib/Target/SystemZ/SystemZMachineScheduler.h
   89   struct SUSet : std::set<SUnit*, SUSorter> {
lib/Target/SystemZ/SystemZTDC.cpp
   81   std::set<Instruction *> PossibleJunk;
lib/Target/WebAssembly/WebAssemblyLowerEmscriptenEHSjLj.cpp
  250   std::set<std::string> EHWhitelistSet;
lib/TextAPI/ELF/TBEHandler.cpp
  117   static void inputOne(IO &IO, StringRef Key, std::set<ELFSymbol> &Set) {
  123   static void output(IO &IO, std::set<ELFSymbol> &Set) {
lib/TextAPI/MachO/TextStub.cpp
  458       std::set<ArchitectureSet> ArchSet;
  848             std::set<TargetList> TargetSet;
  995       std::set<TargetList> targetSet;
lib/Transforms/IPO/ArgumentPromotion.cpp
  114   using ScalarizeTable = std::set<std::pair<Type *, IndicesVector>>;
  516                      std::set<IndicesVector> &Set) {
  517   std::set<IndicesVector>::iterator Low;
  535                             std::set<IndicesVector> &Safe) {
  536   std::set<IndicesVector>::iterator Low;
  557   std::set<IndicesVector>::iterator End = Safe.end();
  559     std::set<IndicesVector>::iterator Remove = Low;
  572   using GEPIndicesSet = std::set<IndicesVector>;
lib/Transforms/IPO/FunctionImport.cpp
 1084   std::set<StringRef> ModuleNameOrderedList;
lib/Transforms/IPO/LowerTypeTests.cpp
  181 void GlobalLayoutBuilder::addFragment(const std::set<uint64_t> &F) {
  210 void ByteArrayBuilder::allocate(const std::set<uint64_t> &Bits,
  246   std::set<uint64_t> Bits;
 1598   std::vector<std::set<uint64_t>> TypeMembers(TypeIds.size());
 1614     std::set<uint64_t> &TMSet = TypeMembers.back();
lib/Transforms/IPO/MergeFunctions.cpp
  226   using FnTreeType = std::set<FunctionNode, FunctionNodeCmp>;
  554   std::set<Instruction *> PDIRelated;
lib/Transforms/IPO/StripSymbols.cpp
  317   std::set<DIGlobalVariableExpression *> LiveGVs;
  325   std::set<DICompileUnit *> LiveCUs;
lib/Transforms/IPO/WholeProgramDevirt.cpp
  494       DenseMap<Metadata *, std::set<TypeMemberInfo>> &TypeIdMap);
  497                             const std::set<TypeMemberInfo> &TypeMemberInfos,
  585   std::set<GlobalValue::GUID> &ExportedGUIDs;
  595       std::set<GlobalValue::GUID> &ExportedGUIDs,
  608                            std::set<ValueInfo> &DevirtTargets);
  705     ModuleSummaryIndex &Summary, std::set<GlobalValue::GUID> &ExportedGUIDs,
  780     DenseMap<Metadata *, std::set<TypeMemberInfo>> &TypeIdMap) {
  814     const std::set<TypeMemberInfo> &TypeMemberInfos, uint64_t ByteOffset) {
  976                                       std::set<ValueInfo> &DevirtTargets) {
 1805   DenseMap<Metadata *, std::set<TypeMemberInfo>> TypeIdMap;
 1975   std::set<ValueInfo> DevirtTargets;
lib/Transforms/Instrumentation/ControlHeightReduction.cpp
  515 static std::set<Value *> getBaseValues(
  517     DenseMap<Value *, std::set<Value *>> &Visited) {
  521   std::set<Value *> Result;
  532       std::set<Value *> OpResult = getBaseValues(Op, DT, Visited);
 1088     std::set<Value *> PrevBases, Bases;
 1089     DenseMap<Value *, std::set<Value *>> Visited;
 1091       std::set<Value *> BaseValues = getBaseValues(V, DT, Visited);
 1095       std::set<Value *> BaseValues = getBaseValues(V, DT, Visited);
 1108     std::set<Value *> Intersection;
lib/Transforms/Instrumentation/DataFlowSanitizer.cpp
  406   DenseMap<Value *, std::set<Value *>> ShadowElements;
 1146   std::set<Value *> UnionElems;
lib/Transforms/Scalar/LoopFuse.cpp
  397 using FusionCandidateSet = std::set<FusionCandidate, FusionCandidateCompare>;
lib/Transforms/Scalar/LoopLoadElimination.cpp
  387     std::set<Value *> CandLoadPtrs;
lib/Transforms/Scalar/LoopUnswitch.cpp
  835                                          std::set<BasicBlock*> &Visited) {
  869   std::set<BasicBlock*> Visited;
lib/Transforms/Scalar/NewGVN.cpp
 3312   std::set<
lib/Transforms/Scalar/RewriteStatepointsForGC.cpp
 2176   std::set<CallBase *> Uniqued;
lib/Transforms/Utils/LoopSimplify.cpp
  165                                   std::set<BasicBlock*> &Blocks) {
  289   std::set<BasicBlock*> BlocksInL;
lib/Transforms/Utils/SimplifyCFG.cpp
 1066         std::set<ConstantInt *, ConstantIntOrdering> PTIHandled;
 1121         std::set<ConstantInt *, ConstantIntOrdering> PTIHandled;
lib/Transforms/Vectorize/SLPVectorizer.cpp
 4872   std::set<ScheduleData *, ScheduleDataCompare> ReadyInsts;
tools/bugpoint/CrashDebugger.cpp
  151   std::set<GlobalVariable *> GVSet;
  245   std::set<Function *> Functions;
tools/bugpoint/ExtractFunction.cpp
   59   std::set<Constant *> Done;
  323   std::set<Function *> TestFunctions;
tools/clang/examples/PrintFunctionNames/PrintFunctionNames.cpp
   27   std::set<std::string> ParsedTemplates;
   31                          std::set<std::string> ParsedTemplates)
   56       const std::set<std::string> &ParsedTemplates;
   57       Visitor(const std::set<std::string> &ParsedTemplates)
   66       std::set<FunctionDecl*> LateParsedDecls;
   80   std::set<std::string> ParsedTemplates;
tools/clang/include/clang/Analysis/PathDiagnostic.h
  722 using FilesToLineNumsMap = std::map<FileID, std::set<unsigned>>;
tools/clang/include/clang/Lex/PreprocessorOptions.h
   92   std::set<std::string> DeserializedPCHDeclsToErrorOn;
tools/clang/include/clang/Sema/Sema.h
 9180   llvm::DenseMap<const Type*, std::set<std::string>> OpenCLTypeExtMap;
 9182   llvm::DenseMap<const Decl*, std::set<std::string>> OpenCLDeclExtMap;
tools/clang/include/clang/Serialization/ASTReader.h
  882   llvm::DenseMap<const Type *, std::set<std::string>> OpenCLTypeExtMap;
  885   llvm::DenseMap<const Decl *, std::set<std::string>> OpenCLDeclExtMap;
tools/clang/include/clang/Tooling/Core/Replacement.h
  211   using ReplacementsImpl = std::set<Replacement>;
tools/clang/include/clang/Tooling/Inclusions/HeaderIncludes.h
  127   std::set<int> Priorities;
tools/clang/lib/AST/InheritViz.cpp
   37   std::set<QualType, QualTypeOrdering> KnownVirtualBases;
tools/clang/lib/AST/MicrosoftMangle.cpp
  277   typedef std::set<std::pair<int, bool>> PassObjectSizeArgsSet;
tools/clang/lib/AST/VTableBuilder.cpp
 2045         std::set<std::string> ClassNames;
 3461   typedef std::set<const CXXMethodDecl *> OverriderSetTy;
tools/clang/lib/ASTMatchers/ASTMatchFinder.cpp
  816   llvm::DenseMap<const Type*, std::set<const TypedefNameDecl*> > TypeAliases;
tools/clang/lib/ASTMatchers/Dynamic/Registry.cpp
  541                                      const std::set<ASTNodeKind> &KS) {
  543   for (std::set<ASTNodeKind>::const_iterator I = KS.begin(), E = KS.end();
  569   std::set<ArgKind> TypeSet(std::begin(InitialTypes), std::end(InitialTypes));
  595     std::set<ASTNodeKind> RetKinds;
  630           std::set<ASTNodeKind> MatcherKinds;
tools/clang/lib/Driver/Driver.cpp
 2513       std::set<CudaArch> GpuArchs;
tools/clang/lib/Driver/ToolChains/Gnu.h
  205     std::set<std::string> CandidateGCCInstallPaths;
tools/clang/lib/Format/Format.cpp
 1504     std::set<unsigned> DeletedLines;
 1527                            std::set<unsigned> &DeletedLines) {
 1671   std::set<FormatToken *, FormatTokenLess> DeletedTokens;
 2294   std::set<llvm::StringRef> HeadersToDelete;
tools/clang/lib/Format/UnwrappedLineFormatter.cpp
  942     std::set<LineState *, CompareLineStatePointers> Seen;
tools/clang/lib/Frontend/FrontendAction.cpp
  106   std::set<std::string> NamesToCheck;
  110                            const std::set<std::string> &NamesToCheck,
tools/clang/lib/Frontend/InterfaceStubFunctionsConsumer.cpp
   23   std::set<std::string> ParsedTemplates;
  227       std::set<const NamedDecl *> LateParsedDecls;
  228       std::set<NamedDecl *> NamedDecls;
  229       std::set<const ValueDecl *> ValueDecls;
tools/clang/lib/Sema/SemaCast.cpp
 1473     std::set<unsigned> DisplayedPaths;
tools/clang/lib/Sema/SemaDeclCXX.cpp
 2928   std::set<unsigned> DisplayedPaths;
tools/clang/lib/Sema/SemaLookup.cpp
 2565     std::set<Decl *> DeclsPrinted;
tools/clang/lib/Serialization/ASTWriter.cpp
 4337   const llvm::DenseMap<const Type *, std::set<std::string>> &OpenCLTypeExtMap =
 4339   using ElementTy = std::pair<TypeID, const std::set<std::string> *>;
 4355     const std::set<std::string> *ExtSet = E.second;
 4370   const llvm::DenseMap<const Decl *, std::set<std::string>> &OpenCLDeclExtMap =
 4372   using ElementTy = std::pair<DeclID, const std::set<std::string> *>;
 4387     const std::set<std::string> *ExtSet = E.second;
tools/clang/lib/StaticAnalyzer/Core/BugReporter.cpp
 2025     std::set<llvm::FoldingSetNodeID> DeduplicationSet;
tools/clang/lib/Tooling/Refactoring/Rename/USRFindingAction.cpp
  175   std::set<std::string> USRSet;
tools/clang/lib/Tooling/Refactoring/Rename/USRLocFinder.cpp
  103   const std::set<std::string> USRSet;
  493   const std::set<std::string> USRSet;
tools/clang/tools/clang-refactor/ClangRefactor.cpp
  479     std::set<std::string> Files;
tools/clang/tools/clang-refactor/TestSupport.cpp
   86   std::set<std::string> Files;
tools/clang/tools/driver/driver.cpp
   70 static const char *GetStableCStr(std::set<std::string> &SavedStrings,
  105                                std::set<std::string> &SavedStrings) {
  177                             std::set<std::string> &SavedStrings) {
  211                                     std::set<std::string> &SavedStrings) {
  419   std::set<std::string> SavedStrings;
tools/clang/tools/extra/clang-apply-replacements/lib/Tooling/ApplyReplacements.cpp
  142   std::set<StringRef> Warned;
  148   llvm::DenseMap<const FileEntry *, std::set<tooling::Replacement>>
tools/clang/tools/extra/clang-change-namespace/tool/ClangChangeNamespace.cpp
  140   std::set<llvm::StringRef> ChangedFiles;
tools/clang/tools/extra/clang-move/tool/ClangMove.cpp
  186     std::set<llvm::StringRef> Files;
tools/clang/tools/extra/clang-tidy/bugprone/LambdaFunctionNameCheck.h
   34   using SourceRangeSet = std::set<SourceRange, SourceRangeLessThan>;
tools/clang/tools/extra/clang-tidy/modernize/UseEqualsDefaultCheck.cpp
   23 static std::set<const FieldDecl *>
   25   std::set<const FieldDecl *> Result;
   37 static std::set<const Type *> getAllDirectBases(const CXXRecordDecl *Record) {
   38   std::set<const Type *> Result;
tools/clang/tools/extra/clang-tidy/readability/BracesAroundStatementsCheck.h
   60   std::set<const Stmt *> ForceBracesStmts;
tools/clang/tools/extra/clang-tidy/utils/IncludeInserter.h
   75   llvm::DenseMap<FileID, std::set<std::string>> InsertedHeaders;
tools/clang/tools/extra/clang-tidy/utils/UsingInserter.h
   43   std::set<NameInFunction> AddedUsing;
tools/clang/tools/extra/clangd/CodeComplete.cpp
  533     std::set<std::string> Results;
tools/clang/tools/extra/clangd/Diagnostics.cpp
  443   std::set<std::pair<Range, std::string>> SeenDiags;
tools/clang/tools/extra/clangd/index/Ref.h
  104     llvm::DenseMap<SymbolID, std::set<Ref>> Refs;
tools/clang/tools/extra/clangd/unittests/ExpectedTypeTest.cpp
   49   using EquivClass = std::set<std::string>;
tools/clang/tools/extra/clangd/unittests/SourceCodeTests.cpp
  393   std::set<std::string> ActualWords(Words.keys().begin(), Words.keys().end());
  394   std::set<std::string> ExpectedWords = {"define",  "fizz",    "buzz",  "this",
tools/clang/unittests/ASTMatchers/ASTMatchersTraversalTest.cpp
 2291       std::set<const void *> Parents;
tools/clang/unittests/Tooling/ReplacementTest.h
   27 toReplacements(const std::set<tooling::Replacement> &Replaces) {
tools/clang/unittests/libclang/TestUtils.h
   24   std::set<std::string> Files;
tools/clang/utils/TableGen/ClangASTNodesEmitter.cpp
  218   typedef std::set<Record*> RecordSet;
tools/clang/utils/TableGen/ClangAttrEmitter.cpp
  163   std::set<std::string> Seen;
 1600   std::set<std::string> Uniques;
 3384   static std::set<std::string> CustomSubjectSet;
 3532   static std::set<std::string> CustomLangOptsSet;
 3592   static std::set<std::string> CustomTargetSet;
 3723   std::set<std::string> Seen;
 3989       std::set<std::string> Uniques;
tools/clang/utils/TableGen/ClangDiagnosticsEmitter.cpp
 1636 std::set<std::string>
 1639   std::set<std::string> States;
tools/clang/utils/TableGen/MveEmitter.cpp
  598   std::set<unsigned> AddressArgs;
  599   std::set<unsigned> IntConstantArgs;
  601                   std::set<unsigned> AddressArgs,
  602                   std::set<unsigned> IntConstantArgs)
 1026       std::set<unsigned> AddressArgs;
 1029       std::set<unsigned> IntConstantArgs;
 1440   std::set<std::string> ShortNamesSeen;
 1455   std::map<std::string, std::set<std::string>> Checks;
 1521   std::map<MergeableGroup, std::set<OutputIntrinsic>> MergeableGroupsPrelim;
 1544   std::map<MergeableGroup, std::set<OutputIntrinsic>> MergeableGroups;
tools/clang/utils/TableGen/NeonEmitter.cpp
  324   std::set<Intrinsic *> Dependencies;
  386   const std::set<Intrinsic *> &getDependencies() const { return Dependencies; }
 2105   std::set<std::string> Builtins;
 2229   std::set<std::string> Emitted;
tools/lld/COFF/Config.h
  118   std::set<std::string> noDefaultLibs;
  126   std::set<std::string> delayLoads;
tools/lld/COFF/Driver.cpp
 1557   std::set<sys::fs::UniqueID> wholeArchives;
tools/lld/COFF/Driver.h
  109   std::set<llvm::sys::fs::UniqueID> visitedFiles;
  111   std::set<std::string> visitedLibs;
tools/lld/COFF/DriverUtils.cpp
  623   std::set<uint16_t> ords;
tools/lld/include/lld/Core/Resolver.h
   82   std::set<const Atom *>        _deadStripRoots;
tools/lld/include/lld/ReaderWriter/MachOLinkingContext.h
  452   std::set<StringRef> _existingPaths; // For testing only.
  492   mutable std::set<mach_o::MachODylibFile*> _upwardDylibs;
tools/lld/lib/Core/Resolver.cpp
  217   std::set<File *> seen;
tools/lld/lib/ReaderWriter/FileArchive.cpp
  189   typedef std::set<const char *> InstantiatedSet;
tools/lld/lib/ReaderWriter/MachO/CompactUnwindPass.cpp
  502     std::set<const Atom *> usedDwarfFrames;
tools/lld/lib/ReaderWriter/MachO/LayoutPass.cpp
  153   std::set<const DefinedAtom *> roots;
tools/lld/lib/ReaderWriter/MachO/MachONormalizedFileFromAtoms.cpp
  802   std::set<const mach_o::MachOFile*> filesWithStabs;
tools/lldb/include/lldb/Core/Disassembler.h
  514       std::map<FileSpec, std::set<uint32_t>> &source_lines_seen);
tools/lldb/include/lldb/DataFormatters/ValueObjectPrinter.h
   36   typedef std::set<uint64_t> InstancePointersSet;
tools/lldb/include/lldb/Expression/ExpressionVariable.h
  245   typedef std::set<lldb::IRExecutionUnitSP> ExecutionUnitSet;
tools/lldb/include/lldb/Interpreter/CommandCompletions.h
  180     typedef std::set<ConstString> collection;
tools/lldb/include/lldb/Interpreter/Options.h
  199   typedef std::set<int> OptionSet;
tools/lldb/include/lldb/Symbol/ClangASTImporter.h
  316     std::set<clang::Decl *> m_decls_to_ignore;
tools/lldb/include/lldb/Symbol/Symtab.h
  193       uint32_t value, std::set<const char *> &class_contexts,
  199                             const std::set<const char *> &class_contexts);
tools/lldb/include/lldb/Target/Language.h
   43     typedef std::set<std::unique_ptr<Result>> ResultSet;
  268   static std::set<lldb::LanguageType> GetSupportedLanguages();
tools/lldb/include/lldb/Utility/Broadcaster.h
  111   typedef std::set<lldb::ListenerSP> listener_collection;
tools/lldb/source/API/SBFrame.cpp
  827   std::set<VariableSP> variable_set;
tools/lldb/source/Breakpoint/BreakpointIDList.cpp
  120   std::set<std::string> names_found;
tools/lldb/source/Commands/CommandObjectMemory.cpp
  474         std::set<LanguageType> languages_to_check;
  481         std::set<CompilerType> user_defined_types;
tools/lldb/source/Commands/CommandObjectSource.cpp
  977         std::set<SourceInfo> source_match_set;
tools/lldb/source/Commands/CommandObjectThread.cpp
  145       std::set<UniqueStack> unique_stacks;
  200   bool BucketThread(lldb::tid_t tid, std::set<UniqueStack> &unique_stacks,
  225     std::set<UniqueStack>::iterator matching_stack =
tools/lldb/source/Core/Disassembler.cpp
  328     std::map<FileSpec, std::set<uint32_t>> &source_lines_seen) {
  332       std::set<uint32_t> lines;
  433   std::map<FileSpec, std::set<uint32_t>> source_lines_seen;
tools/lldb/source/Core/IOHandler.cpp
 4439   typedef std::set<uint32_t> BreakpointLines;
 4440   typedef std::set<lldb::addr_t> BreakpointAddrs;
tools/lldb/source/Expression/IRExecutionUnit.cpp
  736     std::set<ConstString> alternates;
tools/lldb/source/Interpreter/Options.cpp
  445       std::set<int> options;
  446       std::set<int>::const_iterator options_pos, options_end;
  865   std::set<OptionGroup *> group_set;
  877   std::set<OptionGroup *> group_set;
tools/lldb/source/Plugins/ExpressionParser/Clang/ClangASTSource.cpp
   41   ScopedLexicalDeclEraser(std::set<const clang::Decl *> &decls,
   48   std::set<const clang::Decl *> &m_active_lexical_decls;
tools/lldb/source/Plugins/ExpressionParser/Clang/ClangASTSource.h
  423   std::set<const clang::Decl *> m_active_lexical_decls;
  424   std::set<const char *> m_active_lookups;
tools/lldb/source/Plugins/ExpressionParser/Clang/ClangModulesDeclVendor.cpp
   91   ReportModuleExportsHelper(std::set<ClangModulesDeclVendor::ModuleID> &exports,
  110   typedef std::set<ModuleID> ImportedModuleSet;
  170     std::set<ClangModulesDeclVendor::ModuleID> &exports,
  188   std::set<ClangModulesDeclVendor::ModuleID> exports_set;
tools/lldb/source/Plugins/Language/CPlusPlus/CPlusPlusLanguage.cpp
  356     const ConstString mangled_name, std::set<ConstString> &alternates) {
tools/lldb/source/Plugins/Language/CPlusPlus/CPlusPlusLanguage.h
  126                                  std::set<ConstString> &candidates);
tools/lldb/source/Plugins/LanguageRuntime/RenderScript/RenderScriptRuntime/RenderScriptx86ABIFixups.cpp
  127                      std::set<llvm::CallInst *> &rs_callsites,
  152   std::set<llvm::CallInst *> rs_callsites;
  224   std::set<llvm::CallInst *> rs_callsites;
  228   std::set<llvm::Function *> rs_functions;
tools/lldb/source/Plugins/ObjectFile/Mach-O/ObjectFileMachO.cpp
 1935                              std::set<lldb::addr_t> &resolver_addresses,
 2499   std::set<lldb::addr_t> resolver_addresses;
 2519   typedef std::set<ConstString> IndirectSymbols;
tools/lldb/source/Plugins/Process/gdb-remote/GDBRemoteCommunicationServerPlatform.h
   68   std::set<lldb::pid_t> m_spawned_pids;
tools/lldb/source/Plugins/SymbolFile/DWARF/DWARFDebugAbbrev.cpp
   73     std::set<dw_form_t> &invalid_forms) const {
  143     std::set<dw_form_t> &invalid_forms) const {
tools/lldb/source/Plugins/SymbolFile/DWARF/DWARFDebugAbbrev.h
   43   void GetUnsupportedForms(std::set<dw_form_t> &invalid_forms) const;
   74   void GetUnsupportedForms(std::set<dw_form_t> &invalid_forms) const;
tools/lldb/source/Plugins/SymbolFile/DWARF/DWARFDebugInfo.cpp
   48   std::set<dw_offset_t> cus_with_data;
tools/lldb/source/Plugins/SymbolFile/DWARF/DebugNamesDWARFIndex.cpp
  236   std::set<DWARFDebugInfoEntry *> seen;
tools/lldb/source/Plugins/SymbolFile/DWARF/SymbolFileDWARF.cpp
  369   std::set<CompilerType> compiler_type_set;
  512         std::set<dw_form_t> invalid_forms;
tools/lldb/source/Plugins/SymbolFile/DWARF/SymbolFileDWARF.h
  418   typedef std::set<lldb_private::Type *> TypeSet;
  483   typedef std::set<lldb::user_id_t> DIERefSet;
tools/lldb/source/Plugins/SymbolFile/PDB/PDBASTParser.h
   71   typedef std::set<clang::NamespaceDecl *> NamespacesSet;
tools/lldb/source/Plugins/SymbolFile/PDB/SymbolFilePDB.cpp
 1317     std::set<uint32_t> resolved_ids;
 1357   std::set<uint32_t> resolved_ids;
 1378   std::set<lldb::addr_t> sym_addresses;
tools/lldb/source/Symbol/ClangASTContext.cpp
 1891   std::set<clang::DeclContext *> path_left;
 9977     std::set<DeclContext *> searched;
10074     std::set<DeclContext *> searched;
tools/lldb/source/Symbol/ClangASTImporter.cpp
  263   std::set<NamedDecl *> m_decls_to_complete;
  264   std::set<NamedDecl *> m_decls_already_completed;
tools/lldb/source/Symbol/Symtab.cpp
  265     std::set<const char *> class_contexts;
  345     uint32_t value, std::set<const char *> &class_contexts,
  397     const std::set<const char *> &class_contexts) {
tools/lldb/source/Symbol/TypeSystem.cpp
  189   std::set<TypeSystem *> visited;
  209   std::set<TypeSystem *> visited;
tools/lldb/source/Target/Language.cpp
  351 std::set<lldb::LanguageType> Language::GetSupportedLanguages() {
  352   std::set<lldb::LanguageType> supported_languages;
tools/lldb/source/Target/Process.cpp
 5869   std::set<ConstString> const_type_names;
tools/lldb/source/Target/TargetList.cpp
  241             std::set<Platform *> platform_set;
tools/lldb/tools/driver/Driver.h
   89     using OptionSet = std::set<char>;
tools/lldb/tools/lldb-vscode/lldb-vscode.cpp
 1704   std::set<std::string> unset_filters;
tools/lldb/unittests/Language/CPlusPlus/CPlusPlusLanguageTest.cpp
  174 static std::set<std::string> FindAlternate(llvm::StringRef Name) {
  175   std::set<ConstString> Results;
  179   std::set<std::string> Strings;
tools/llvm-cfi-verify/lib/FileAnalysis.cpp
  230 std::set<const Instr *>
  232   std::set<const Instr *> CFCrossReferences;
  258 const std::set<object::SectionedAddress> &
tools/llvm-cfi-verify/lib/FileAnalysis.h
  135   std::set<const Instr *>
  142   const std::set<object::SectionedAddress> &getIndirectInstructions() const;
  229   std::set<object::SectionedAddress> IndirectInstructions;
tools/llvm-cfi-verify/lib/GraphBuilder.cpp
  226   std::set<const Instr *> CFCrossRefs =
tools/llvm-config/llvm-config.cpp
   77                            std::set<AvailableComponent *> &VisitedComponents,
  146   std::set<AvailableComponent *> VisitedComponents;
tools/llvm-ifs/llvm-ifs.cpp
  145   static void inputOne(IO &IO, StringRef Key, std::set<IFSSymbol> &Set) {
  152   static void output(IO &IO, std::set<IFSSymbol> &Set) {
  170   std::set<IFSSymbol> Symbols;
  221 int writeTbdStub(const llvm::Triple &T, const std::set<IFSSymbol> &Symbols,
  283 int writeElfStub(const llvm::Triple &T, const std::set<IFSSymbol> &Symbols,
tools/llvm-objcopy/ELF/Object.h
  368   std::set<const SectionBase *, SectionCompare> Sections;
  435   std::set<const SectionBase *, SectionCompare> Sections;
tools/llvm-opt-report/OptReport.cpp
  426                std::set<std::string>> UniqueLIs;
tools/llvm-reduce/deltas/Delta.cpp
  109   std::set<Chunk> UninterestingChunks;
tools/llvm-reduce/deltas/ReduceArguments.cpp
   24                                  const std::set<int> &ArgIndexesToKeep) {
   46   std::set<Argument *> ArgsToKeep;
   83     std::set<int> ArgIndexesToKeep;
tools/llvm-reduce/deltas/ReduceBasicBlocks.cpp
   28                                     std::set<BasicBlock *> BBsToKeep) {
   66                                              std::set<BasicBlock *> BBsToKeep) {
   86   std::set<BasicBlock *> BBsToKeep;
tools/llvm-reduce/deltas/ReduceFunctions.cpp
   27   std::set<Function *> FuncsToKeep;
tools/llvm-reduce/deltas/ReduceGlobalVars.cpp
   23   std::set<GlobalVariable *> GVsToKeep;
tools/llvm-reduce/deltas/ReduceInstructions.cpp
   23   std::set<Instruction *> InstToKeep;
tools/llvm-reduce/deltas/ReduceMetadata.cpp
   26                                   std::set<MDNode *> &SeenNodes,
   27                                   std::set<MDNode *> &NodesToKeep) {
   44                                         const std::set<MDNode *> &NodesToKeep) {
   56   std::set<MDNode *> SeenNodes;
   57   std::set<MDNode *> NodesToKeep;
  106 static void addMetadataToSet(T &MDUser, std::set<MDNode *> &UnnamedNodes) {
  115   std::set<MDNode *> UnnamedNodes;
tools/polly/include/polly/ScopDetection.h
   66 using ParamSetType = std::set<const SCEV *>;
tools/sancov/sancov.cpp
  136   explicit RawCoverage(std::unique_ptr<std::set<uint64_t>> Addrs)
  143   std::unique_ptr<std::set<uint64_t>> Addrs;
  160   std::set<std::string> CoveredIds;
  223                      std::set<uint64_t> *Ints) {
  248   auto Addrs = std::make_unique<std::set<uint64_t>>();
  322         std::set<std::string> WrittenIds;
  521                   const std::set<uint64_t> &Addrs,
  522                   const std::set<uint64_t> &CoveredAddrs) {
  527   std::set<std::string> CoveredFiles;
  550     std::set<DILineInfo> Infos; // deduplicate debug info.
  606                                           std::set<uint64_t> *Result) {
  645 static std::set<uint64_t>
  647   std::set<uint64_t> Result;
  704                                     std::set<uint64_t> *Addrs) {
  808 static std::set<uint64_t>
  810   std::set<uint64_t> Result;
  821 static std::set<uint64_t> findCoveragePointAddrs(const std::string &FileName) {
  822   std::set<uint64_t> Result;
  890   std::set<uint64_t> AllAddrs = findCoveragePointAddrs(ObjectFile);
  909 static std::set<FileFn>
  911   std::set<FileFn> Fns;
  920 static std::set<FileFn>
  936 static std::set<FileFn>
  939   std::set<FileFn> Result;
  956                                      const std::set<FileFn> &Fns) {
 1056     std::set<std::string> CovFiles;
unittests/ADT/DAGDeltaAlgorithmTest.cpp
   38 std::set<unsigned> fixed_set(unsigned N, ...) {
   39   std::set<unsigned> S;
   48 std::set<unsigned> range(unsigned Start, unsigned End) {
   49   std::set<unsigned> S;
   55 std::set<unsigned> range(unsigned N) {
unittests/ADT/DeltaAlgorithmTest.cpp
   18                          const std::set<unsigned> &S) {
   20   for (std::set<unsigned>::const_iterator it = S.begin(),
   53 std::set<unsigned> fixed_set(unsigned N, ...) {
   54   std::set<unsigned> S;
   63 std::set<unsigned> range(unsigned Start, unsigned End) {
   64   std::set<unsigned> S;
   70 std::set<unsigned> range(unsigned N) {
   77   std::set<unsigned> Fails = fixed_set(3, 3, 5, 7);
unittests/ADT/DenseMapTest.cpp
   35   static std::set<CtorTester *> Constructed;
   58 std::set<CtorTester *> CtorTester::Constructed;
unittests/ADT/PostOrderIteratorTest.cpp
   22   po_iterator_storage<std::set<void *>, false> PIS;
unittests/DebugInfo/PDB/StringTableBuilderTest.cpp
   46   std::set<uint32_t> Distinct{FooID, BarID, BazID, BuzzID, BazzID, BarrID};
unittests/ExecutionEngine/Orc/RPCUtilsTest.cpp
  138                                           std::set<int>, std::map<int, bool>)> {
  506     std::set<int> S({7, 42});
unittests/IR/CFGBuilder.h
   87   std::set<Arc> Arcs;
unittests/Transforms/IPO/LowerTypeTests.cpp
   18     std::set<uint64_t> Bits;
   85     std::vector<std::set<uint64_t>> Fragments;
  111     std::set<uint64_t> Bits;
unittests/XRay/GraphTest.cpp
   65   std::set<unsigned> V({1u, 2u, 3u, 4u, 5u, 6u});
   88   std::set<unsigned> V({1u, 2u, 3u, 4u, 5u, 6u});
   90   std::set<std::pair<unsigned, unsigned>> E(
unittests/tools/llvm-cfi-verify/FileAnalysis.cpp
  417   std::set<const Instr *> XRefs =
unittests/tools/llvm-exegesis/X86/RegisterAliasingTest.cpp
   31   std::set<MCPhysReg> ActualAliasedRegisters;
   34   const std::set<MCPhysReg> ExpectedAliasedRegisters = {
usr/include/c++/7.4.0/bits/stl_set.h
  213       set(const set&) = default;
  221       set(set&&) = default;
  245       set(const set& __x, const allocator_type& __a)
  249       set(set&& __x, const allocator_type& __a)
  287       set&
  288       operator=(const set&) = default;
  291       set&
  292       operator=(set&&) = default;
  305       set&
  431       swap(set& __x)
  893 	operator==(const set<_K1, _C1, _A1>&, const set<_K1, _C1, _A1>&);
  893 	operator==(const set<_K1, _C1, _A1>&, const set<_K1, _C1, _A1>&);
  897 	operator<(const set<_K1, _C1, _A1>&, const set<_K1, _C1, _A1>&);
  897 	operator<(const set<_K1, _C1, _A1>&, const set<_K1, _C1, _A1>&);
  913     operator==(const set<_Key, _Compare, _Alloc>& __x,
  914 	       const set<_Key, _Compare, _Alloc>& __y)
  930     operator<(const set<_Key, _Compare, _Alloc>& __x,
  931 	      const set<_Key, _Compare, _Alloc>& __y)
  937     operator!=(const set<_Key, _Compare, _Alloc>& __x,
  938 	       const set<_Key, _Compare, _Alloc>& __y)
  944     operator>(const set<_Key, _Compare, _Alloc>& __x,
  945 	      const set<_Key, _Compare, _Alloc>& __y)
  951     operator<=(const set<_Key, _Compare, _Alloc>& __x,
  952 	       const set<_Key, _Compare, _Alloc>& __y)
  958     operator>=(const set<_Key, _Compare, _Alloc>& __x,
  959 	       const set<_Key, _Compare, _Alloc>& __y)
  965     swap(set<_Key, _Compare, _Alloc>& __x, set<_Key, _Compare, _Alloc>& __y)
  965     swap(set<_Key, _Compare, _Alloc>& __x, set<_Key, _Compare, _Alloc>& __y)
usr/include/c++/7.4.0/tuple
 1313     constexpr __tuple_element_t<__i, tuple<_Elements...>>&
 1319     constexpr const __tuple_element_t<__i, tuple<_Elements...>>&
 1325     constexpr __tuple_element_t<__i, tuple<_Elements...>>&&
utils/TableGen/AsmMatcherEmitter.cpp
  141 typedef std::set<Record*, LessRecordByID> RegisterSet;
 1078   std::set<std::string> OperandNames;
 1218   typedef std::set<RegisterSet, LessRegisterSet> RegisterSetSet;
 2654   std::set<StringRef> Types;
utils/TableGen/AsmWriterEmitter.cpp
  778   typedef std::set<std::pair<CodeGenInstAlias, int>, AliasPriorityComparator>
utils/TableGen/CodeEmitterGen.cpp
   54                                std::set<unsigned> &NamedOpIndices,
   83                         std::set<unsigned> &NamedOpIndices,
  293   std::set<unsigned> NamedOpIndices;
  401   std::set<unsigned> HwModes;
utils/TableGen/CodeGenDAGPatterns.cpp
  753   std::set<MVT> Ovs;
 4226 static void collectModes(std::set<unsigned> &Modes, const TreePatternNode *N) {
 4268     std::set<unsigned> Modes;
utils/TableGen/CodeGenInstruction.cpp
   56   std::set<std::string> OperandNames;
utils/TableGen/CodeGenRegisters.cpp
 1594   std::set<unsigned> AllocatableRegs;
 1931       std::set<unsigned> Intersection;
utils/TableGen/DFAEmitter.cpp
  287   std::set<uint64_t> SeenStates;
utils/TableGen/DFAEmitter.h
   79   std::set<action_type> Actions;
   85   std::set<state_type> NfaStates;
utils/TableGen/DFAPacketizerEmitter.cpp
   96 void dbgsStateInfo(const std::set<unsigned> &stateInfo);
  513   std::set<NfaStateTy> SeenStates;
utils/TableGen/FixedLenDecoderEmitter.cpp
 1849   std::set<std::string> NumberedInsnOperandsNoTie;
 1855     std::set<unsigned> NamedOpIndices;
 2388   std::set<StringRef> HwModeNames;
utils/TableGen/GlobalISelEmitter.cpp
  182 std::set<LLTCodeGen> KnownTypes;
  759   std::set<MatchTableRecord> Values;
utils/TableGen/InfoByHwMode.h
   43   std::set<unsigned> U;
utils/TableGen/RISCVCompressInstEmitter.cpp
  469 static void getReqFeatures(std::set<StringRef> &FeaturesSet,
  613     std::set<StringRef> FeaturesSet;
utils/TableGen/RegisterInfoEmitter.cpp
 1218   std::set<Record*> AllocatableRegs;
utils/TableGen/SearchableTableEmitter.cpp
   93   std::set<std::string> PreprocessorGuards;
utils/benchmark/include/benchmark/benchmark.h
 1439   std::set< std::string > user_counter_names_;
utils/unittest/googlemock/include/gmock/gmock-spec-builders.h
  537   typedef ::std::set<Expectation, Less> Set;
utils/unittest/googlemock/src/gmock-spec-builders.cc
  518 typedef std::set<internal::UntypedFunctionMockerBase*> FunctionMockers;
utils/unittest/googletest/include/gtest/internal/gtest-param-util.h
  565         std::set<std::string> test_param_names;
utils/unittest/googletest/src/gtest-typed-test.cc
   69   std::set<std::string> tests;