LLVM  8.0.1
Namespaces | Macros | Functions | Variables
Debug.h File Reference

Go to the source code of this file.

Namespaces

 llvm
 This class represents lattice values for constants.
 

Macros

#define DEBUG_WITH_TYPE(TYPE, X)
 DEBUG_WITH_TYPE macro - This macro should be used by passes to emit debug information. More...
 
#define LLVM_DEBUG(X)   DEBUG_WITH_TYPE(DEBUG_TYPE, X)
 

Functions

bool llvm::isCurrentDebugType (const char *Type)
 isCurrentDebugType - Return true if the specified string is the debug type specified on the command line, or if none was specified on the command line with the -debug-only=X option. More...
 
void llvm::setCurrentDebugType (const char *Type)
 setCurrentDebugType - Set the current debug type, as if the -debug-only=X option were specified. More...
 
void llvm::setCurrentDebugTypes (const char **Types, unsigned Count)
 setCurrentDebugTypes - Set the current debug type, as if the -debug-only=X,Y,Z option were specified. More...
 
raw_ostreamllvm::dbgs ()
 dbgs() - This returns a reference to a raw_ostream for debugging messages. More...
 

Variables

bool llvm::DebugFlag = false
 This boolean is set to true if the '-debug' command line option is specified. More...
 
bool llvm::EnableDebugBuffering = false
 EnableDebugBuffering - This defaults to false. More...
 
Verification flags.

These flags turns on/off that are expensive and are turned off by default, unless macro EXPENSIVE_CHECKS is defined.

The flags allow selectively turning the checks on without need to recompile.

bool llvm::VerifyDomInfo = false
 Enables verification of dominator trees. More...
 
bool llvm::VerifyLoopInfo = false
 Enables verification of loop info. More...
 
bool llvm::VerifyMemorySSA = false
 Enables verification of MemorySSA. More...
 

Macro Definition Documentation

◆ DEBUG_WITH_TYPE

#define DEBUG_WITH_TYPE (   TYPE,
  X 
)
Value:
do { if (::llvm::DebugFlag && ::llvm::isCurrentDebugType(TYPE)) { X; } \
} while (false)
static GCMetadataPrinterRegistry::Add< ErlangGCPrinter > X("erlang", "erlang-compatible garbage collector")
bool DebugFlag
This boolean is set to true if the &#39;-debug&#39; command line option is specified.
Definition: Debug.cpp:44
bool isCurrentDebugType(const char *Type)
isCurrentDebugType - Return true if the specified string is the debug type specified on the command l...
Definition: Debug.cpp:51

DEBUG_WITH_TYPE macro - This macro should be used by passes to emit debug information.

In the '-debug' option is specified on the commandline, and if this is a debug build, then the code specified as the option to the macro will be executed. Otherwise it will not be. Example:

DEBUG_WITH_TYPE("bitset", dbgs() << "Bitset contains: " << Bitset << "\n");

This will emit the debug information if -debug is present, and -debug-only is not specified, or is specified as "bitset".

Definition at line 65 of file Debug.h.

Referenced by llvm::colorEHFunclets(), llvm::InstructionSelector::executeMatchTable(), llvm::ARMAsmBackendDarwin::generateCompactUnwindEncoding(), llvm::AMDGPULibCalls::initNativeFuncs(), isPermutation(), isValidEncoding(), llvm::MCAssembler::layout(), llvm::object::MachORebaseEntry::moveNext(), llvm::object::MachOBindEntry::moveNext(), llvm::HexagonDAGToDAGISel::PreprocessISelDAG(), llvm::SCEVExpander::replaceCongruentIVs(), llvm::HvxSelector::selectShuffle(), and llvm::AMDGPULibCalls::useNative().

◆ LLVM_DEBUG

#define LLVM_DEBUG (   X)    DEBUG_WITH_TYPE(DEBUG_TYPE, X)

Definition at line 123 of file Debug.h.

Referenced by llvm::InstCombineWorklist::Add(), llvm::SSAUpdaterBulk::AddAvailableValue(), addData(), addDiscriminators(), addEdge(), addForcedAttributes(), llvm::ExecutionEngine::addGlobalMapping(), llvm::InstCombineWorklist::AddInitialGroup(), AddMACCandidate(), addNonNullAttrs(), AddReachableCodeToWorklist(), llvm::mca::RegisterFile::addRegisterWrite(), llvm::LoopAccessInfo::addRuntimeChecks(), addSegmentsWithValNo(), llvm::DIEHash::addSLEB128(), llvm::DIEHash::addULEB128(), llvm::SSAUpdaterBulk::AddUse(), llvm::IVUsers::AddUsersImpl(), llvm::SSAUpdaterBulk::AddVariable(), adjCycles(), llvm::BlockFrequencyInfoImplBase::adjustLoopHeaderMass(), AdjustStackOffset(), llvm::HexagonHazardRecognizer::AdvanceCycle(), llvm::AggressiveAntiDepBreaker::AggressiveAntiDepBreaker(), llvm::RegAllocBase::allocatePhysRegs(), llvm::AllocationOrder::AllocationOrder(), llvm::LoopVectorizeHints::allowVectorization(), allPhiOperandsUndefined(), alwaysAvailable(), llvm::GISelCSEInfo::analyze(), llvm::HexagonInstrInfo::analyzeBranch(), llvm::InterleavedAccessInfo::analyzeInterleaving(), analyzeLoopUnrollCost(), annotateAllFunctions(), AppendEndToFunction(), llvm::mca::Pipeline::appendStage(), llvm::A57ChainingConstraint::apply(), llvm::LegalizeRuleSet::apply(), llvm::RegisterBankInfo::applyDefaultMapping(), llvm::RuntimeDyldImpl::applyExternalSymbolRelocations(), llvm::MemorySSAUpdater::applyInsertUpdates(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::ApplyNextUpdate(), llvm::applyPPChighesta(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::ApplyUpdates(), AreAliased(), areCandidatesToMergeOrPair(), llvm::MemoryDepChecker::areDepsSafe(), areLoopExitPHIsSupported(), AreSequentialAccesses(), areStridedAccessesIndependent(), asmClobbersCTR(), llvm::LiveRegMatrix::assign(), llvm::ARCFrameLowering::assignCalleeSavedSpillSlots(), llvm::HexagonFrameLowering::assignCalleeSavedSpillSlots(), AssignProtectedObjSet(), atomicSizeSupported(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::attachNewSubtree(), llvm::AVRDAGToDAGISel::select< ISD::BRIND >(), BadConditionCode(), llvm::orc::BasicIRLayerMaterializationUnit::BasicIRLayerMaterializationUnit(), BBIsJumpedOver(), llvm::DebugHandlerBase::beginFunction(), bitTrackingDCE(), llvm::LoopVectorizationLegality::blockNeedsPredication(), bothUsedInPHI(), llvm::BranchFolder::BranchFolder(), branchMaxOffsets(), BreakUpSubtract(), BUCompareLatency(), llvm::coro::buildCoroutineFrame(), llvm::CFGMST< Edge, BBInfo >::buildEdges(), buildExtractionBlockSet(), llvm::VPlanSlp::buildGraph(), llvm::VPlanHCFGBuilder::buildHierarchicalCFG(), buildMultiplyTree(), llvm::ScheduleDAGInstrs::buildSchedGraph(), llvm::SchedBoundary::bumpCycle(), llvm::SchedBoundary::bumpNode(), BURRSort(), CalcNodeSethiUllmanNumber(), llvm::BranchProbabilityInfo::calculate(), llvm::BlockFrequencyInfoImpl< llvm::BitTracker >::calculate(), calculateCXXStateNumbers(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::CalculateFromScratch(), calculateOffsetDiff(), llvm::LiveRangeEdit::calculateRegClassAndHint(), llvm::LoopVectorizationCostModel::calculateRegisterUsage(), calculateSEHStateNumbers(), llvm::calculateSpillWeightsAndHints(), calculateUnswitchCostMultiplier(), llvm::DomTreeBuilder::CalculateWithUpdates(), callHasRegMask(), llvm::orc::remote::OrcRemoteTargetClient::callIntVoid(), llvm::orc::remote::OrcRemoteTargetClient::callMain(), callsiteIsHot(), llvm::orc::remote::OrcRemoteTargetClient::callVoidVoid(), canClobberPhysRegDefs(), canCreateAliasFor(), canEnableCoalescing(), canFoldInAddressingMode(), canFoldIVIncExpr(), llvm::LoopVectorizationLegality::canFoldTailByMasking(), llvm::slpvectorizer::BoUpSLP::canMapToVector(), canMoveInstsAcrossMemOp(), llvm::HexagonPacketizerList::canPromoteToDotCur(), CanPropagatePredecessorsForPHIs(), canRenameComdat(), canSafelyUnrollMultiExitLoop(), llvm::MachineBasicBlock::canSplitCriticalEdge(), llvm::TailDuplicator::canTailDuplicate(), canTurnIntoCOPY(), llvm::LoopVectorizationLegality::canVectorize(), llvm::Evaluator::castCallResultIfNeeded(), CC_Lanai32_VarArg(), CC_MipsO32_FP64(), CC_RISCV(), changeFCMPPredToAArch64CC(), llvm::RuntimeDyldCheckerImpl::check(), llvm::GenericScheduler::checkAcyclicLatency(), checkDependencies(), CheckForCanReleaseCFGHazard(), llvm::SchedBoundary::checkHazard(), CheckMACMemory(), checkRegOnlyPHIInputs(), clampStackAlignment(), llvm::HexagonPacketizerList::cleanUpDotCur(), llvm::SplitAnalysis::clear(), llvm::objcarc::PtrState::ClearKnownPositiveRefCount(), llvm::RegionBase< RegionTraits< Function > >::clearNodeCache(), cloneConstantExprWithNewAddressSpace(), CloneLoop(), llvm::FunctionComparator::cmpConstants(), collectFunctionUsers(), llvm::LoopVectorizationCostModel::collectInstsToScalarize(), llvm::ScalarEvolution::collectParametricTerms(), collectPHIs(), combineInstructionsOverFunction(), llvm::Combiner::combineMachineInstrs(), CompareMBBNumbers(), completeEphemeralValues(), llvm::ObjectSizeOffsetVisitor::compute(), llvm::ObjectSizeOffsetEvaluator::compute(), llvm::ScalarEvolution::computeAccessFunctions(), computeBranchTargetAndInversion(), llvm::ComputeCrossModuleImport(), llvm::ComputeCrossModuleImportForModule(), llvm::ScheduleDAGMILive::computeCyclicCriticalPath(), llvm::HexagonBlockRanges::computeDeadMap(), llvm::computeDeadSymbols(), computeImportForFunction(), ComputeImportForModule(), computeImportForReferencedGlobals(), llvm::DivergencePropagator::computeJoinPoints(), llvm::safestack::StackLayout::computeLayout(), llvm::HexagonBlockRanges::computeLiveMap(), computeLiveOuts(), llvm::BlockFrequencyInfoImplBase::computeLoopScale(), llvm::LoopVectorizationCostModel::computeMaxVF(), llvm::computePeelCount(), ComputePostOrders(), llvm::mca::computeProcResourceMasks(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::ComputeUnreachableDominators(), computeUnrollAndJamCount(), llvm::computeUnrollCount(), computeWeight(), ConstantBuildVector(), llvm::constrainSelectedInstRegOperands(), llvm::sys::UnicodeCharSet::contains(), containsNewBackedge(), containsSafePHI(), llvm::ConvertDebugDeclareToDebugValue(), convertFloatingToInteger(), llvm::convertToDeclaration(), llvm::PPCInstrInfo::convertToImmediateForm(), ConvertToSInt(), copyDebugInfoToPredecessor(), copyDebugInfoToSuccessor(), llvm::X86InstrInfo::copyPhysReg(), llvm::SystemZHazardRecognizer::copyState(), llvm::SchedBoundary::countResource(), llvm::createAArch64ConditionOptimizerPass(), createAndInstr(), createBBSelectReg(), llvm::createBlockExtractorPass(), llvm::createBreakFalseDeps(), createCallInst(), createCast(), llvm::createCodeGenPreparePass(), llvm::createConstantHoistingPass(), llvm::createCopyConstrainDAGMutation(), llvm::createFalkorMarkStridedAccessesPass(), llvm::createGenericSchedPostRA(), llvm::createGreedyRegisterAllocator(), llvm::createHexagonHardwareLoops(), llvm::createHWAddressSanitizerPass(), createIrreducibleLoop(), llvm::createLICMPass(), CreateLoadIns(), llvm::createLoopDeletionPass(), llvm::createMergeFunctionsPass(), llvm::createMSP430ISelDag(), llvm::createObjCARCOptPass(), llvm::createPGOIndirectCallPromotionLegacyPass(), llvm::createPGOInstrumentationUseLegacyPass(), createRdxShuffleMask(), llvm::createRegUsageInfoCollector(), createSegmentsForValues(), llvm::createSIFixWWMLivenessPass(), llvm::createSIWholeQuadModePass(), CreateWrapper(), llvm::createX86CondBrFolding(), llvm::createX86FixupBWInsts(), llvm::createX86FixupLEAs(), llvm::createX86OptimizeLEAs(), llvm::createX86RetpolineThunksPass(), CriticalPathStep(), decodeFRMArg(), DecodeGPR32RegisterClass(), DecodeLdLImmInstruction(), DecodeLdRLImmInstruction(), DecodeMoveHRegInstruction(), DecodeStLImmInstruction(), llvm::VPBlockBase::deleteCFG(), deleteDeadInstruction(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::DeleteEdge(), deleteIfDead(), deleteLoopIfDead(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::DeleteReachable(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::DeleteUnreachable(), llvm::ScalarEvolution::delinearize(), llvm::DependenceInfo::depends(), llvm::ARCFrameLowering::determineCalleeSaves(), llvm::ARMFrameLowering::determineCalleeSaves(), llvm::AArch64FrameLowering::determineCalleeSaves(), llvm::HexagonFrameLowering::determineCalleeSaves(), llvm::mca::Scheduler::dispatch(), llvm::orc::ExecutionSession::dispatchMaterialization(), llvm::BlockFrequencyInfoImplBase::distributeIrrLoopHeaderMass(), llvm::BlockFrequencyInfoImplBase::distributeMass(), doCandidateWalk(), llvm::LoopVectorizationRequirements::doesNotMeet(), doPromotion(), llvm::SelectionDAGBuilder::dropDanglingDebugInfo(), llvm::GVNExpression::Expression::dump(), llvm::mca::LSUnit::dump(), llvm::ConstantUniqueMap< llvm::ConstantExpr >::dump(), dumpImportListForModule(), dumpMachineInstrRangeWithSlotIndex(), dumpRelocs(), llvm::JumpThreadingPass::DuplicateCondBranchOnPHIIntoPred(), llvm::ARCFrameLowering::eliminateCallFramePseudoInstr(), eliminateDeadStores(), eliminateDeadSwitchCases(), llvm::ARCRegisterInfo::eliminateFrameIndex(), llvm::XCoreRegisterInfo::eliminateFrameIndex(), llvm::MipsRegisterInfo::eliminateFrameIndex(), eliminateNoopStore(), llvm::DIEAbbrev::Emit(), llvm::RuntimeDyldImpl::emitCommonSymbols(), llvm::ARCFrameLowering::emitEpilogue(), llvm::PPCDispatchGroupSBHazardRecognizer::EmitInstruction(), llvm::WebAssemblyAsmPrinter::EmitInstruction(), llvm::HexagonHazardRecognizer::EmitInstruction(), llvm::SystemZHazardRecognizer::EmitInstruction(), llvm::ScoreboardHazardRecognizer::EmitInstruction(), llvm::ARCFrameLowering::emitPrologue(), llvm::RuntimeDyldImpl::emitSection(), llvm::HexagonMCCodeEmitter::encodeInstruction(), llvm::HexagonMCCodeEmitter::EncodeSingleInstruction(), llvm::HexagonPacketizerList::endPacket(), llvm::VLIWPacketizerList::endPacket(), ensurePromotedGV(), llvm::SplitEditor::enterIntvAfter(), llvm::SplitEditor::enterIntvBefore(), llvm::SystemZPostRASchedStrategy::enterMBB(), eraseDeadBBsAndChildren(), llvm::InstCombiner::eraseInstFromFunction(), llvm::LiveRangeEdit::eraseVirtReg(), llvm::Evaluator::EvaluateBlock(), llvm::Evaluator::EvaluateFunction(), EvaluateStaticConstructor(), llvm::VPBasicBlock::execute(), llvm::VPRegionBlock::execute(), expandBounds(), ExpandBVWithShuffles(), llvm::ARMBaseInstrInfo::expandPostRAPseudo(), llvm::CodeExtractor::extractCodeRegion(), extractInteger(), extractVector(), llvm::SchedDFSImpl::finalize(), llvm::orc::remote::OrcRemoteTargetClient::RemoteRTDyldMemoryManager::finalizeMemory(), llvm::BlockFrequencyInfoImplBase::finalizeMetrics(), llvm::GCNScheduleDAGMILive::finalizeSchedule(), llvm::SMSchedule::finalizeSchedule(), llvm::RuntimeDyldMachOI386::finalizeSection(), llvm::RuntimeDyldMachOARM::finalizeSection(), find_best(), findArgumentCopyElisionCandidates(), llvm::ScalarEvolution::findArrayDimensions(), llvm::SSAUpdaterImpl< UpdaterT >::FindAvailableVals(), findBaseDefiningValueCached(), findBasePointer(), findCalledFunction(), findGCD(), findGluedUser(), FindIDom(), findInitTrampoline(), findInnerReductionPhi(), llvm::CodeExtractor::findInputsOutputs(), findIrreducibleHeaders(), llvm::SchedBoundary::findMaxLatency(), findPartitions(), findPotentialBlockers(), FindPredecessorAutoreleaseWithSafePath(), findProfitablePHIs(), findReturnsToZap(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::FindRoots(), findSingleRegDef(), findStartOfTree(), findUncondBrI(), llvm::RegScavenger::FindUnusedReg(), fixupGlobalSaddr(), llvm::ScheduleDAGInstrs::fixupKills(), fixupRegionExits(), llvm::AMDGPULibCalls::fold(), llvm::foldBlockIntoPredecessor(), llvm::FoldBranchToCommonDest(), foldMaskedShiftToBEXTR(), foldReturnAndProcessPred(), llvm::InstCombiner::FoldShiftByConstant(), FoldTwoEntryPHINode(), llvm::formDedicatedExitBlocks(), llvm::ARMTargetLowering::functionArgumentNeedsConsecutiveRegisters(), llvm::StackSafetyInfo::FunctionInfo::FunctionInfo(), fuseInstructionPair(), llvm::GCNScheduleDAGMILive::GCNScheduleDAGMILive(), llvm::HexagonInstrInfo::genAllInsnTimingClasses(), llvm::RuntimeDyldCOFFX86_64::generateRelocationStub(), generateStackAdjustment(), genLoopLimit(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::ChildrenGetter< Inverse >::Get(), llvm::LegalizerInfo::getAction(), llvm::LegalizerInfo::getActionDefinitionsIdx(), llvm::RegBankSelect::getAnalysisUsage(), llvm::FunctionLoweringInfo::getArgumentFrameIndex(), getBlockName(), getBoundsCheckCond(), getBranchHint(), getChainID(), llvm::MemorySSA::ClobberWalkerBase::getClobberingMemoryAccessBase(), getCmpForPseudo(), getCombinerObjective(), getCompoundInsn(), getConstantPart(), llvm::coverage::CoverageMapping::getCoverageForExpansion(), llvm::coverage::CoverageMapping::getCoverageForFile(), llvm::coverage::CoverageMapping::getCoverageForFunction(), getDIEStringAttr(), getDPPOp(), llvm::HexagonMCInstrInfo::getDuplexPossibilties(), getEdgeValueLocal(), getExpandedMinMaxOps(), getFalkorUnrollingPreferences(), getFilename(), llvm::Evaluator::getFormalParams(), GetFPLibCall(), getFPReg(), llvm::AArch64FrameLowering::getFrameIndexReferencePreferSP(), getFromRangeMetadata(), llvm::ExecutionEngine::getGlobalValueAtAddress(), llvm::HexagonHazardRecognizer::getHazardType(), llvm::ScoreboardHazardRecognizer::getHazardType(), getInductionVariable(), llvm::getInlineCost(), getInstrVecReg(), getIPMConversion(), getLAScore(), getLayoutSuccessorProbThreshold(), getLoadStoreOffsetAlign(), llvm::VNCoercion::getLoadValueForLoad(), GetLoopInvariantInsertPosition(), llvm::orc::IRMaterializationUnit::getName(), getNarrowIntrinsic(), getNewAlignment(), getNewAlignmentDiff(), getNewSource(), getNewValueJumpOpcode(), llvm::DOTGraphTraits< BoUpSLP * >::getNodeAttributes(), llvm::MemoryDependenceResults::getNonLocalCallDependency(), getNotRelocatableInstructions(), getNumAllocatableRegsForConstraints(), getOffsetFromIndices(), getOModValue(), getOnlyLiveSuccessor(), llvm::SchedBoundary::getOtherResourceCount(), GetPointerOperand(), llvm::HexagonInstrInfo::getPredReg(), getPromotedVectorElementType(), GetPromotionOpcode(), llvm::getPtrStride(), GetQuadraticEquation(), getReassignedChan(), getRegClassForUnfoldedLoad(), getRegClassFromGRPhysReg(), llvm::WebAssemblyAsmPrinter::getRegType(), getRetComponentType(), getSchedRegions(), getShiftAmountTyForConstant(), getSignature(), llvm::slpvectorizer::BoUpSLP::getSpillCost(), llvm::DependenceInfo::getSplitIteration(), getStartOrEndSlot(), getSuccState(), llvm::object::WasmObjectFile::getSymbolFlags(), getTag(), llvm::MipsTargetMachine::getTargetTransformInfo(), llvm::slpvectorizer::BoUpSLP::getTreeCost(), getTypePartition(), getUnconditionalBrDisp(), getUnderlyingArgReg(), llvm::SelectionDAGISel::getUninvalidatedNodeId(), llvm::AMDGPUTTIImpl::getUnrollingPreferences(), llvm::ARMTTIImpl::getUnrollingPreferences(), llvm::MachineSSAUpdater::GetValueInMiddleOfBlock(), llvm::SSAUpdater::GetValueInMiddleOfBlock(), GetVBR(), GetVRegRenameMap(), llvm::getWeightFromBranchProb(), giveUpWithRemarks(), greaterWithBias(), handleADRP(), handleEndBlock(), handleFree(), handleNormalInst(), llvm::objcarc::BottomUpPtrState::HandlePotentialAlterRefCount(), llvm::objcarc::TopDownPtrState::HandlePotentialAlterRefCount(), llvm::objcarc::BottomUpPtrState::HandlePotentialUse(), llvm::objcarc::TopDownPtrState::HandlePotentialUse(), llvm::GISelCSEInfo::handleRecordedInst(), llvm::VPRecipeBuilder::handleReplication(), HasArgumentDef(), hasDataDependencyPred(), hasOneExitNode(), hasOneNonDBGUseInst(), hasOnlyUniformBranches(), llvm::hasOutsideLoopUser(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::HasProperSupport(), hasTiedDef(), hasUndefContents(), hasUsesOutsideLoop(), hasValueBeenRAUWed(), hasVRegCycleUse(), hasVulnerableLoad(), hasZeroSignBit(), llvm::HexagonMCShuffle(), hoist(), hoistAndMergeSGPRInits(), llvm::hoistRegion(), llvm::ICallPromotionAnalysis::ICallPromotionAnalysis(), ignoreDependence(), llvm::FunctionImporter::importFunctions(), incorporateNewSCCRange(), inferAttrsFromFunctionBodies(), llvm::objcarc::BottomUpPtrState::InitBottomUp(), llvm::GenericScheduler::initCandidate(), llvm::GCNMaxOccupancySchedStrategy::initialize(), llvm::SystemZPostRASchedStrategy::initialize(), INITIALIZE_PASS(), INITIALIZE_PASS_END(), llvm::ExecutionEngine::InitializeMemory(), llvm::mca::initializeUsedResources(), llvm::ScheduleDAGMILive::initRegPressure(), initVRegCycle(), inlineCallsImpl(), llvm::DivergenceAnalysis::inRegion(), llvm::SMSchedule::insert(), llvm::HexagonInstrInfo::insertBranch(), insertCopy(), insertDeleteInstructions(), llvm::po_iterator_storage< LoopBounds, true >::insertEdge(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::InsertEdge(), insertInteger(), insertNopBeforeInstruction(), llvm::InsertPreheaderForLoop(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::InsertReachable(), insertUndefLaneMask(), insertUniqueBackedgeBlock(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::InsertUnreachable(), insertVector(), InstructionStoresToFI(), instrumentMaskedLoadOrStore(), instrumentOneFunc(), llvm::InternalizePass::internalizeModule(), intersect(), llvm::Mips16RegisterInfo::intRegClass(), llvm::MachineTraceMetrics::Ensemble::invalidate(), llvm::MachineTraceMetrics::invalidate(), llvm::InterleavedAccessInfo::invalidateGroupsRequiringScalarEpilogue(), inversePermutation(), llvm::HexagonInstrInfo::invertAndChangeJumpTarget(), llvm::IRTranslator::IRTranslator(), isACalleeSavedRegister(), isAlwaysFoldable(), isAnyConstantBuildVector(), isAtomic(), llvm::mca::RegisterFile::isAvailable(), isBitfieldExtractOpFromAnd(), isBitfieldExtractOpFromShr(), isBroadcastShuffle(), isCallerPreservedOrConstPhysReg(), isCallPromotable(), llvm::CoalescerPair::isCoalescable(), isCopyFeedingInvariantStore(), llvm::IsCPSRDead< MCInst >(), isCrossCopy(), isDataInvariant(), isDataInvariantLoad(), isDefInSubRange(), isEFLAGSLive(), isExplicitVecOuterLoop(), llvm::MemoryDepChecker::Dependence::isForward(), llvm::AArch64TargetLowering::isFPImmLegal(), isFpMulInstruction(), isFullCopyOf(), isFullUndefDef(), isFuncOrderCorrect(), isFunctionEntryBlock(), llvm::HexagonTargetObjectFile::isGlobalInSmallSection(), isIgnorableInst(), isImmValidForOpcode(), isIndirectBrTarget(), llvm::InductionDescriptor::isInductionPHI(), isInRage(), isInSymtab(), isIntegerLoopHeaderPHI(), isIntersect(), isKnownTypeIdMember(), llvm::HexagonInstrInfo::isLateInstrFeedsEarlyInstr(), isLEASimpleIncOrDec(), llvm::AArch64TargetLowering::isLegalAddImmediate(), isLegalArithImmed(), llvm::X86Subtarget::isLegalToCallImmediateAddr(), isLiveOut(), isLoadConditional(), isLoopIncrement(), isLoopInvariant(), isMergeableLdStUpdate(), isMinSize(), IsMovepDestinationRegPair(), IsNarrowSequence(), IsNonLocalValue(), isNopCopy(), isNoWrap(), isObjectDereferencedInBlock(), isOnlyReachableViaThisEdge(), isOperandOf(), isOverwrite(), isPCRel(), isPHIRegionIndex(), isProfitableChain(), isProfitableForVectorization(), isPromotedInstructionLegal(), IsPseudoCallIndirect(), isReassociableOp(), llvm::RecurrenceDescriptor::isReductionPHI(), isRegUsedByPhiNodes(), isReInterleaveMask(), isRemainderZero(), IsSafeAndProfitableToMove(), isSafeAndProfitableToSpeculateAroundPHI(), isSafeToPromoteArgument(), isSafeToSpeculatePHIUsers(), llvm::isSafeToUnrollAndJam(), isSETCCorConvertedSETCC(), IsSingleInstrConstant(), isSink(), llvm::FullDependence::isSplitable(), isTargetConstant(), isTerminalReg(), isThunkProfitable(), isTrivialLoopExitBlock(), isUnconditionalBranch(), llvm::LoopVectorizationLegality::isUniform(), llvm::isUniformLoop(), llvm::SMSchedule::isValidSchedule(), isVectorReductionOp(), isVirtualRegisterOperand(), isWrapperOnlyCall(), iterativelySinkInstructions(), llvm::LazyCallGraph::LazyCallGraph(), llvm::SplitEditor::leaveIntvAfter(), llvm::SplitEditor::leaveIntvBefore(), llvm::SystemZPostRASchedStrategy::leaveMBB(), llvm::LegalizerHelper::legalizeInstrStep(), LinearizeExprTree(), LLVMSetLinkage(), llvm::coverage::CoverageMapping::load(), llvm::RuntimeDyldELF::loadObject(), llvm::ARCInstrInfo::loadRegFromStackSlot(), llvm::log2(), lookForCompound(), lookupCandidateBaseReg(), LoopIsOuterMostWithPredecessor(), llvm::LoopVectorizeHints::LoopVectorizeHints(), llvm::HexagonTargetLowering::LowerCall(), lowerCallResult(), llvm::HexagonTargetLowering::LowerDYNAMIC_STACKALLOC(), llvm::AArch64TargetLowering::LowerOperation(), llvm::ARMTargetLowering::LowerOperation(), makeBitReverse(), makeCombineInst(), mapBinOpcode(), llvm::SparseSolver< LatticeKey, LatticeVal, KeyInfo >::MarkBlockExecutable(), MarkBlocksLiveIn(), markTails(), MatchParallelMACSequences(), llvm::matchPassManager(), MatchReductions(), matchSwap(), llvm::gvn::AvailableValue::MaterializeAdjustedValue(), mayLoopAccessLocation(), mayTailCallThisCC(), mayUseP9Setb(), mayUsePostIncMode(), llvm::LoopVectorizationCostModel::memoryInstructionCanBeWidened(), mergeCleanupPad(), mergeConstants(), mergeInlinedArrayAllocas(), mergeOperations(), minAPInt(), MoveAndTeeForMultiUse(), MoveForSingleUse(), moveLCSSAPhis(), moveSpillUsesAfterCoroBegin(), moveUp(), nearest_common_dominator(), needsFP(), llvm::TargetRegisterInfo::needsStackRealignment(), NewSDValueDbgMsg(), node_eq(), normalizePBQPSpillWeight(), llvm::mca::ExecuteStage::notifyInstructionExecuted(), llvm::mca::ExecuteStage::notifyInstructionIssued(), llvm::mca::ExecuteStage::notifyInstructionReady(), llvm::mca::RetireStage::notifyInstructionRetired(), llvm::orc::remote::OrcRemoteTargetClient::RemoteRTDyldMemoryManager::notifyObjectLoaded(), llvm::mca::ExecuteStage::notifyResourceAvailable(), numVectorEltsOrZero(), llvm::AggressiveAntiDepBreaker::Observe(), okayForPHIOfOps(), llvm::mca::LSUnit::onInstructionExecuted(), operator new(), false::IntervalSorter::operator()(), llvm::bfi_detail::BlockEdgesAdder< BT >::operator()(), llvm::operator<<(), operator<<(), llvm::OProfileWrapper::OProfileWrapper(), OptimizeAwayTrappingUsesOfLoads(), optimizeCall(), llvm::slpvectorizer::BoUpSLP::optimizeGatherSequence(), OptimizeGlobalAddressOfMalloc(), llvm::optimizeGlobalCtorsList(), llvm::MemorySSA::OptimizeUses::OptimizeUses(), optimizeVcndVcmpPair(), llvm::OptLevelChanger::OptLevelChanger(), llvm::BlockFrequencyInfoImplBase::packageLoop(), packCmovGroup(), llvm::VLIWPacketizerList::PacketizeMIs(), parseCond(), patchAndReplaceAllUsesWith(), PeepholePPC64ZExtGather(), false::LibCallsShrinkWrap::perform(), performBitcastCombine(), performConcatVectorsCombine(), llvm::MipsSETargetLowering::PerformDAGCombine(), llvm::AArch64TargetLowering::PerformDAGCombine(), PerformHeapAllocSRoA(), performMaskedAtomicOp(), PerformSHLSimplify(), performSink(), llvm::GCNMaxOccupancySchedStrategy::pickNode(), llvm::R600SchedStrategy::pickNode(), llvm::SystemZPostRASchedStrategy::pickNode(), llvm::ConvergingVLIWScheduler::pickNode(), llvm::GenericScheduler::pickNode(), llvm::PostGenericScheduler::pickNode(), llvm::GenericScheduler::pickNodeBidirectional(), llvm::ConvergingVLIWScheduler::pickNodeBidrectional(), llvm::ConvergingVLIWScheduler::pickNodeFromQueue(), llvm::GenericScheduler::pickNodeFromQueue(), llvm::PostGenericScheduler::pickNodeFromQueue(), llvm::SchedBoundary::pickOnlyChoice(), llvm::LoopVectorizationPlanner::plan(), llvm::LoopVectorizationPlanner::planInVPlanNativePath(), pointerInvalidatedByLoop(), populateCandidates(), populateDependencyMatrix(), llvm::RuntimeDyldMachO::populateIndirectSymbolPointersSection(), populateWorklist(), llvm::PPCHazardRecognizer970::PPCHazardRecognizer970(), llvm::HexagonInstrInfo::PredicateInstruction(), PrepareCall(), llvm::MemoryDepChecker::Dependence::print(), llvm::LiveIntervals::print(), printExtendedName(), llvm::AlignmentFromAssumptionsPass::processAssumption(), llvm::JumpThreadingPass::ProcessBlock(), llvm::ARCFrameLowering::processFunctionBeforeFrameFinalized(), processInternalGlobal(), llvm::LoopVectorizePass::processLoop(), processLoopInVPlanNativePath(), processPHI(), llvm::RuntimeDyldCOFFI386::processRelocationRef(), llvm::RuntimeDyldCOFFThumb::processRelocationRef(), llvm::RuntimeDyldELF::processRelocationRef(), llvm::RuntimeDyldCOFFX86_64::processRelocationRef(), llvm::JumpThreadingPass::ProcessThreadableEdges(), ProfitableToMerge(), profitImm(), promoteArguments(), promoteIndirectCalls(), llvm::promoteLoopAccessesToScalars(), propagateMetadata(), llvm::pruneCache(), pushDepHeight(), llvm::CFLAndersAAResult::query(), llvm::CFLSteensAAResult::query(), llvm::GVNHoist::rank(), readInstruction32(), readSection(), readsVCCZ(), llvm::RuntimeDyldImpl::reassignSectionAddress(), llvm::AArch64TargetLowering::ReconstructShuffle(), llvm::GISelCSEInfo::recordNewInstruction(), llvm::StackMaps::recordStatepoint(), llvm::ScheduleDAGInstrs::reduceHugeMemNodeMaps(), RedzoneSizeForScale(), RefineErrorLoc(), registerDefinedBetween(), llvm::GenericScheduler::registerRoots(), llvm::PostGenericScheduler::registerRoots(), regOverlapsSet(), llvm::R600SchedStrategy::releaseBottomNode(), llvm::ConvergingVLIWScheduler::releaseBottomNode(), llvm::LazyMachineBlockFrequencyInfoPass::releaseMemory(), llvm::DemandedBitsWrapperPass::releaseMemory(), llvm::R600SchedStrategy::releaseTopNode(), RematerializeCheapDef(), llvm::safestack::StackColoring::removeAllMarkers(), llvm::HexagonInstrInfo::removeBranch(), RemoveDeadAddBetweenLEAAndJT(), removeExternalCFGEdges(), llvm::MemoryDependenceResults::removeInstruction(), removeRedundantBlockingStores(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::RemoveRedundantRoots(), removeUndefIntroducingPredecessor(), removeUseSoftFloat(), llvm::SlotIndexes::renumberIndexes(), replace(), llvm::orc::MaterializationResponsibility::replace(), ReplaceDominatedUses(), replaceDominatedUsesWith(), ReplaceFrameIndex(), llvm::InstCombiner::replaceInstUsesWith(), llvm::replaceSymbolicStrideSCEV(), ReplaceUsesOfWith(), reportLoadElim(), reportMayClobberedLoad(), rescheduleCanonically(), rescheduleLexographically(), llvm::GenericScheduler::reschedulePhysReg(), llvm::orc::remote::OrcRemoteTargetClient::RemoteRTDyldMemoryManager::reserveAllocationSpace(), llvm::VLIWResourceModel::reserveResources(), llvm::HexagonHazardRecognizer::Reset(), llvm::SystemZHazardRecognizer::Reset(), llvm::cl::ResetAllOptionOccurrences(), llvm::objcarc::PtrState::ResetSequenceProgress(), llvm::MipsTargetMachine::resetSubtarget(), llvm::HexagonMCShuffler::reshuffleTo(), llvm::orc::MaterializationResponsibility::resolve(), llvm::SelectionDAGBuilder::resolveDanglingDebugInfo(), llvm::RuntimeDyldImpl::resolveLocalRelocations(), llvm::RuntimeDyldELFMips::resolveMIPSO32Relocation(), llvm::RuntimeDyldELFMips::resolveRelocation(), llvm::RuntimeDyldMachOX86_64::resolveRelocation(), llvm::RuntimeDyldMachOI386::resolveRelocation(), llvm::RuntimeDyldCOFFI386::resolveRelocation(), llvm::RuntimeDyldCOFFThumb::resolveRelocation(), llvm::RuntimeDyldELF::resolveRelocation(), llvm::RuntimeDyldMachOARM::resolveRelocation(), llvm::RuntimeDyldMachOAArch64::resolveRelocation(), llvm::RuntimeDyldImpl::resolveRelocations(), llvm::ARCFrameLowering::restoreCalleeSavedRegisters(), llvm::AArch64FrameLowering::restoreCalleeSavedRegisters(), RetagMask(), llvm::HexagonInstrInfo::reversePredSense(), llvm::SSAUpdaterBulk::RewriteAllUses(), rewriteDebugUsers(), RewriteP2Align(), llvm::IRCEPass::run(), llvm::LoopPredicationPass::run(), llvm::LoopDataPrefetchPass::run(), llvm::LoopDeletionPass::run(), llvm::PassManager< Function >::run(), llvm::SimpleLoopUnswitchPass::run(), llvm::DeadArgumentEliminationPass::run(), llvm::TruncInstCombine::run(), llvm::ThinLTOCodeGenerator::run(), llvm::InlinerPass::run(), llvm::Interpreter::run(), llvm::safestack::StackColoring::run(), llvm::InstCombiner::run(), llvm::ModuleToPostOrderCGSCCPassAdaptor< CGSCCPassT >::run(), llvm::CGSCCToFunctionPassAdaptor< FunctionPassT >::run(), llvm::DevirtSCCRepeatedPass< PassT >::run(), llvm::Float2IntPass::runImpl(), llvm::SpeculativeExecutionPass::runImpl(), llvm::SLPVectorizerPass::runImpl(), llvm::JumpThreadingPass::runImpl(), llvm::runIPSCCP(), runOnBasicBlock(), llvm::LegacyDivergenceAnalysis::runOnFunction(), llvm::RGPassManager::runOnFunction(), llvm::InstructionSelect::runOnMachineFunction(), llvm::Legalizer::runOnMachineFunction(), llvm::BreakFalseDeps::runOnMachineFunction(), llvm::Localizer::runOnMachineFunction(), llvm::SelectionDAGISel::runOnMachineFunction(), llvm::ReachingDefAnalysis::runOnMachineFunction(), llvm::RegisterClassInfo::runOnMachineFunction(), llvm::MachineRegionInfoPass::runOnMachineFunction(), llvm::WebAssemblyExceptionInfo::runOnMachineFunction(), llvm::ExecutionDomainFix::runOnMachineFunction(), llvm::LiveIntervals::runOnMachineFunction(), llvm::SlotIndexes::runOnMachineFunction(), llvm::RegBankSelect::runOnMachineFunction(), runSCCP(), llvm::salvageDebugInfo(), llvm::SelectionDAG::salvageDebugInfo(), salvageDebugInfoFromEmptyBlock(), scaleCaseProbality(), scaleWeights(), llvm::scavengeFrameVirtualRegs(), llvm::RegScavenger::scavengeRegister(), llvm::RegScavenger::scavengeRegisterBackwards(), scavengeStackSlot(), llvm::R600SchedStrategy::schedNode(), llvm::SystemZPostRASchedStrategy::schedNode(), llvm::GCNIterativeScheduler::schedule(), llvm::VLIWMachineScheduler::schedule(), llvm::GCNScheduleDAGMILive::schedule(), llvm::SwingSchedulerDAG::schedule(), llvm::GCNIterativeScheduler::OverrideLegacyStrategy::schedule(), llvm::ScheduleDAGMI::schedule(), llvm::SIScheduleDAGMI::schedule(), llvm::ScheduleDAGMILive::schedule(), llvm::GCNIterativeScheduler::scheduleILP(), llvm::GCNIterativeScheduler::scheduleLegacyMaxOccupancy(), llvm::ScheduleDAGMILive::scheduleMI(), llvm::GCNIterativeScheduler::scheduleMinReg(), llvm::SchedDFSResult::scheduleTree(), llvm::ConvergingVLIWScheduler::SchedulingCost(), llvm::ScoreboardHazardRecognizer::ScoreboardHazardRecognizer(), llvm::mca::Scheduler::select(), llvm::SelectionDAGISel::SelectCodeCommon(), selectCopy(), selectI64Imm(), llvm::LoopVectorizationCostModel::selectInterleaveCount(), llvm::FastISel::selectIntrinsicCall(), llvm::SplitEditor::selectIntv(), llvm::LoopVectorizationCostModel::selectVectorizationFactor(), separateNestedLoop(), llvm::FaultMaps::serializeToFaultMapSection(), llvm::StackMaps::serializeToStackMapSection(), llvm::LoopVectorizationPlanner::setBestPlan(), llvm::BlockFrequencyInfoImpl< llvm::BitTracker >::setBlockFreq(), setBranchWeights(), llvm::InnerLoopVectorizer::setDebugLocFromInst(), llvm::BranchProbabilityInfo::setEdgeProbability(), setFastFlags(), llvm::SelectionDAG::setGraphColor(), llvm::objcarc::PtrState::SetKnownPositiveRefCount(), llvm::GenericSchedulerBase::setPolicy(), llvm::setProfMetadata(), llvm::objcarc::PtrState::SetSeq(), llvm::DwarfDebug::shareAcrossDWOCUs(), llvm::ARMBaseRegisterInfo::shouldCoalesce(), shouldConvert(), shouldFixMainFunction(), shouldInline(), shouldRotateLoopExitingLatch(), shouldUseLA(), llvm::LiveIntervals::shrinkToUses(), llvm::HexagonShuffler::shuffle(), simplifyAllocaArraySize(), SimplifyBranchOnICmpChain(), SimplifyCondBranchToCondBranch(), SimplifyCondBranchToTwoReturns(), simplifyDivRem(), simplifyOneLoop(), sink(), sinkAndCmp0Expression(), SinkCommonCodeFromPredecessors(), SinkInstruction(), sinkInstruction(), llvm::sinkRegion(), llvm::SIScheduleBlockScheduler::SIScheduleBlockScheduler(), llvm::BasicBlockPass::skipBasicBlock(), llvm::FunctionPass::skipFunction(), llvm::LoopPass::skipLoop(), llvm::RegionPass::skipRegion(), AllocaSlices::SliceBuilder::SliceBuilder(), llvm::InstCombiner::SliceUpIllegalIntegerPHI(), llvm::SparseSolver< LatticeKey, LatticeVal, KeyInfo >::Solve(), SolveQuadraticAddRecExact(), SolveQuadraticAddRecRange(), llvm::APIntOps::SolveQuadraticEquationWrap(), SortBlocks(), SortCallTargets(), SortNonLocalDepInfoCache(), speculatePHINodeLoads(), speculatePHIs(), speculateSelectInstLoads(), SpeculativelyExecuteBB(), llvm::ARCFrameLowering::spillCalleeSavedRegisters(), llvm::AArch64FrameLowering::spillCalleeSavedRegisters(), split(), splitBlock(), splitCallSite(), llvm::MachineBasicBlock::SplitCriticalEdge(), splitEdge(), splitMBB(), llvm::LiveIntervals::splitSeparateComponents(), SRAGlobal(), StackMallocSizeClass(), llvm::DbgValueHistoryMap::startInstrRange(), llvm::ARCInstrInfo::storeRegToStackSlot(), false::Chain::str(), subRangeLiveAt(), swapMIOperands(), llvm::TailDuplicator::tailDuplicateBlocks(), llvm::thinLTOResolvePrevailingInModule(), llvm::JumpThreadingPass::ThreadEdge(), llvm::JumpThreadingPass::ThreadGuard(), tracePick(), truncateIVUse(), llvm::LegalizationArtifactCombiner::tryCombineAnyExt(), llvm::CombinerHelper::tryCombineExtendingLoads(), llvm::LegalizationArtifactCombiner::tryCombineSExt(), llvm::LegalizationArtifactCombiner::tryCombineZExt(), llvm::HexagonMCInstrInfo::tryCompound(), llvm::mca::RegisterFile::tryEliminateMove(), llvm::LegalizationArtifactCombiner::tryFoldImplicitDef(), tryFoldInst(), tryLowerToSLI(), llvm::GCNIterativeScheduler::tryMaximizeOccupancy(), tryPromoteAllocaToVector(), llvm::VPRecipeBuilder::tryToCreateRecipe(), tryToElideArgumentCopy(), tryToReplaceWithConstant(), tryToShorten(), TryToShrinkGlobalToBoolean(), llvm::TryToSimplifyUncondBranchFromEmptyBlock(), TryToSinkInstruction(), tryToSpeculatePHIs(), tryToUnrollAndJamLoop(), tryToUnrollLoop(), tryToVectorizeHorReductionOrInstOperands(), turnGuardIntoBranch(), TypeSizeToSizeIndex(), llvm::LiveRegMatrix::unassign(), llvm::UnrollAndJamLoop(), llvm::UnrollLoop(), llvm::UnrollRuntimeLoopRemainder(), unsupportedBinOp(), unswitchBestCondition(), unswitchTrivialBranch(), unswitchTrivialSwitch(), unwrapLoop(), llvm::LiveIntervals::HMEditor::updateAllRanges(), llvm::InnerLoopVectorizer::updateAnalysis(), llvm::MachineTraceMetrics::Ensemble::updateDepth(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::UpdateInsertion(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::UpdateLevelsAfterInsertion(), updateOperand(), updateOperandRegConstraints(), llvm::ScheduleDAGMILive::updatePressureDiffs(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::UpdateRootsAfterUpdate(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::UpdateRootsBeforeInsertion(), llvm::ScheduleDAGMILive::updateScheduledPressure(), llvm::MipsSubtarget::useConstantIslands(), usedAsAddr(), useSinCos(), llvm::LoopVectorizeHints::vectorizeAnalysisPassName(), llvm::slpvectorizer::BoUpSLP::vectorizeTree(), Verify(), llvm::LegalizerInfo::verify(), verifyCTRBranch(), llvm::VPlanVerifier::verifyHierarchicalCFG(), VerifyLowRegs(), llvm::mca::verifyOperands(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::verifyParentProperty(), llvm::LegalizeRuleSet::verifyTypeIdxsCoverage(), llvm::sroa::AllocaSliceRewriter::visit(), llvm::Interpreter::visitAllocaInst(), llvm::InstCombiner::visitAllocaInst(), llvm::DomTreeBuilder::SemiNCAInfo< DomTreeT >::VisitInsertion(), llvm::ObjectSizeOffsetVisitor::visitInstruction(), llvm::ObjectSizeOffsetEvaluator::visitInstruction(), llvm::InstCombiner::visitSExt(), llvm::InstCombiner::visitTrunc(), llvm::InstCombiner::visitZExt(), warnAboutLeftoverTransformations(), llvm::InnerLoopVectorizer::widenInstruction(), X86SelectAddress(), llvm::LiveDebugVariables::~LiveDebugVariables(), llvm::OptLevelChanger::~OptLevelChanger(), and llvm::orc::remote::OrcRemoteTargetClient::RemoteRTDyldMemoryManager::~RemoteRTDyldMemoryManager().