//===- Pass.cpp - Pass infrastructure implementation ----------------------===// // // Part of the LLVM Project, under the Apache License v2.0 with LLVM Exceptions. // See https://llvm.org/LICENSE.txt for license information. // SPDX-License-Identifier: Apache-2.0 WITH LLVM-exception // //===----------------------------------------------------------------------===// // // This file implements common pass infrastructure. // //===----------------------------------------------------------------------===// #include "mlir/Pass/Pass.h" #include "PassDetail.h" #include "mlir/IR/Diagnostics.h" #include "mlir/IR/Dialect.h" #include "mlir/IR/OpDefinition.h" #include "mlir/IR/Threading.h" #include "mlir/IR/Verifier.h" #include "mlir/Support/FileUtilities.h" #include "llvm/ADT/Hashing.h" #include "llvm/ADT/STLExtras.h" #include "llvm/ADT/ScopeExit.h" #include "llvm/Support/CommandLine.h" #include "llvm/Support/CrashRecoveryContext.h" #include "llvm/Support/Mutex.h" #include "llvm/Support/Signals.h" #include "llvm/Support/Threading.h" #include "llvm/Support/ToolOutputFile.h" #include using namespace mlir; using namespace mlir::detail; //===----------------------------------------------------------------------===// // PassExecutionAction //===----------------------------------------------------------------------===// PassExecutionAction::PassExecutionAction(ArrayRef irUnits, const Pass &pass) : Base(irUnits), pass(pass) {} void PassExecutionAction::print(raw_ostream &os) const { os << llvm::formatv("`{0}` running `{1}` on Operation `{2}`", tag, pass.getName(), getOp()->getName()); } Operation *PassExecutionAction::getOp() const { ArrayRef irUnits = getContextIRUnits(); return irUnits.empty() ? nullptr : llvm::dyn_cast_if_present(irUnits[0]); } //===----------------------------------------------------------------------===// // Pass //===----------------------------------------------------------------------===// /// Out of line virtual method to ensure vtables and metadata are emitted to a /// single .o file. void Pass::anchor() {} /// Attempt to initialize the options of this pass from the given string. LogicalResult Pass::initializeOptions(StringRef options) { return passOptions.parseFromString(options); } /// Copy the option values from 'other', which is another instance of this /// pass. void Pass::copyOptionValuesFrom(const Pass *other) { passOptions.copyOptionValuesFrom(other->passOptions); } /// Prints out the pass in the textual representation of pipelines. If this is /// an adaptor pass, print its pass managers. void Pass::printAsTextualPipeline(raw_ostream &os) { // Special case for adaptors to print its pass managers. if (auto *adaptor = dyn_cast(this)) { llvm::interleave( adaptor->getPassManagers(), [&](OpPassManager &pm) { pm.printAsTextualPipeline(os); }, [&] { os << ","; }); return; } // Otherwise, print the pass argument followed by its options. If the pass // doesn't have an argument, print the name of the pass to give some indicator // of what pass was run. StringRef argument = getArgument(); if (!argument.empty()) os << argument; else os << "unknown<" << getName() << ">"; passOptions.print(os); } //===----------------------------------------------------------------------===// // OpPassManagerImpl //===----------------------------------------------------------------------===// namespace mlir { namespace detail { struct OpPassManagerImpl { OpPassManagerImpl(OperationName opName, OpPassManager::Nesting nesting) : name(opName.getStringRef().str()), opName(opName), initializationGeneration(0), nesting(nesting) {} OpPassManagerImpl(StringRef name, OpPassManager::Nesting nesting) : name(name == OpPassManager::getAnyOpAnchorName() ? "" : name.str()), initializationGeneration(0), nesting(nesting) {} OpPassManagerImpl(OpPassManager::Nesting nesting) : initializationGeneration(0), nesting(nesting) {} OpPassManagerImpl(const OpPassManagerImpl &rhs) : name(rhs.name), opName(rhs.opName), initializationGeneration(rhs.initializationGeneration), nesting(rhs.nesting) { for (const std::unique_ptr &pass : rhs.passes) { std::unique_ptr newPass = pass->clone(); newPass->threadingSibling = pass.get(); passes.push_back(std::move(newPass)); } } /// Merge the passes of this pass manager into the one provided. void mergeInto(OpPassManagerImpl &rhs); /// Nest a new operation pass manager for the given operation kind under this /// pass manager. OpPassManager &nest(OperationName nestedName) { return nest(OpPassManager(nestedName, nesting)); } OpPassManager &nest(StringRef nestedName) { return nest(OpPassManager(nestedName, nesting)); } OpPassManager &nestAny() { return nest(OpPassManager(nesting)); } /// Nest the given pass manager under this pass manager. OpPassManager &nest(OpPassManager &&nested); /// Add the given pass to this pass manager. If this pass has a concrete /// operation type, it must be the same type as this pass manager. void addPass(std::unique_ptr pass); /// Clear the list of passes in this pass manager, other options are /// preserved. void clear(); /// Finalize the pass list in preparation for execution. This includes /// coalescing adjacent pass managers when possible, verifying scheduled /// passes, etc. LogicalResult finalizePassList(MLIRContext *ctx); /// Return the operation name of this pass manager. std::optional getOpName(MLIRContext &context) { if (!name.empty() && !opName) opName = OperationName(name, &context); return opName; } std::optional getOpName() const { return name.empty() ? std::optional() : std::optional(name); } /// Return the name used to anchor this pass manager. This is either the name /// of an operation, or the result of `getAnyOpAnchorName()` in the case of an /// op-agnostic pass manager. StringRef getOpAnchorName() const { return getOpName().value_or(OpPassManager::getAnyOpAnchorName()); } /// Indicate if the current pass manager can be scheduled on the given /// operation type. bool canScheduleOn(MLIRContext &context, OperationName opName); /// The name of the operation that passes of this pass manager operate on. std::string name; /// The cached OperationName (internalized in the context) for the name of the /// operation that passes of this pass manager operate on. std::optional opName; /// The set of passes to run as part of this pass manager. std::vector> passes; /// The current initialization generation of this pass manager. This is used /// to indicate when a pass manager should be reinitialized. unsigned initializationGeneration; /// Control the implicit nesting of passes that mismatch the name set for this /// OpPassManager. OpPassManager::Nesting nesting; }; } // namespace detail } // namespace mlir void OpPassManagerImpl::mergeInto(OpPassManagerImpl &rhs) { assert(name == rhs.name && "merging unrelated pass managers"); for (auto &pass : passes) rhs.passes.push_back(std::move(pass)); passes.clear(); } OpPassManager &OpPassManagerImpl::nest(OpPassManager &&nested) { auto *adaptor = new OpToOpPassAdaptor(std::move(nested)); addPass(std::unique_ptr(adaptor)); return adaptor->getPassManagers().front(); } void OpPassManagerImpl::addPass(std::unique_ptr pass) { // If this pass runs on a different operation than this pass manager, then // implicitly nest a pass manager for this operation if enabled. std::optional pmOpName = getOpName(); std::optional passOpName = pass->getOpName(); if (pmOpName && passOpName && *pmOpName != *passOpName) { if (nesting == OpPassManager::Nesting::Implicit) return nest(*passOpName).addPass(std::move(pass)); llvm::report_fatal_error(llvm::Twine("Can't add pass '") + pass->getName() + "' restricted to '" + *passOpName + "' on a PassManager intended to run on '" + getOpAnchorName() + "', did you intend to nest?"); } passes.emplace_back(std::move(pass)); } void OpPassManagerImpl::clear() { passes.clear(); } LogicalResult OpPassManagerImpl::finalizePassList(MLIRContext *ctx) { auto finalizeAdaptor = [ctx](OpToOpPassAdaptor *adaptor) { for (auto &pm : adaptor->getPassManagers()) if (failed(pm.getImpl().finalizePassList(ctx))) return failure(); return success(); }; // Walk the pass list and merge adjacent adaptors. OpToOpPassAdaptor *lastAdaptor = nullptr; for (auto &pass : passes) { // Check to see if this pass is an adaptor. if (auto *currentAdaptor = dyn_cast(pass.get())) { // If it is the first adaptor in a possible chain, remember it and // continue. if (!lastAdaptor) { lastAdaptor = currentAdaptor; continue; } // Otherwise, try to merge into the existing adaptor and delete the // current one. If merging fails, just remember this as the last adaptor. if (succeeded(currentAdaptor->tryMergeInto(ctx, *lastAdaptor))) pass.reset(); else lastAdaptor = currentAdaptor; } else if (lastAdaptor) { // If this pass isn't an adaptor, finalize it and forget the last adaptor. if (failed(finalizeAdaptor(lastAdaptor))) return failure(); lastAdaptor = nullptr; } } // If there was an adaptor at the end of the manager, finalize it as well. if (lastAdaptor && failed(finalizeAdaptor(lastAdaptor))) return failure(); // Now that the adaptors have been merged, erase any empty slots corresponding // to the merged adaptors that were nulled-out in the loop above. llvm::erase_if(passes, std::logical_not>()); // If this is a op-agnostic pass manager, there is nothing left to do. std::optional rawOpName = getOpName(*ctx); if (!rawOpName) return success(); // Otherwise, verify that all of the passes are valid for the current // operation anchor. std::optional opName = rawOpName->getRegisteredInfo(); for (std::unique_ptr &pass : passes) { if (opName && !pass->canScheduleOn(*opName)) { return emitError(UnknownLoc::get(ctx)) << "unable to schedule pass '" << pass->getName() << "' on a PassManager intended to run on '" << getOpAnchorName() << "'!"; } } return success(); } bool OpPassManagerImpl::canScheduleOn(MLIRContext &context, OperationName opName) { // If this pass manager is op-specific, we simply check if the provided // operation name is the same as this one. std::optional pmOpName = getOpName(context); if (pmOpName) return pmOpName == opName; // Otherwise, this is an op-agnostic pass manager. Check that the operation // can be scheduled on all passes within the manager. std::optional registeredInfo = opName.getRegisteredInfo(); if (!registeredInfo || !registeredInfo->hasTrait()) return false; return llvm::all_of(passes, [&](const std::unique_ptr &pass) { return pass->canScheduleOn(*registeredInfo); }); } //===----------------------------------------------------------------------===// // OpPassManager //===----------------------------------------------------------------------===// OpPassManager::OpPassManager(Nesting nesting) : impl(new OpPassManagerImpl(nesting)) {} OpPassManager::OpPassManager(StringRef name, Nesting nesting) : impl(new OpPassManagerImpl(name, nesting)) {} OpPassManager::OpPassManager(OperationName name, Nesting nesting) : impl(new OpPassManagerImpl(name, nesting)) {} OpPassManager::OpPassManager(OpPassManager &&rhs) { *this = std::move(rhs); } OpPassManager::OpPassManager(const OpPassManager &rhs) { *this = rhs; } OpPassManager &OpPassManager::operator=(const OpPassManager &rhs) { impl = std::make_unique(*rhs.impl); return *this; } OpPassManager &OpPassManager::operator=(OpPassManager &&rhs) { impl = std::move(rhs.impl); return *this; } OpPassManager::~OpPassManager() = default; OpPassManager::pass_iterator OpPassManager::begin() { return MutableArrayRef>{impl->passes}.begin(); } OpPassManager::pass_iterator OpPassManager::end() { return MutableArrayRef>{impl->passes}.end(); } OpPassManager::const_pass_iterator OpPassManager::begin() const { return ArrayRef>{impl->passes}.begin(); } OpPassManager::const_pass_iterator OpPassManager::end() const { return ArrayRef>{impl->passes}.end(); } /// Nest a new operation pass manager for the given operation kind under this /// pass manager. OpPassManager &OpPassManager::nest(OperationName nestedName) { return impl->nest(nestedName); } OpPassManager &OpPassManager::nest(StringRef nestedName) { return impl->nest(nestedName); } OpPassManager &OpPassManager::nestAny() { return impl->nestAny(); } /// Add the given pass to this pass manager. If this pass has a concrete /// operation type, it must be the same type as this pass manager. void OpPassManager::addPass(std::unique_ptr pass) { impl->addPass(std::move(pass)); } void OpPassManager::clear() { impl->clear(); } /// Returns the number of passes held by this manager. size_t OpPassManager::size() const { return impl->passes.size(); } /// Returns the internal implementation instance. OpPassManagerImpl &OpPassManager::getImpl() { return *impl; } /// Return the operation name that this pass manager operates on. std::optional OpPassManager::getOpName() const { return impl->getOpName(); } /// Return the operation name that this pass manager operates on. std::optional OpPassManager::getOpName(MLIRContext &context) const { return impl->getOpName(context); } StringRef OpPassManager::getOpAnchorName() const { return impl->getOpAnchorName(); } /// Prints out the passes of the pass manager as the textual representation /// of pipelines. void printAsTextualPipeline( raw_ostream &os, StringRef anchorName, const llvm::iterator_range &passes) { os << anchorName << "("; llvm::interleave( passes, [&](mlir::Pass &pass) { pass.printAsTextualPipeline(os); }, [&]() { os << ","; }); os << ")"; } void OpPassManager::printAsTextualPipeline(raw_ostream &os) const { StringRef anchorName = getOpAnchorName(); ::printAsTextualPipeline( os, anchorName, {MutableArrayRef>{impl->passes}.begin(), MutableArrayRef>{impl->passes}.end()}); } void OpPassManager::dump() { llvm::errs() << "Pass Manager with " << impl->passes.size() << " passes:\n"; printAsTextualPipeline(llvm::errs()); llvm::errs() << "\n"; } static void registerDialectsForPipeline(const OpPassManager &pm, DialectRegistry &dialects) { for (const Pass &pass : pm.getPasses()) pass.getDependentDialects(dialects); } void OpPassManager::getDependentDialects(DialectRegistry &dialects) const { registerDialectsForPipeline(*this, dialects); } void OpPassManager::setNesting(Nesting nesting) { impl->nesting = nesting; } OpPassManager::Nesting OpPassManager::getNesting() { return impl->nesting; } LogicalResult OpPassManager::initialize(MLIRContext *context, unsigned newInitGeneration) { if (impl->initializationGeneration == newInitGeneration) return success(); impl->initializationGeneration = newInitGeneration; for (Pass &pass : getPasses()) { // If this pass isn't an adaptor, directly initialize it. auto *adaptor = dyn_cast(&pass); if (!adaptor) { if (failed(pass.initialize(context))) return failure(); continue; } // Otherwise, initialize each of the adaptors pass managers. for (OpPassManager &adaptorPM : adaptor->getPassManagers()) if (failed(adaptorPM.initialize(context, newInitGeneration))) return failure(); } return success(); } llvm::hash_code OpPassManager::hash() { llvm::hash_code hashCode{}; for (Pass &pass : getPasses()) { // If this pass isn't an adaptor, directly hash it. auto *adaptor = dyn_cast(&pass); if (!adaptor) { hashCode = llvm::hash_combine(hashCode, &pass); continue; } // Otherwise, hash recursively each of the adaptors pass managers. for (OpPassManager &adaptorPM : adaptor->getPassManagers()) llvm::hash_combine(hashCode, adaptorPM.hash()); } return hashCode; } //===----------------------------------------------------------------------===// // OpToOpPassAdaptor //===----------------------------------------------------------------------===// LogicalResult OpToOpPassAdaptor::run(Pass *pass, Operation *op, AnalysisManager am, bool verifyPasses, unsigned parentInitGeneration) { std::optional opInfo = op->getRegisteredInfo(); if (!opInfo) return op->emitOpError() << "trying to schedule a pass on an unregistered operation"; if (!opInfo->hasTrait()) return op->emitOpError() << "trying to schedule a pass on an operation not " "marked as 'IsolatedFromAbove'"; if (!pass->canScheduleOn(*op->getName().getRegisteredInfo())) return op->emitOpError() << "trying to schedule a pass on an unsupported operation"; // Initialize the pass state with a callback for the pass to dynamically // execute a pipeline on the currently visited operation. PassInstrumentor *pi = am.getPassInstrumentor(); PassInstrumentation::PipelineParentInfo parentInfo = {llvm::get_threadid(), pass}; auto dynamicPipelineCallback = [&](OpPassManager &pipeline, Operation *root) -> LogicalResult { if (!op->isAncestor(root)) return root->emitOpError() << "Trying to schedule a dynamic pipeline on an " "operation that isn't " "nested under the current operation the pass is processing"; assert( pipeline.getImpl().canScheduleOn(*op->getContext(), root->getName())); // Before running, finalize the passes held by the pipeline. if (failed(pipeline.getImpl().finalizePassList(root->getContext()))) return failure(); // Initialize the user provided pipeline and execute the pipeline. if (failed(pipeline.initialize(root->getContext(), parentInitGeneration))) return failure(); AnalysisManager nestedAm = root == op ? am : am.nest(root); return OpToOpPassAdaptor::runPipeline(pipeline, root, nestedAm, verifyPasses, parentInitGeneration, pi, &parentInfo); }; pass->passState.emplace(op, am, dynamicPipelineCallback); // Instrument before the pass has run. if (pi) pi->runBeforePass(pass, op); bool passFailed = false; op->getContext()->executeAction( [&]() { // Invoke the virtual runOnOperation method. if (auto *adaptor = dyn_cast(pass)) adaptor->runOnOperation(verifyPasses); else pass->runOnOperation(); passFailed = pass->passState->irAndPassFailed.getInt(); }, {op}, *pass); // Invalidate any non preserved analyses. am.invalidate(pass->passState->preservedAnalyses); // When verifyPasses is specified, we run the verifier (unless the pass // failed). if (!passFailed && verifyPasses) { bool runVerifierNow = true; // If the pass is an adaptor pass, we don't run the verifier recursively // because the nested operations should have already been verified after // nested passes had run. bool runVerifierRecursively = !isa(pass); // Reduce compile time by avoiding running the verifier if the pass didn't // change the IR since the last time the verifier was run: // // 1) If the pass said that it preserved all analyses then it can't have // permuted the IR. // // We run these checks in EXPENSIVE_CHECKS mode out of caution. #ifndef EXPENSIVE_CHECKS runVerifierNow = !pass->passState->preservedAnalyses.isAll(); #endif if (runVerifierNow) passFailed = failed(verify(op, runVerifierRecursively)); } // Instrument after the pass has run. if (pi) { if (passFailed) pi->runAfterPassFailed(pass, op); else pi->runAfterPass(pass, op); } // Return if the pass signaled a failure. return failure(passFailed); } /// Run the given operation and analysis manager on a provided op pass manager. LogicalResult OpToOpPassAdaptor::runPipeline( OpPassManager &pm, Operation *op, AnalysisManager am, bool verifyPasses, unsigned parentInitGeneration, PassInstrumentor *instrumentor, const PassInstrumentation::PipelineParentInfo *parentInfo) { assert((!instrumentor || parentInfo) && "expected parent info if instrumentor is provided"); auto scopeExit = llvm::make_scope_exit([&] { // Clear out any computed operation analyses. These analyses won't be used // any more in this pipeline, and this helps reduce the current working set // of memory. If preserving these analyses becomes important in the future // we can re-evaluate this. am.clear(); }); // Run the pipeline over the provided operation. if (instrumentor) { instrumentor->runBeforePipeline(pm.getOpName(*op->getContext()), *parentInfo); } for (Pass &pass : pm.getPasses()) if (failed(run(&pass, op, am, verifyPasses, parentInitGeneration))) return failure(); if (instrumentor) { instrumentor->runAfterPipeline(pm.getOpName(*op->getContext()), *parentInfo); } return success(); } /// Find an operation pass manager with the given anchor name, or nullptr if one /// does not exist. static OpPassManager * findPassManagerWithAnchor(MutableArrayRef mgrs, StringRef name) { auto *it = llvm::find_if( mgrs, [&](OpPassManager &mgr) { return mgr.getOpAnchorName() == name; }); return it == mgrs.end() ? nullptr : &*it; } /// Find an operation pass manager that can operate on an operation of the given /// type, or nullptr if one does not exist. static OpPassManager *findPassManagerFor(MutableArrayRef mgrs, OperationName name, MLIRContext &context) { auto *it = llvm::find_if(mgrs, [&](OpPassManager &mgr) { return mgr.getImpl().canScheduleOn(context, name); }); return it == mgrs.end() ? nullptr : &*it; } OpToOpPassAdaptor::OpToOpPassAdaptor(OpPassManager &&mgr) { mgrs.emplace_back(std::move(mgr)); } void OpToOpPassAdaptor::getDependentDialects(DialectRegistry &dialects) const { for (auto &pm : mgrs) pm.getDependentDialects(dialects); } LogicalResult OpToOpPassAdaptor::tryMergeInto(MLIRContext *ctx, OpToOpPassAdaptor &rhs) { // Functor used to check if a pass manager is generic, i.e. op-agnostic. auto isGenericPM = [&](OpPassManager &pm) { return !pm.getOpName(); }; // Functor used to detect if the given generic pass manager will have a // potential schedule conflict with the given `otherPMs`. auto hasScheduleConflictWith = [&](OpPassManager &genericPM, MutableArrayRef otherPMs) { return llvm::any_of(otherPMs, [&](OpPassManager &pm) { // If this is a non-generic pass manager, a conflict will arise if a // non-generic pass manager's operation name can be scheduled on the // generic passmanager. if (std::optional pmOpName = pm.getOpName(*ctx)) return genericPM.getImpl().canScheduleOn(*ctx, *pmOpName); // Otherwise, this is a generic pass manager. We current can't determine // when generic pass managers can be merged, so conservatively assume they // conflict. return true; }); }; // Check that if either adaptor has a generic pass manager, that pm is // compatible within any non-generic pass managers. // // Check the current adaptor. auto *lhsGenericPMIt = llvm::find_if(mgrs, isGenericPM); if (lhsGenericPMIt != mgrs.end() && hasScheduleConflictWith(*lhsGenericPMIt, rhs.mgrs)) return failure(); // Check the rhs adaptor. auto *rhsGenericPMIt = llvm::find_if(rhs.mgrs, isGenericPM); if (rhsGenericPMIt != rhs.mgrs.end() && hasScheduleConflictWith(*rhsGenericPMIt, mgrs)) return failure(); for (auto &pm : mgrs) { // If an existing pass manager exists, then merge the given pass manager // into it. if (auto *existingPM = findPassManagerWithAnchor(rhs.mgrs, pm.getOpAnchorName())) { pm.getImpl().mergeInto(existingPM->getImpl()); } else { // Otherwise, add the given pass manager to the list. rhs.mgrs.emplace_back(std::move(pm)); } } mgrs.clear(); // After coalescing, sort the pass managers within rhs by name. auto compareFn = [](const OpPassManager *lhs, const OpPassManager *rhs) { // Order op-specific pass managers first and op-agnostic pass managers last. if (std::optional lhsName = lhs->getOpName()) { if (std::optional rhsName = rhs->getOpName()) return lhsName->compare(*rhsName); return -1; // lhs(op-specific) < rhs(op-agnostic) } return 1; // lhs(op-agnostic) > rhs(op-specific) }; llvm::array_pod_sort(rhs.mgrs.begin(), rhs.mgrs.end(), compareFn); return success(); } /// Returns the adaptor pass name. std::string OpToOpPassAdaptor::getAdaptorName() { std::string name = "Pipeline Collection : ["; llvm::raw_string_ostream os(name); llvm::interleaveComma(getPassManagers(), os, [&](OpPassManager &pm) { os << '\'' << pm.getOpAnchorName() << '\''; }); os << ']'; return os.str(); } void OpToOpPassAdaptor::runOnOperation() { llvm_unreachable( "Unexpected call to Pass::runOnOperation() on OpToOpPassAdaptor"); } /// Run the held pipeline over all nested operations. void OpToOpPassAdaptor::runOnOperation(bool verifyPasses) { if (getContext().isMultithreadingEnabled()) runOnOperationAsyncImpl(verifyPasses); else runOnOperationImpl(verifyPasses); } /// Run this pass adaptor synchronously. void OpToOpPassAdaptor::runOnOperationImpl(bool verifyPasses) { auto am = getAnalysisManager(); PassInstrumentation::PipelineParentInfo parentInfo = {llvm::get_threadid(), this}; auto *instrumentor = am.getPassInstrumentor(); for (auto ®ion : getOperation()->getRegions()) { for (auto &block : region) { for (auto &op : block) { auto *mgr = findPassManagerFor(mgrs, op.getName(), *op.getContext()); if (!mgr) continue; // Run the held pipeline over the current operation. unsigned initGeneration = mgr->impl->initializationGeneration; if (failed(runPipeline(*mgr, &op, am.nest(&op), verifyPasses, initGeneration, instrumentor, &parentInfo))) return signalPassFailure(); } } } } /// Utility functor that checks if the two ranges of pass managers have a size /// mismatch. static bool hasSizeMismatch(ArrayRef lhs, ArrayRef rhs) { return lhs.size() != rhs.size() || llvm::any_of(llvm::seq(0, lhs.size()), [&](size_t i) { return lhs[i].size() != rhs[i].size(); }); } /// Run this pass adaptor synchronously. void OpToOpPassAdaptor::runOnOperationAsyncImpl(bool verifyPasses) { AnalysisManager am = getAnalysisManager(); MLIRContext *context = &getContext(); // Create the async executors if they haven't been created, or if the main // pipeline has changed. if (asyncExecutors.empty() || hasSizeMismatch(asyncExecutors.front(), mgrs)) asyncExecutors.assign(context->getThreadPool().getThreadCount(), mgrs); // This struct represents the information for a single operation to be // scheduled on a pass manager. struct OpPMInfo { OpPMInfo(unsigned passManagerIdx, Operation *op, AnalysisManager am) : passManagerIdx(passManagerIdx), op(op), am(am) {} /// The index of the pass manager to schedule the operation on. unsigned passManagerIdx; /// The operation to schedule. Operation *op; /// The analysis manager for the operation. AnalysisManager am; }; // Run a prepass over the operation to collect the nested operations to // execute over. This ensures that an analysis manager exists for each // operation, as well as providing a queue of operations to execute over. std::vector opInfos; DenseMap> knownOpPMIdx; for (auto ®ion : getOperation()->getRegions()) { for (Operation &op : region.getOps()) { // Get the pass manager index for this operation type. auto pmIdxIt = knownOpPMIdx.try_emplace(op.getName(), std::nullopt); if (pmIdxIt.second) { if (auto *mgr = findPassManagerFor(mgrs, op.getName(), *context)) pmIdxIt.first->second = std::distance(mgrs.begin(), mgr); } // If this operation can be scheduled, add it to the list. if (pmIdxIt.first->second) opInfos.emplace_back(*pmIdxIt.first->second, &op, am.nest(&op)); } } // Get the current thread for this adaptor. PassInstrumentation::PipelineParentInfo parentInfo = {llvm::get_threadid(), this}; auto *instrumentor = am.getPassInstrumentor(); // An atomic failure variable for the async executors. std::vector> activePMs(asyncExecutors.size()); std::fill(activePMs.begin(), activePMs.end(), false); auto processFn = [&](OpPMInfo &opInfo) { // Find an executor for this operation. auto it = llvm::find_if(activePMs, [](std::atomic &isActive) { bool expectedInactive = false; return isActive.compare_exchange_strong(expectedInactive, true); }); unsigned pmIndex = it - activePMs.begin(); // Get the pass manager for this operation and execute it. OpPassManager &pm = asyncExecutors[pmIndex][opInfo.passManagerIdx]; LogicalResult pipelineResult = runPipeline( pm, opInfo.op, opInfo.am, verifyPasses, pm.impl->initializationGeneration, instrumentor, &parentInfo); // Reset the active bit for this pass manager. activePMs[pmIndex].store(false); return pipelineResult; }; // Signal a failure if any of the executors failed. if (failed(failableParallelForEach(context, opInfos, processFn))) signalPassFailure(); } //===----------------------------------------------------------------------===// // PassManager //===----------------------------------------------------------------------===// PassManager::PassManager(MLIRContext *ctx, StringRef operationName, Nesting nesting) : OpPassManager(operationName, nesting), context(ctx), passTiming(false), verifyPasses(true) {} PassManager::PassManager(OperationName operationName, Nesting nesting) : OpPassManager(operationName, nesting), context(operationName.getContext()), passTiming(false), verifyPasses(true) {} PassManager::~PassManager() = default; void PassManager::enableVerifier(bool enabled) { verifyPasses = enabled; } /// Run the passes within this manager on the provided operation. LogicalResult PassManager::run(Operation *op) { MLIRContext *context = getContext(); std::optional anchorOp = getOpName(*context); if (anchorOp && anchorOp != op->getName()) return emitError(op->getLoc()) << "can't run '" << getOpAnchorName() << "' pass manager on '" << op->getName() << "' op"; // Register all dialects for the current pipeline. DialectRegistry dependentDialects; getDependentDialects(dependentDialects); context->appendDialectRegistry(dependentDialects); for (StringRef name : dependentDialects.getDialectNames()) context->getOrLoadDialect(name); // Before running, make sure to finalize the pipeline pass list. if (failed(getImpl().finalizePassList(context))) return failure(); // Notify the context that we start running a pipeline for bookkeeping. context->enterMultiThreadedExecution(); // Initialize all of the passes within the pass manager with a new generation. llvm::hash_code newInitKey = context->getRegistryHash(); llvm::hash_code pipelineKey = hash(); if (newInitKey != initializationKey || pipelineKey != pipelineInitializationKey) { if (failed(initialize(context, impl->initializationGeneration + 1))) return failure(); initializationKey = newInitKey; pipelineKey = pipelineInitializationKey; } // Construct a top level analysis manager for the pipeline. ModuleAnalysisManager am(op, instrumentor.get()); // If reproducer generation is enabled, run the pass manager with crash // handling enabled. LogicalResult result = crashReproGenerator ? runWithCrashRecovery(op, am) : runPasses(op, am); // Notify the context that the run is done. context->exitMultiThreadedExecution(); // Dump all of the pass statistics if necessary. if (passStatisticsMode) dumpStatistics(); return result; } /// Add the provided instrumentation to the pass manager. void PassManager::addInstrumentation(std::unique_ptr pi) { if (!instrumentor) instrumentor = std::make_unique(); instrumentor->addInstrumentation(std::move(pi)); } LogicalResult PassManager::runPasses(Operation *op, AnalysisManager am) { return OpToOpPassAdaptor::runPipeline(*this, op, am, verifyPasses, impl->initializationGeneration); } //===----------------------------------------------------------------------===// // AnalysisManager //===----------------------------------------------------------------------===// /// Get an analysis manager for the given operation, which must be a proper /// descendant of the current operation represented by this analysis manager. AnalysisManager AnalysisManager::nest(Operation *op) { Operation *currentOp = impl->getOperation(); assert(currentOp->isProperAncestor(op) && "expected valid descendant operation"); // Check for the base case where the provided operation is immediately nested. if (currentOp == op->getParentOp()) return nestImmediate(op); // Otherwise, we need to collect all ancestors up to the current operation. SmallVector opAncestors; do { opAncestors.push_back(op); op = op->getParentOp(); } while (op != currentOp); AnalysisManager result = *this; for (Operation *op : llvm::reverse(opAncestors)) result = result.nestImmediate(op); return result; } /// Get an analysis manager for the given immediately nested child operation. AnalysisManager AnalysisManager::nestImmediate(Operation *op) { assert(impl->getOperation() == op->getParentOp() && "expected immediate child operation"); auto it = impl->childAnalyses.find(op); if (it == impl->childAnalyses.end()) it = impl->childAnalyses .try_emplace(op, std::make_unique(op, impl)) .first; return {it->second.get()}; } /// Invalidate any non preserved analyses. void detail::NestedAnalysisMap::invalidate( const detail::PreservedAnalyses &pa) { // If all analyses were preserved, then there is nothing to do here. if (pa.isAll()) return; // Invalidate the analyses for the current operation directly. analyses.invalidate(pa); // If no analyses were preserved, then just simply clear out the child // analysis results. if (pa.isNone()) { childAnalyses.clear(); return; } // Otherwise, invalidate each child analysis map. SmallVector mapsToInvalidate(1, this); while (!mapsToInvalidate.empty()) { auto *map = mapsToInvalidate.pop_back_val(); for (auto &analysisPair : map->childAnalyses) { analysisPair.second->invalidate(pa); if (!analysisPair.second->childAnalyses.empty()) mapsToInvalidate.push_back(analysisPair.second.get()); } } } //===----------------------------------------------------------------------===// // PassInstrumentation //===----------------------------------------------------------------------===// PassInstrumentation::~PassInstrumentation() = default; void PassInstrumentation::runBeforePipeline( std::optional name, const PipelineParentInfo &parentInfo) {} void PassInstrumentation::runAfterPipeline( std::optional name, const PipelineParentInfo &parentInfo) {} //===----------------------------------------------------------------------===// // PassInstrumentor //===----------------------------------------------------------------------===// namespace mlir { namespace detail { struct PassInstrumentorImpl { /// Mutex to keep instrumentation access thread-safe. llvm::sys::SmartMutex mutex; /// Set of registered instrumentations. std::vector> instrumentations; }; } // namespace detail } // namespace mlir PassInstrumentor::PassInstrumentor() : impl(new PassInstrumentorImpl()) {} PassInstrumentor::~PassInstrumentor() = default; /// See PassInstrumentation::runBeforePipeline for details. void PassInstrumentor::runBeforePipeline( std::optional name, const PassInstrumentation::PipelineParentInfo &parentInfo) { llvm::sys::SmartScopedLock instrumentationLock(impl->mutex); for (auto &instr : impl->instrumentations) instr->runBeforePipeline(name, parentInfo); } /// See PassInstrumentation::runAfterPipeline for details. void PassInstrumentor::runAfterPipeline( std::optional name, const PassInstrumentation::PipelineParentInfo &parentInfo) { llvm::sys::SmartScopedLock instrumentationLock(impl->mutex); for (auto &instr : llvm::reverse(impl->instrumentations)) instr->runAfterPipeline(name, parentInfo); } /// See PassInstrumentation::runBeforePass for details. void PassInstrumentor::runBeforePass(Pass *pass, Operation *op) { llvm::sys::SmartScopedLock instrumentationLock(impl->mutex); for (auto &instr : impl->instrumentations) instr->runBeforePass(pass, op); } /// See PassInstrumentation::runAfterPass for details. void PassInstrumentor::runAfterPass(Pass *pass, Operation *op) { llvm::sys::SmartScopedLock instrumentationLock(impl->mutex); for (auto &instr : llvm::reverse(impl->instrumentations)) instr->runAfterPass(pass, op); } /// See PassInstrumentation::runAfterPassFailed for details. void PassInstrumentor::runAfterPassFailed(Pass *pass, Operation *op) { llvm::sys::SmartScopedLock instrumentationLock(impl->mutex); for (auto &instr : llvm::reverse(impl->instrumentations)) instr->runAfterPassFailed(pass, op); } /// See PassInstrumentation::runBeforeAnalysis for details. void PassInstrumentor::runBeforeAnalysis(StringRef name, TypeID id, Operation *op) { llvm::sys::SmartScopedLock instrumentationLock(impl->mutex); for (auto &instr : impl->instrumentations) instr->runBeforeAnalysis(name, id, op); } /// See PassInstrumentation::runAfterAnalysis for details. void PassInstrumentor::runAfterAnalysis(StringRef name, TypeID id, Operation *op) { llvm::sys::SmartScopedLock instrumentationLock(impl->mutex); for (auto &instr : llvm::reverse(impl->instrumentations)) instr->runAfterAnalysis(name, id, op); } /// Add the given instrumentation to the collection. void PassInstrumentor::addInstrumentation( std::unique_ptr pi) { llvm::sys::SmartScopedLock instrumentationLock(impl->mutex); impl->instrumentations.emplace_back(std::move(pi)); }