26#include "llvm/Config/llvm-config.h" 
   48#ifdef EXPENSIVE_CHECKS 
   68  return all_of(
I->operands(), [&](
Value *V) { return isLoopInvariant(V); });
 
 
   87  if (
I->mayReadFromMemory())
 
  101  for (
Value *Operand : 
I->operands())
 
  116  I->dropUnknownNonDebugMetadata();
 
 
  147  assert(
Incoming && Backedge && 
"expected non-null incoming and backedges");
 
 
  166          if (Inc->getOpcode() == Instruction::Add && Inc->getOperand(0) == PN)
 
 
  178      if (BI->isConditional())
 
 
  187  ICmpInst *LatchCmpInst = L.getLatchCmpInst();
 
  193  if (Op0 == &IndVar || Op0 == &StepInst)
 
  196  if (Op1 == &IndVar || Op1 == &StepInst)
 
 
  202std::optional<Loop::LoopBounds>
 
  211  if (!InitialIVValue || !StepInst)
 
  215  Value *StepInstOp1 = StepInst->getOperand(1);
 
  216  Value *StepInstOp0 = StepInst->getOperand(0);
 
  217  Value *StepValue = 
nullptr;
 
  218  if (SE.getSCEV(StepInstOp1) == Step)
 
  219    StepValue = StepInstOp1;
 
  220  else if (SE.getSCEV(StepInstOp0) == Step)
 
  221    StepValue = StepInstOp0;
 
  227  return LoopBounds(L, *InitialIVValue, *StepInst, StepValue, *FinalIVValue,
 
 
  235  assert(Latch && 
"Expecting valid latch");
 
  242         "Expecting the latch compare instruction to be a CmpInst");
 
  264  if (
D == Direction::Increasing)
 
  267  if (
D == Direction::Decreasing)
 
 
  278    if (
const SCEV *StepRecur = StepAddRecExpr->getStepRecurrence(SE)) {
 
  279      if (SE.isKnownPositive(StepRecur))
 
  280        return Direction::Increasing;
 
  281      if (SE.isKnownNegative(StepRecur))
 
  282        return Direction::Decreasing;
 
  285  return Direction::Unknown;
 
 
  300  assert(Header && 
"Expected a valid loop header");
 
  308  for (
PHINode &IndVar : Header->phis()) {
 
  314    Value *StepInst = IndVar.getIncomingValueForBlock(Latch);
 
  320    if (StepInst == LatchCmpOp0 || StepInst == LatchCmpOp1)
 
  327    if (&IndVar == LatchCmpOp0 || &IndVar == LatchCmpOp1)
 
 
  374         "Expecting a loop with valid preheader and latch");
 
 
  425  if (!Step || !Step->
isOne())
 
 
  438    if (IgnoreTokens && 
I.getType()->isTokenTy())
 
  441    for (
const Use &U : 
I.uses()) {
 
  449        UserBB = 
P->getIncomingBlock(U);
 
  455      if (UserBB != &BB && !L.contains(UserBB) &&
 
 
  471                                  bool IgnoreTokens)
 const {
 
 
  496        if (CB->cannotDuplicate())
 
 
  517    else if (MD != LoopID)
 
 
  528         "Loop ID needs at least one operand");
 
  530         "Loop ID should refer to itself");
 
  535    BB->getTerminator()->setMetadata(LLVMContext::MD_loop, LoopID);
 
 
  545      Context, LoopID, {
"llvm.loop.unroll."}, {DisableUnrollMD});
 
 
  568  if (!DesiredLoopIdMetadata)
 
  571  MDNode *ParallelAccesses =
 
  574      ParallelAccessGroups; 
 
  575  if (ParallelAccesses) {
 
  579             "List item must be an access group");
 
  580      ParallelAccessGroups.
insert(AccGroup);
 
  591      if (!
I.mayReadOrWriteMemory())
 
  594      if (
MDNode *AccessGroup = 
I.getMetadata(LLVMContext::MD_access_group)) {
 
  595        auto ContainsAccessGroup = [&ParallelAccessGroups](
MDNode *AG) -> 
bool {
 
  596          if (AG->getNumOperands() == 0) {
 
  598            return ParallelAccessGroups.
count(AG);
 
  601          for (
const MDOperand &AccessListItem : AG->operands()) {
 
  604                   "List item must be an access group");
 
  605            if (ParallelAccessGroups.
count(AccGroup))
 
  611        if (ContainsAccessGroup(AccessGroup))
 
  620          I.getMetadata(LLVMContext::MD_mem_parallel_loop_access);
 
 
  656    if (
DebugLoc DL = PHeadBB->getTerminator()->getDebugLoc())
 
  662    return LocRange(HeadBB->getTerminator()->getDebugLoc());
 
 
  671    LoopDbgLoc.print(OS);
 
 
  678#if !defined(NDEBUG) || defined(LLVM_ENABLE_DUMP) 
  707  bool FoundIB = 
false;
 
  710  UnloopUpdater(
Loop *UL, 
LoopInfo *LInfo) : Unloop(*UL), LI(LInfo), DFS(UL) {}
 
  712  void updateBlockParents();
 
  714  void removeBlocksFromAncestors();
 
  716  void updateSubloopParents();
 
  725void UnloopUpdater::updateBlockParents() {
 
  726  if (Unloop.getNumBlocks()) {
 
  729    LoopBlocksTraversal Traversal(DFS, LI);
 
  730    for (BasicBlock *POI : Traversal) {
 
  732      Loop *
L = LI->getLoopFor(POI);
 
  733      Loop *NL = getNearestLoop(POI, L);
 
  738               "uninitialized successor");
 
  739        LI->changeLoopFor(POI, NL);
 
  743        assert((FoundIB || Unloop.contains(L)) && 
"uninitialized successor");
 
  750  for (
unsigned NIters = 0; 
Changed; ++NIters) {
 
  751    assert(NIters < Unloop.getNumBlocks() && 
"runaway iterative algorithm");
 
  758                                   POE = DFS.endPostorder();
 
  761      Loop *
L = LI->getLoopFor(*POI);
 
  762      Loop *NL = getNearestLoop(*POI, L);
 
  765               "uninitialized successor");
 
  766        LI->changeLoopFor(*POI, NL);
 
  774void UnloopUpdater::removeBlocksFromAncestors() {
 
  777  for (BasicBlock *BB : Unloop.blocks()) {
 
  778    Loop *OuterParent = LI->getLoopFor(BB);
 
  779    if (Unloop.contains(OuterParent)) {
 
  782      OuterParent = SubloopParents[OuterParent];
 
  786    for (Loop *OldParent = Unloop.getParentLoop(); OldParent != OuterParent;
 
  787         OldParent = OldParent->getParentLoop()) {
 
  788      assert(OldParent && 
"new loop is not an ancestor of the original");
 
  789      OldParent->removeBlockFromLoop(BB);
 
  795void UnloopUpdater::updateSubloopParents() {
 
  796  while (!Unloop.isInnermost()) {
 
  797    Loop *Subloop = *std::prev(Unloop.end());
 
  798    Unloop.removeChildLoop(std::prev(Unloop.end()));
 
  800    assert(SubloopParents.count(Subloop) && 
"DFS failed to visit subloop");
 
  801    if (Loop *Parent = SubloopParents[Subloop])
 
  802      Parent->addChildLoop(Subloop);
 
  804      LI->addTopLevelLoop(Subloop);
 
  813Loop *UnloopUpdater::getNearestLoop(BasicBlock *BB, Loop *BBLoop) {
 
  817  Loop *NearLoop = BBLoop;
 
  819  Loop *Subloop = 
nullptr;
 
  820  if (NearLoop != &Unloop && Unloop.contains(NearLoop)) {
 
  825      assert(Subloop && 
"subloop is not an ancestor of the original loop");
 
  828    NearLoop = SubloopParents.insert({Subloop, &Unloop}).first->second;
 
  832    assert(!Subloop && 
"subloop blocks must have a successor");
 
  839    Loop *
L = LI->getLoopFor(Succ);
 
  843      assert((FoundIB || !DFS.hasPostorder(Succ)) && 
"should have seen IB");
 
  846    if (L != &Unloop && Unloop.contains(L)) {
 
  852      assert(
L->getParentLoop() == &Unloop && 
"cannot skip into nested loops");
 
  855      L = SubloopParents[
L];
 
  862    if (L && !
L->contains(&Unloop)) {
 
  863      L = 
L->getParentLoop();
 
  866    if (NearLoop == &Unloop || !NearLoop || NearLoop->
contains(L))
 
  870    SubloopParents[Subloop] = NearLoop;
 
  879                          FunctionAnalysisManager::Invalidator &) {
 
 
  923  UnloopUpdater Updater(Unloop, 
this);
 
  924  Updater.updateBlockParents();
 
  927  Updater.removeBlocksFromAncestors();
 
  930  Updater.updateSubloopParents();
 
  935    assert(
I != ParentLoop->
end() && 
"Couldn't find loop");
 
 
  945  if (V->getType()->isTokenTy())
 
  956  if (L->contains(ExitBB))
 
 
  984  OS << 
"Loop info for function '" << 
F.getName() << 
"':\n";
 
 
  990                     const std::string &Banner) {
 
  993    OS << Banner << 
" (loop: ";
 
  994    L.getHeader()->printAsOperand(OS, 
false);
 
  998    OS << *L.getHeader()->getModule();
 
 1005    OS << Banner << 
" (loop: ";
 
 1006    L.getHeader()->printAsOperand(OS, 
false);
 
 1010    OS << *L.getHeader()->getParent();
 
 1016  auto *PreHeader = L.getLoopPreheader();
 
 1018    OS << 
"\n; Preheader:";
 
 1019    PreHeader->print(OS);
 
 1023  for (
auto *
Block : L.blocks())
 
 1027      OS << 
"Printing <null> block";
 
 1030  L.getExitBlocks(ExitBlocks);
 
 1031  if (!ExitBlocks.
empty()) {
 
 1032    OS << 
"\n; Exit blocks";
 
 1033    for (
auto *
Block : ExitBlocks)
 
 1037        OS << 
"Printing <null> block";
 
 
 1076std::optional<const MDOperand *>
 
 1080    return std::nullopt;
 
 
 1095    return std::nullopt;
 
 1103      return IntMD->getZExtValue();
 
 
 1118    return std::nullopt;
 
 1122    return std::nullopt;
 
 
 1136      if (!CB->isConvergent())
 
 1141      if (
auto *Token = CB->getConvergenceControlToken()) {
 
 1143        if (!TheLoop->
contains(TokenDef->getParent()))
 
 
 1153  return L->getHeader()->getParent()->willReturn();
 
 
 1163  return L->getHeader()->getParent()->mustProgress() || 
hasMustProgress(L);
 
 
 1167  return Node->getNumOperands() == 0 && 
Node->isDistinct();
 
 
 1184      bool IsVectorMetadata = 
false;
 
 1194      if (!IsVectorMetadata)
 
 
 1267                                        POE = Traversal.
end();
 
 
assert(UImm &&(UImm !=~static_cast< T >(0)) &&"Invalid immediate!")
MachineBasicBlock MachineBasicBlock::iterator DebugLoc DL
static GCRegistry::Add< StatepointGC > D("statepoint-example", "an example strategy for statepoint")
#define LLVM_DUMP_METHOD
Mark debug helper function definitions like dump() that should not be stripped from debug builds.
#define LLVM_EXPORT_TEMPLATE
This file contains the declarations for the subclasses of Constant, which represent the different fla...
This file provides various utilities for inspecting and working with the control flow graph in LLVM I...
Module.h This file contains the declarations for the Module class.
This header defines various interfaces for pass management in LLVM.
static bool isBlockInLCSSAForm(const Loop &L, const BasicBlock &BB, const DominatorTree &DT, bool IgnoreTokens)
static const char * LLVMLoopMustProgress
static Value * findFinalIVValue(const Loop &L, const PHINode &IndVar, const Instruction &StepInst)
Return the final value of the loop induction variable if found.
Loop::LoopBounds::Direction Direction
static cl::opt< bool, true > VerifyLoopInfoX("verify-loop-info", cl::location(VerifyLoopInfo), cl::Hidden, cl::desc("Verify loop info (time consuming)"))
This file defines the interface for the loop nest analysis.
This file exposes an interface to building/using memory SSA to walk memory instructions using a use/d...
uint64_t IntrinsicInst * II
#define INITIALIZE_PASS_DEPENDENCY(depName)
#define INITIALIZE_PASS_END(passName, arg, name, cfg, analysis)
#define INITIALIZE_PASS_BEGIN(passName, arg, name, cfg, analysis)
This file defines the make_scope_exit function, which executes user-defined cleanup logic at scope ex...
This file defines the SmallPtrSet class.
This templated class represents "all analyses that operate over <aparticular IR unit>" (e....
PassT::Result & getResult(IRUnitT &IR, ExtraArgTs... ExtraArgs)
Get the result of an analysis pass for a given IR unit.
Represent the analysis usage information of a pass.
void setPreservesAll()
Set by analyses that do not transform their input at all.
AnalysisUsage & addRequiredTransitive()
ArrayRef - Represent a constant reference to an array (0 or more elements consecutively in memory),...
LLVM Basic Block Representation.
const Function * getParent() const
Return the enclosing method, or null if none.
LLVM_ABI const BasicBlock * getUniquePredecessor() const
Return the predecessor of this block if it has a unique predecessor block.
InstListType::iterator iterator
Instruction iterators...
LLVM_ABI LLVMContext & getContext() const
Get the context in which this basic block lives.
const Instruction * getTerminator() const LLVM_READONLY
Returns the terminator instruction if the block is well formed or null if the block is not well forme...
Conditional or Unconditional Branch instruction.
bool isConditional() const
BasicBlock * getSuccessor(unsigned i) const
bool isUnconditional() const
Value * getCondition() const
Represents analyses that only rely on functions' control flow.
Base class for all callable instructions (InvokeInst and CallInst) Holds everything related to callin...
This class is the base class for the comparison instructions.
Predicate
This enumeration lists the possible predicates for CmpInst subclasses.
@ ICMP_SLT
signed less than
@ ICMP_SGT
signed greater than
Predicate getSwappedPredicate() const
For example, EQ->EQ, SLE->SGE, ULT->UGT, OEQ->OEQ, ULE->UGE, OLT->OGT, etc.
Predicate getInversePredicate() const
For example, EQ -> NE, UGT -> ULE, SLT -> SGE, OEQ -> UNE, UGT -> OLE, OLT -> UGE,...
Predicate getPredicate() const
Return the predicate for this instruction.
Predicate getFlippedStrictnessPredicate() const
For predicate of kind "is X or equal to 0" returns the predicate "is X".
This is the shared class of boolean and integer constants.
bool isOne() const
This is just a convenience method to make client code smaller for a common case.
int64_t getSExtValue() const
Return the constant as a 64-bit integer value after it has been sign extended as appropriate for the ...
Analysis pass which computes a DominatorTree.
Legacy analysis pass which computes a DominatorTree.
void print(raw_ostream &OS, const Module *M=nullptr) const override
print - Print out the internal state of the pass.
Concrete subclass of DominatorTreeBase that is used to compute a normal dominator tree.
LLVM_ABI bool isReachableFromEntry(const Use &U) const
Provide an overload for a Use.
Module * getParent()
Get the module that this global value is contained inside of...
This instruction compares its operands according to the predicate given to the constructor.
A struct for saving information about induction variables.
BinaryOperator * getInductionBinOp() const
const SCEV * getStep() const
static LLVM_ABI bool isInductionPHI(PHINode *Phi, const Loop *L, ScalarEvolution *SE, InductionDescriptor &D, const SCEV *Expr=nullptr, SmallVectorImpl< Instruction * > *CastsToIgnore=nullptr)
Returns true if Phi is an induction in the loop L.
Instruction::BinaryOps getInductionOpcode() const
Returns binary opcode of the induction operator.
Value * getStartValue() const
LLVM_ABI ConstantInt * getConstIntStepValue() const
MDNode * getMetadata(unsigned KindID) const
Get the metadata of given kind attached to this Instruction.
This is an important class for using LLVM in a threaded context.
Analysis pass that exposes the LoopInfo for a function.
LLVM_ABI LoopInfo run(Function &F, FunctionAnalysisManager &AM)
Instances of this class are used to represent loops that are detected in the flow graph.
bool contains(const Loop *L) const
bool isOutermost() const
Return true if the loop does not have a parent (natural) loop.
BasicBlock * getLoopLatch() const
bool isInnermost() const
Return true if the loop does not contain any (natural) loops.
BasicBlock * getHeader() const
void getLoopLatches(SmallVectorImpl< BasicBlock * > &LoopLatches) const
void print(raw_ostream &OS, bool Verbose=false, bool PrintNested=true, unsigned Depth=0) const
std::vector< Loop * >::const_iterator iterator
iterator_range< block_iterator > blocks() const
bool isInvalid() const
Return true if this loop is no longer valid.
BasicBlock * getLoopPreheader() const
LoopT * getParentLoop() const
Return the parent loop if it exists or nullptr for top level loops.
bool hasDedicatedExits() const
BasicBlock * getUniqueExitBlock() const
LoopT * removeChildLoop(iterator I)
This removes the specified child from being a subloop of this loop.
Store the result of a depth first search within basic blocks contained by a single loop.
friend class LoopBlocksTraversal
std::vector< BasicBlock * >::const_iterator POIterator
Postorder list iterators.
void perform(const LoopInfo *LI)
Traverse the loop blocks and store the DFS result.
po_iterator< BasicBlock *, LoopBlocksTraversal, true > POTIterator
Graph traversal iterator.
POTIterator begin()
Postorder traversal over the graph.
This class builds and contains all of the top-level loop structures in the specified function.
void verify(const DominatorTreeBase< BlockT, false > &DomTree) const
void addTopLevelLoop(Loop *New)
void analyze(const DominatorTreeBase< BlockT, false > &DomTree)
Create the loop forest using a stable algorithm.
Loop * removeLoop(iterator I)
void changeLoopFor(BasicBlock *BB, Loop *L)
LoopT * getLoopFor(const BlockT *BB) const
Return the inner most loop that BB lives in.
std::vector< Loop * >::const_iterator iterator
The legacy pass manager's analysis pass to compute loop information.
void getAnalysisUsage(AnalysisUsage &AU) const override
getAnalysisUsage - This function should be overriden by passes that need analysis information to do t...
void releaseMemory() override
releaseMemory() - This member can be implemented by a pass if it wants to be able to release its memo...
bool runOnFunction(Function &F) override
Calculate the natural loop information for a given function.
void verifyAnalysis() const override
verifyAnalysis() - This member can be implemented by a analysis pass to check state of analysis infor...
void print(raw_ostream &O, const Module *M=nullptr) const override
print - Print out the internal state of the pass.
LLVM_ABI bool wouldBeOutOfLoopUseRequiringLCSSA(const Value *V, const BasicBlock *ExitBB) const
LLVM_ABI bool invalidate(Function &F, const PreservedAnalyses &PA, FunctionAnalysisManager::Invalidator &)
Handle invalidation explicitly.
LLVM_ABI void erase(Loop *L)
Update LoopInfo after removing the last backedge from a loop.
static const BasicBlock & skipEmptyBlockUntil(const BasicBlock *From, const BasicBlock *End, bool CheckUniquePred=false)
Recursivelly traverse all empty 'single successor' basic blocks of From (if there are any).
LLVM_ABI PreservedAnalyses run(Function &F, FunctionAnalysisManager &AM)
A range representing the start and end location of a loop.
const DebugLoc & getStart() const
Represents a single loop in the control flow graph.
bool isCanonical(ScalarEvolution &SE) const
Return true if the loop induction variable starts at zero and increments by one each time through the...
bool isLCSSAForm(const DominatorTree &DT, bool IgnoreTokens=true) const
Return true if the Loop is in LCSSA form.
std::optional< LoopBounds > getBounds(ScalarEvolution &SE) const
Return the struct LoopBounds collected if all struct members are found, else std::nullopt.
bool isSafeToClone() const
Return true if the loop body is safe to clone in practice.
std::string getLocStr() const
Return a string containing the debug location of the loop (file name + line number if present,...
bool hasLoopInvariantOperands(const Instruction *I) const
Return true if all the operands of the specified instruction are loop invariant.
BranchInst * getLoopGuardBranch() const
Return the loop guard branch, if it exists.
bool isAnnotatedParallel() const
Returns true if the loop is annotated parallel.
DebugLoc getStartLoc() const
Return the debug location of the start of this loop.
LocRange getLocRange() const
Return the source code span of the loop.
bool isLoopInvariant(const Value *V) const
Return true if the specified value is loop invariant.
ICmpInst * getLatchCmpInst() const
Get the latch condition instruction.
bool getInductionDescriptor(ScalarEvolution &SE, InductionDescriptor &IndDesc) const
Get the loop induction descriptor for the loop induction variable.
bool isRotatedForm() const
Return true if the loop is in rotated form.
void setLoopMustProgress()
Add llvm.loop.mustprogress to this loop's loop id metadata.
PHINode * getInductionVariable(ScalarEvolution &SE) const
Return the loop induction variable if found, else return nullptr.
bool isLoopSimplifyForm() const
Return true if the Loop is in the form that the LoopSimplify form transforms loops to,...
bool isRecursivelyLCSSAForm(const DominatorTree &DT, const LoopInfo &LI, bool IgnoreTokens=true) const
Return true if this Loop and all inner subloops are in LCSSA form.
void setLoopID(MDNode *LoopID) const
Set the llvm.loop loop id metadata for this loop.
void setLoopAlreadyUnrolled()
Add llvm.loop.unroll.disable to this loop's loop id metadata.
bool makeLoopInvariant(Value *V, bool &Changed, Instruction *InsertPt=nullptr, MemorySSAUpdater *MSSAU=nullptr, ScalarEvolution *SE=nullptr) const
If the given value is an instruction inside of the loop and it can be hoisted, do so to make it trivi...
PHINode * getCanonicalInductionVariable() const
Check to see if the loop has a canonical induction variable: an integer recurrence that starts at 0 a...
bool getIncomingAndBackEdge(BasicBlock *&Incoming, BasicBlock *&Backedge) const
Obtain the unique incoming and back edge.
MDNode * getLoopID() const
Return the llvm.loop loop id metadata node for this loop if it is present.
bool isAuxiliaryInductionVariable(PHINode &AuxIndVar, ScalarEvolution &SE) const
Return true if the given PHINode AuxIndVar is.
LLVM_ABI void replaceOperandWith(unsigned I, Metadata *New)
Replace a specific operand.
static MDTuple * getDistinct(LLVMContext &Context, ArrayRef< Metadata * > MDs)
const MDOperand & getOperand(unsigned I) const
ArrayRef< MDOperand > operands() const
static MDTuple * get(LLVMContext &Context, ArrayRef< Metadata * > MDs)
unsigned getNumOperands() const
Return number of MDNode operands.
Tracking metadata reference owned by Metadata.
LLVM_ABI StringRef getString() const
static LLVM_ABI MDString * get(LLVMContext &Context, StringRef Str)
MemorySSA * getMemorySSA() const
Get handle on MemorySSA.
LLVM_ABI void moveToPlace(MemoryUseOrDef *What, BasicBlock *BB, MemorySSA::InsertionPlace Where)
MemoryUseOrDef * getMemoryAccess(const Instruction *I) const
Given a memory Mod/Ref'ing instruction, get the MemorySSA access associated with it.
A Module instance is used to store all the information related to an LLVM module.
const std::string & getModuleIdentifier() const
Get the module identifier which is, essentially, the name of the module.
Value * getIncomingValueForBlock(const BasicBlock *BB) const
AnalysisType & getAnalysis() const
getAnalysis<AnalysisType>() - This function is used by subclasses to get to the analysis information ...
A set of analyses that are preserved following a run of a transformation pass.
static PreservedAnalyses all()
Construct a special preserved set that preserves all passes.
PreservedAnalysisChecker getChecker() const
Build a checker for this PreservedAnalyses and the specified analysis type.
This node represents a polynomial recurrence on the trip count of the specified loop.
This class represents an analyzed expression in the program.
The main scalar evolution driver.
LLVM_ABI bool isLoopInvariant(const SCEV *S, const Loop *L)
Return true if the value of the given SCEV is unchanging in the specified loop.
LLVM_ABI void forgetBlockAndLoopDispositions(Value *V=nullptr)
Called when the client has changed the disposition of values in a loop or block.
size_type count(ConstPtrType Ptr) const
count - Return 1 if the specified pointer is in the set, 0 otherwise.
std::pair< iterator, bool > insert(PtrType Ptr)
Inserts Ptr if and only if there is no element in the container equal to Ptr.
SmallPtrSet - This class implements a set which is optimized for holding SmallSize or less elements.
void append(ItTy in_start, ItTy in_end)
Add the specified range to the end of the SmallVector.
void push_back(const T &Elt)
This is a 'vector' (really, a variable-sized array), optimized for the case when the array is small.
StringRef - Represent a constant reference to a string, i.e.
bool starts_with(StringRef Prefix) const
Check if this string starts with the given Prefix.
A Use represents the edge between a Value definition and its users.
Value * getOperand(unsigned i) const
LLVM Value Representation.
iterator_range< user_iterator > users()
const ParentTy * getParent() const
self_iterator getIterator()
This class implements an extremely fast bulk output stream that can only output to a stream.
A raw_ostream that writes to an std::string.
#define llvm_unreachable(msg)
Marks that the current location is not supposed to be reachable.
LocationClass< Ty > location(Ty &L)
std::enable_if_t< detail::IsValidPointer< X, Y >::value, X * > extract_or_null(Y &&MD)
Extract a Value from Metadata, allowing null.
This is an optimization pass for GlobalISel generic memory operations.
auto drop_begin(T &&RangeOrContainer, size_t N=1)
Return a range covering RangeOrContainer with the first N elements excluded.
bool all_of(R &&range, UnaryPredicate P)
Provide wrappers to std::all_of which take ranges instead of having to pass begin/end explicitly.
LLVM_ABI bool getBooleanLoopAttribute(const Loop *TheLoop, StringRef Name)
Returns true if Name is applied to TheLoop and enabled.
bool succ_empty(const Instruction *I)
bool forcePrintModuleIR()
detail::scope_exit< std::decay_t< Callable > > make_scope_exit(Callable &&F)
LLVM_ABI std::optional< bool > getOptionalBoolLoopAttribute(const Loop *TheLoop, StringRef Name)
LLVM_ABI int getIntLoopAttribute(const Loop *TheLoop, StringRef Name, int Default=0)
Find named metadata for a loop with an integer value.
auto pred_end(const MachineBasicBlock *BB)
decltype(auto) dyn_cast(const From &Val)
dyn_cast<X> - Return the argument parameter cast to the specified type.
LLVM_ABI std::optional< const MDOperand * > findStringMetadataForLoop(const Loop *TheLoop, StringRef Name)
Find string metadata for loop.
auto successors(const MachineBasicBlock *BB)
LLVM_ABI MDNode * findOptionMDForLoop(const Loop *TheLoop, StringRef Name)
Find string metadata for a loop.
LLVM_ABI bool isSafeToSpeculativelyExecute(const Instruction *I, const Instruction *CtxI=nullptr, AssumptionCache *AC=nullptr, const DominatorTree *DT=nullptr, const TargetLibraryInfo *TLI=nullptr, bool UseVariableInfo=true, bool IgnoreUBImplyingAttrs=true)
Return true if the instruction does not have any effects besides calculating the result and does not ...
LLVM_ABI bool hasMustProgress(const Loop *L)
Look for the loop attribute that requires progress within the loop.
auto dyn_cast_or_null(const Y &Val)
bool any_of(R &&range, UnaryPredicate P)
Provide wrappers to std::any_of which take ranges instead of having to pass begin/end explicitly.
LLVM_ABI bool isMustProgress(const Loop *L)
Return true if this loop can be assumed to make progress.
LLVM_ABI CallBase * getLoopConvergenceHeart(const Loop *TheLoop)
Find the convergence heart of the loop.
LLVM_ABI bool isFinite(const Loop *L)
Return true if this loop can be assumed to run for a finite number of iterations.
DominatorTreeBase< T, false > DomTreeBase
LLVM_ABI raw_ostream & dbgs()
dbgs() - This returns a reference to a raw_ostream for debugging messages.
LLVM_ABI bool VerifyLoopInfo
Enable verification of loop info.
bool isa(const From &Val)
isa<X> - Return true if the parameter to the template is an instance of one of the template type argu...
LLVM_ABI std::optional< int > getOptionalIntLoopAttribute(const Loop *TheLoop, StringRef Name)
Find named metadata for a loop with an integer value.
LLVM_ABI bool isValidAsAccessGroup(MDNode *AccGroup)
Return whether an MDNode might represent an access group.
LLVM_ABI void printLoop(const Loop &L, raw_ostream &OS, const std::string &Banner="")
Function to print a loop's contents as LLVM's text IR assembly.
DWARFExpression::Operation Op
PredIterator< BasicBlock, Value::user_iterator > pred_iterator
auto pred_begin(const MachineBasicBlock *BB)
decltype(auto) cast(const From &Val)
cast<X> - Return the argument parameter cast to the specified type.
LLVM_ABI llvm::MDNode * makePostTransformationMetadata(llvm::LLVMContext &Context, MDNode *OrigLoopID, llvm::ArrayRef< llvm::StringRef > RemovePrefixes, llvm::ArrayRef< llvm::MDNode * > AddAttrs)
Create a new LoopID after the loop has been transformed.
bool is_contained(R &&Range, const E &Element)
Returns true if Element is found in Range.
AnalysisManager< Function > FunctionAnalysisManager
Convenience typedef for the Function analysis manager.
@ Default
The result values are uniform if and only if all operands are uniform.
LLVM_ABI MDNode * findOptionMDForLoopID(MDNode *LoopID, StringRef Name)
Find and return the loop attribute node for the attribute Name in LoopID.
void swap(llvm::BitVector &LHS, llvm::BitVector &RHS)
Implement std::swap in terms of BitVector swap.
A special type used by analysis passes to provide an address that identifies that particular analysis...
Incoming for lane maks phi as machine instruction, incoming register Reg and incoming block Block are...
LLVM_ABI PreservedAnalyses run(Function &F, FunctionAnalysisManager &AM)
static LLVM_ABI std::optional< Loop::LoopBounds > getBounds(const Loop &L, PHINode &IndVar, ScalarEvolution &SE)
Return the LoopBounds object if.
Direction
An enum for the direction of the loop.
Value & getFinalIVValue() const
Get the final value of the loop induction variable.
Instruction & getStepInst() const
Get the instruction that updates the loop induction variable.
LLVM_ABI ICmpInst::Predicate getCanonicalPredicate() const
Return the canonical predicate for the latch compare instruction, if able to be calcuated.
LLVM_ABI Direction getDirection() const
Get the direction of the loop.