MLIR: lib/Dialect/Linalg/TransformOps/LinalgTransformOps.cpp File Reference (original) (raw)

Go to the source code of this file.

Macros
#define DEBUG_TYPE "linalg-transforms"
#define DOWNSCALE(trans)
#define DOWNSCALE_CALL(a, b)
#define DOWNSCALE_NORMAL(a, b)
#define GET_OP_CLASSES
Functions
template<typename PatternTy, typename... Args>
static FailureOr< LinalgOp > tryApply (Operation *operation, Args &&...args)
Attempts to apply the pattern specified as template argument to the given operation.
static DiagnosedSilenceableFailure unpackSingleIndexResultPayloadOperations (transform::TransformState &state, TransformOpInterface transformOp, SmallVector< OpFoldResult > &result, ArrayRef< OpFoldResult > ofrs)
Assuming that ofr is an index attr or a param of index type or a transform dialect handle mapped to exactly one op with one index result, return that value.
static DiagnosedSilenceableFailure unpackSingleIndexResultPayloadOperations (transform::TransformState &state, TransformOpInterface transformOp, SmallVector< OpFoldResult > &result, Value packedHandle)
static DiagnosedSilenceableFailure reifyMixedParamAndHandleResults (TransformState &state, TransformOpInterface &transformOp, ArrayRef< OpFoldResult > mixedResults, SmallVectorImpl< int64_t > &reified)
When possible, converts each OpFoldResult in mixedResult to an integer if the value can be statically inferred.
static bool mayBeRead (OpOperand &operand)
Return true if the operand may be read from by its owner.
static bool mayBeRead (Value value)
Return true if the value may be read through any of its uses.
template<typename Range>
static LogicalResult applyTilingToAll (RewriterBase &rewriter, Operation *transformOp, Range &&payloadOps, unsigned numLoops, transform::TransformResults &transformResults, function_ref< FailureOr< scf::SCFTileAndFuseResult >(TilingInterface)> applyFn)
Apply a tiling transformation to all payload ops and store both the tiled operation as well as the created tile loops.
static Operation * replaceForAllWithNewSignature (RewriterBase &rewriter, Diagnostic &diag, Operation *producerOp, Operation *containingOp, TilingResult &tileAndFuseResult, int64_t resultNumber, SmallVector< OpFoldResult > &offsets, SmallVector< OpFoldResult > &sizes)
Add new operands to the forall op for users of the producerOp that are dominated by the containing scf.forall op.
static bool sameOrEquivalentIterArg (Value src, Value dst)
Given two operands coming from a loop iter arg, 'src' and 'dst', return true if the operand 'src' is equal to 'dst' or equal to a iter arg present in a outer loop.
static std::tuple< SmallVector< Operation * >, Operation * > tileAndFuseFirstExtractUse (RewriterBase &rewriter, Diagnostic &diag, Operation *producerOp, Operation *containingOp)
Find the first "extract" user of producerOp and tile it right before its use.
static SmallVector< Operation * > tileAndFuseFirstExtractUseThroughContainingOpBlockArgument (RewriterBase &rewriter, Diagnostic &diag, Operation *producerOp, Operation *containingOp)
First, find the first "scf::ForallOp" user of producerOp and ensure it is exactly the containingOp, otherwise bail.
static Operation * cloneAndFuseFirstUse (RewriterBase &rewriter, Diagnostic &diag, Operation *producerOp, Operation *containingOp)
static void printMultitileSizesTypes (OpAsmPrinter &printer, Operation *op, Type targetType, Type lowSizeType, Type, Type)
static ParseResult parseMultitileSizesTypes (OpAsmParser &parser, Type &targetType, Type &lowSizeType, Type &highSizeType, Type &splitPointType)
ArrayAttr ()
b getI64ArrayAttr (paddingDimensions)
static void printContinuousTileSizeTypes (OpAsmPrinter &printer, Operation *op, Type targetType, Type tileSizes, Type)
static ParseResult parseContinuousTileSizeTypes (OpAsmParser &parser, Type &targetType, Type &tileSizesType, Type &chunkSizesType)
static SmallVector< OpFoldResult > normalizeUpperBounds (RewriterBase &rewriter, Location loc, ArrayRef< OpFoldResult > lbs, ArrayRef< OpFoldResult > ubs, ArrayRef< OpFoldResult > steps)
Given lbs, ubs and steps of loops, return (for each loop), the normalized upper bound.
static SmallVector< Value > denormalizeIndVar (RewriterBase &rewriter, Location loc, ValueRange ivs, ArrayRef< OpFoldResult > lbs, ArrayRef< OpFoldResult > steps)
When a loop is normalized, the uses of the induction variable within the loop need to replaced with original_lb + old_iv * original_step.
static scf::ForallOp normalizeForallLoopOp (RewriterBase &rewriter, scf::ForallOp loop)
Given a scf.forall loop return a loop op with the loop bounds normalized. TODO: Replace this with a general utility to normalize scf.forall. At the time of writing, this wasnt done since adding this to scf dialect would disallow using of affine.apply operations due to cyclic dependencies. To avoid churn in lit tests with the change this was added with, defer that to a follow up.
template
static DiagnosedSilenceableFailure doit (RewriterBase &rewriter, OpTy target, transform::ApplyToEachResultList &results, transform::TransformState &state)
Variables
b
Return true if permutation is a valid permutation of the outer_dims_perm (case OuterOrInnerPerm::Outer) or inner_dims_pos (OuterOrInnerPerm::Inner) of the tensor.pack or tensor.unpack op.
result
TypeRange {resultType, resultType}
target
b ValueRange {}

DEBUG_TYPE

#define DEBUG_TYPE "linalg-transforms"

DOWNSCALE

#define DOWNSCALE ( trans )

Value:

{ \

FailureOr res = tryApply(target); \

if (succeeded(res)) { \

results.push_back(*res); \

} \

}

static FailureOr< LinalgOp > tryApply(Operation *operation, Args &&...args)

Attempts to apply the pattern specified as template argument to the given operation.

static DiagnosedSilenceableFailure success()

Constructs a DiagnosedSilenceableFailure in the success state.

DOWNSCALE_CALL

#define DOWNSCALE_CALL ( a,
b )

Value:

Rewrites 2-D convolution ops with size-1 window dimensions into 1-D convolution ops.

DOWNSCALE_NORMAL

#define DOWNSCALE_NORMAL ( a,
b )

Value:

DOWNSCALE(DOWNSCALE_CALL(a, b))

b

Return true if permutation is a valid permutation of the outer_dims_perm (case OuterOrInnerPerm::Oute...

#define DOWNSCALE_CALL(a, b)

GET_OP_CLASSES

applyTilingToAll()

ArrayAttr()

Referenced by adjustIter(), appendCallOpAliasScopes(), mlir::spirv::attributeName< FPFastMathMode >(), mlir::spirv::attributeName< ImageSamplerUseInfo >(), mlir::spirv::attributeName< ImageSamplingInfo >(), mlir::spirv::attributeName< MemoryModel >(), mlir::spirv::attributeName< PackedVectorFormat >(), checkGlobalXtorData(), concatArrayAttr(), mlir::LLVM::convertArrayToIndices(), convertLinkerOptionsOp(), convertMLIRAttributesToLLVM(), convertModuleFlagsOp(), convertModuleFlagValue(), convertOperandBundles(), deepCloneAliasScopes(), extractVector(), extractVector(), findSegment(), foldExtractStridedOpFromInsertChain(), getArgResAttrs(), getAsIntegers(), mlir::getAsOpFoldResult(), getDimMap(), getFirstIntValue(), getFirstOrLastMappedMemberPtr(), getLLVMAlignParamForCompressExpand(), getOverlappedMembers(), getReductionIndex(), mlir::spirv::getStrArrayAttrForEnumList(), handleArgumentImpl(), handleResultImpl(), inferStridedSliceOpResultType(), inverseTransposeInBoundsAttr(), isArrayOf(), mlir::sparse_tensor::isCertainZero(), isIntegerArrayAttrConfinedToRange(), isIntegerArrayAttrConfinedToShape(), isIntegerArrayAttrSmallerThanShape(), isSumOfIntegerArrayAttrConfinedToShape(), IsValidMatrixOpParams(), makeArrayAttr(), makeI64ArrayAttr(), mlirLinalgGetIndexingMapsAttribute(), parseAlignedClause(), parseAttributesOp(), parseClauseWithRegionArgs(), parseCopyprivate(), parseCreateOperationOpAttributes(), parseDependVarList(), parseForeachMatchSymbols(), parseInReductionPrivateReductionRegion(), parseInReductionPrivateRegion(), parseNamedValueList(), parseNamedValueListImpl(), parseNamedValueListWithVariadicity(), parseOpBundles(), parseOperationOpAttributes(), mlir::AsmParser::parseOptionalAttribute(), mlir::detail::AsmParserImpl< BaseT >::parseOptionalAttribute(), parsePrivateReductionRegion(), parsePrivateRegion(), parseTargetOpRegion(), parseTaskReductionRegion(), parseVerCapExtAttr(), populateFromInt64AttrArray(), populateFromInt64AttrArray(), mlir::vector::populateVectorToVectorCanonicalizationPatterns(), printAttributesOp(), printAttributions(), printClauseWithRegionArgs(), printCreateOperationOpAttributes(), printForeachMatchSymbols(), printFunctionResultList(), printInReductionPrivateReductionRegion(), printInReductionPrivateRegion(), printMembersIndex(), printNamedValueList(), printNamedValueListImpl(), printNamedValueListWithVariadicity(), printOperationOpAttributes(), printPrivateReductionRegion(), printPrivateRegion(), printTargetOpRegion(), printTaskReductionRegion(), processParallelLoop(), processPassthroughAttrs(), processTargetSpecificAttrs(), setArgResAttrDict(), setArgResAttrs(), setAttributionAttrs(), sortMapIndices(), verifyDeviceTypeAndSegmentCountMatch(), verifyDeviceTypeCountMatch(), verifyNames(), verifyStructArrayConstant(), mlir::function_interface_impl::verifyTrait(), and verifyTransferOp().

cloneAndFuseFirstUse()

Definition at line 1182 of file LinalgTransformOps.cpp.

References mlir::OpBuilder::clone(), diag(), mlir::IROperand< DerivedT, IRValueT >::get(), mlir::Operation::getLoc(), mlir::Operation::getOpResults(), mlir::detail::IROperandBase::getOwner(), mlir::Operation::isProperAncestor(), mlir::RewriterBase::modifyOpInPlace(), result, and mlir::OpBuilder::setInsertionPoint().

denormalizeIndVar()

doit()

getI64ArrayAttr()

b getI64ArrayAttr ( paddingDimensions )

References b.

mayBeRead() [1/2]

mayBeRead() [2/2]

normalizeForallLoopOp()

scf::ForallOp normalizeForallLoopOp ( RewriterBase & rewriter, scf::ForallOp loop ) static

normalizeUpperBounds()

parseContinuousTileSizeTypes()

ParseResult parseContinuousTileSizeTypes ( OpAsmParser & parser, Type & targetType, Type & tileSizesType, Type & chunkSizesType ) static

parseMultitileSizesTypes()

ParseResult parseMultitileSizesTypes ( OpAsmParser & parser, Type & targetType, Type & lowSizeType, Type & highSizeType, Type & splitPointType ) static

printContinuousTileSizeTypes()

printMultitileSizesTypes()

reifyMixedParamAndHandleResults()

When possible, converts each OpFoldResult in mixedResult to an integer if the value can be statically inferred.

If a result is a Value then it must be either a ParamType or a handle to an a constant like op.

Definition at line 172 of file LinalgTransformOps.cpp.

References mlir::Operation::getNumResults(), mlir::transform::TransformState::getParams(), mlir::transform::TransformState::getPayloadOps(), mlir::Operation::getResult(), mlir::getType(), mlir::Value::getType(), mlir::Type::isIndex(), mlir::m_Constant(), mlir::matchPattern(), and mlir::DiagnosedSilenceableFailure::success().

replaceForAllWithNewSignature()

Add new operands to the forall op for users of the producerOp that are dominated by the containing scf.forall op.

Definition at line 825 of file LinalgTransformOps.cpp.

References diag(), mlir::DominanceInfo::dominates(), mlir::RewriterBase::eraseBlock(), mlir::Builder::getIndexAttr(), mlir::Operation::getLoc(), mlir::Operation::getResult(), mlir::Value::getUsers(), mlir::Operation::isAncestor(), mlir::RewriterBase::replaceAllUsesWith(), mlir::RewriterBase::replaceUsesWithIf(), result, mlir::OpBuilder::setInsertionPoint(), and mlir::TilingResult::tiledValues.

Referenced by tileAndFuseFirstExtractUse().

sameOrEquivalentIterArg()

tileAndFuseFirstExtractUse()

Find the first "extract" user of producerOp and tile it right before its use.

The tiled op is fused under the containingOp. Return this fused op on success or nullptr if anything fails. If tiled op has uses that are dominated by containingOp, return a new containingOp with results of the fused op appended to results of the containingOp or nullptr if there are no dominated uses.

Definition at line 957 of file LinalgTransformOps.cpp.

References mlir::clone(), mlir::OpBuilder::clone(), diag(), mlir::RewriterBase::eraseOp(), mlir::Operation::getLoc(), mlir::OpOperand::getOperandNumber(), mlir::RewriterBase::modifyOpInPlace(), replaceForAllWithNewSignature(), mlir::RewriterBase::replaceOp(), sameOrEquivalentIterArg(), and mlir::OpBuilder::setInsertionPoint().

tileAndFuseFirstExtractUseThroughContainingOpBlockArgument()

First, find the first "scf::ForallOp" user of producerOp and ensure it is exactly the containingOp, otherwise bail.

Then, find the first "extract" user of the tied block argument and tile it right before its "extract" use. The tiled op is fused under the containingOp. Return this fused op on success or nullptr if anything fails.

Definition at line 1080 of file LinalgTransformOps.cpp.

References mlir::OpBuilder::clone(), diag(), mlir::RewriterBase::eraseOp(), mlir::IROperand< DerivedT, IRValueT >::get(), mlir::Operation::getLoc(), mlir::OpOperand::getOperandNumber(), mlir::tensor::getOrCreateDestinations(), mlir::Value::getUsers(), mlir::IRMapping::map(), mlir::RewriterBase::modifyOpInPlace(), mlir::RewriterBase::replaceOp(), mlir::OpBuilder::setInsertionPoint(), and mlir::Operation::setOperand().

tryApply()

template<typename PatternTy, typename... Args>

FailureOr< LinalgOp > tryApply ( Operation * operation, Args &&... args ) static

unpackSingleIndexResultPayloadOperations() [1/2]

Assuming that ofr is an index attr or a param of index type or a transform dialect handle mapped to exactly one op with one index result, return that value.

Definition at line 86 of file LinalgTransformOps.cpp.

References diag(), mlir::Operation::getLoc(), mlir::Value::getLoc(), mlir::Operation::getNumResults(), mlir::transform::TransformState::getParams(), mlir::transform::TransformState::getPayloadOps(), mlir::Operation::getResult(), mlir::Value::getType(), mlir::Type::isIndex(), result, and mlir::DiagnosedSilenceableFailure::success().

unpackSingleIndexResultPayloadOperations() [2/2]

b

Return true if permutation is a valid permutation of the outer_dims_perm (case OuterOrInnerPerm::Outer) or inner_dims_pos (OuterOrInnerPerm::Inner) of the tensor.pack or tensor.unpack op.

/ This is the case when the permutation rank matches the rank expected by / op and permutation is itself a permutation vector. / Return true if either op or permutation` are empty to allow a simpler / polymorphic implementation. template static bool isValidPackingPermutation( RelayoutOpTy op, ArrayRef<int64_t> permutation, OuterOrInnerPerm outerOrInnerPerm = OuterOrInnerPerm::Outer) { static_assert( llvm::is_one_of<RelayoutOpTy, linalg::PackOp, linalg::UnPackOp>::value, "applies to only pack or unpack operations"); if (!op || permutation.empty()) return true; size_t innerRank = op.getInnerDimsPos().size(); if (outerOrInnerPerm == OuterOrInnerPerm::Inner) return permutation.size() == innerRank && isPermutationVector(permutation); op.getOuterDimsPerm() may be empty, in which case it is identity. Don't rely on it. if (std::is_same<RelayoutOpTy, linalg::PackOp>::value) { return permutation.size() == op.getSourceRank() && isPermutationVector(permutation); } return permutation.size() == op.getDestRank() && isPermutationVector(permutation); }

DiagnosedSilenceableFailure transform::PackTransposeOp::apply(transform::TransformRewriter &rewriter, transform::TransformResults &transformResults, transform::TransformState &state) { auto packOrUnpackOps = state.getPayloadOps(getTargetPackOrUnPackOp()); auto linalgOps = state.getPayloadOps(getTargetLinalgOp()); Step 1. If nothing to pack, propagate success. if (std::empty(packOrUnpackOps)) { transformResults.set(cast(getPackedOp()), {}); transformResults.set(cast(getPackOp()), {}); transformResults.set(cast(getUnPackOp()), {}); return DiagnosedSilenceableFailure::success(); }

Step 2. Bunch of runtime sanity check and error messages. Step 2.1. Fail on multi-op handles. if (!llvm::hasSingleElement(packOrUnpackOps) || !llvm::hasSingleElement(linalgOps)) { return emitSilenceableError() << "requires target to map to exactly 1 " "packing op and 1 packed op (" << "got " << llvm::range_size(packOrUnpackOps) << " and " << llvm::range_size(linalgOps) << ")"; }

Step 2.2. Fail on wrong type. auto packOp = dyn_castlinalg::PackOp(*packOrUnpackOps.begin()); auto unPackOp = dyn_castlinalg::UnPackOp(*packOrUnpackOps.begin()); if ((!packOp && !unPackOp)) { return emitSilenceableError() << "requires target to map to a " "linalg.pack or linalg.unpack"; } LinalgOp linalgOpTarget = dyn_cast(*linalgOps.begin()); if (!linalgOpTarget) return emitSilenceableError() << "requires a LinalgOp target";

Step 2.3. Fail if we can't get the producer / consumer Linalg op. LinalgOp linalgOp; if (packOp && packOp.getResult().hasOneUse()) linalgOp = dyn_cast(*(packOp.getResult().getUsers().begin())); else if (unPackOp) linalgOp = unPackOp.getSource().getDefiningOp(); if (linalgOp != linalgOpTarget) { auto errorMsg = packOp ? StringLiteral{"not a single use by the LinalgOp target"} : StringLiteral{"not produced by the LinalgOp target"}; return emitSilenceableError() << errorMsg; }

Step 2.4. If we have an UnPackOp, we need to fetch the symmetrical PackOp. if (unPackOp) { assert(!packOp && "packOp must be null on entry when unPackOp is not null"); OpOperand *packUse = linalgOp.getDpsInitOperand( cast(unPackOp.getSource()).getResultNumber()); packOp = packUse->get().getDefiningOplinalg::PackOp(); if (!packOp || !packOp.getResult().hasOneUse()) return emitSilenceableError() << "could not find matching pack op"; }

Step 2.5. Fail if any permutation does not validate. for (auto permType : {OuterOrInnerPerm::Outer, OuterOrInnerPerm::Inner}) { ArrayRef<int64_t> perm = (permType == OuterOrInnerPerm::Outer) ? getOuterPerm() : getInnerPerm(); auto errorMsg = (permType == OuterOrInnerPerm::Outer) ? StringLiteral{"invalid outer_perm"} : StringLiteral{"invalid inner_perm"}; if (!isValidPackingPermutation(packOp, perm, permType) || !isValidPackingPermutation(unPackOp, perm, permType)) { Operation *packOrUnpackOp = unPackOp ? unPackOp.getOperation() : packOp.getOperation(); return emitSilenceableError() << errorMsg << ": " << *packOrUnpackOp; } }

From here on, packOp and linalgOp are always present, unPackOp may or may not be present. assert(packOp && linalgOp && "unexpected null op");

Step 3. Actually transpose the ops. FailureOr res = packTranspose( rewriter, packOp, linalgOp, unPackOp, getOuterPerm(), getInnerPerm()); Preconditions have been checked, it is an error to fail here. assert(succeeded(res) && "unexpected packTranspose failure");

Step 4. Return results. transformResults.set(cast(getPackOp()), {res->transposedPackOp}); transformResults.set(cast(getPackedOp()), {res->transposedLinalgOp}); if (unPackOp) { transformResults.set(cast(getUnPackOp()), {res->transposedUnPackOp}); } else { transformResults.set(cast(getUnPackOp()), {}); }

return DiagnosedSilenceableFailure::success(); }

===------------------------------------------------------------------—===// PadOp ===------------------------------------------------------------------—===//

void transform::PadOp::build(OpBuilder &b, OperationState &result, Value target, ArrayRef<int64_t> paddingDimensions, ArrayRef<int64_t> padToMultipleOf, ArrayRef<int64_t> nofoldFlags, ArrayRef transposePaddings, StringRef copyBackOp, bool usePrescribedTensorShapes) { auto resultType = transform::AnyOpType::get(b.getContext()); return build(/*odsBuilder=

Definition at line 2097 of file LinalgTransformOps.cpp.

Referenced by _mlir_apfloat_compare(), addBodyWithPayloadOp(), mlir::FlatLinearValueConstraints::addBound(), addInitOperandsToLoopNest(), mlir::sparse_tensor::Merger::addLat(), mlir::scf::addLoopRangeConstraints(), addShardOp(), addShardOp(), mlir::xegpu::addWithRightAligned(), mlir::affine::affineForOpBodySkew(), mlir::arm_sme::allocateSMETiles(), allocBuffer(), annotateConflict(), annotateNonWritableTensor(), annotateOpsWithAliasSets(), mlir::OpToFuncCallLowering< SourceOp >::appendOrGetFuncOp(), areAllOpsInTheBlockListInvariant(), mlir::ValueBoundsConstraintSet::areOverlappingSlices(), areSameBitwidthScalarType(), areVarsAligned(), mlir::remark::detail::Remark::Arg::Arg(), mlir::arith::AttrConvertOverflowToLLVM< SourceOp, TargetOp >::AttrConvertOverflowToLLVM(), mlir::spirv::attributeName< ImageArrayedInfo >(), mlir::spirv::attributeName< ImageSamplingInfo >(), augmentMapAndBounds(), mlir::affine::boundCheckLoadOrStoreOp(), broadcastIfNeeded(), mlir::tensor::bubbleUpPadSlice(), buildArithValue(), buildBatchMatmulOp(), buildBatchReduceMatmulOp(), buildDivOp(), buildIdentityRegion(), mlir::memref::buildIndependentOp(), mlir::tensor::buildIndependentOp(), mlir::tensor::buildIndependentOp(), buildLLVMFunctionType(), buildMatmulOp(), mlir::tosa::buildMatMulOpQuantizationAttr(), buildMatMulOpWithQuantInfo(), buildMax(), buildMin(), buildMultiDimReduce(), buildNumReadElements(), buildStructuredOp(), buildSubAndExpOp(), calculateTileOffsetsAndSizes(), mlir::bufferization::castOrReallocMemRefValue(), ValueEquivalenceCache::checkCommutativeEquivalent(), mlir::math::impl::MathExpandOpsPassBase< DerivedT >::classof(), mlir::nvgpu::impl::OptimizeSharedMemoryBase< DerivedT >::classof(), mlir::clone(), mlir::clone(), mlir::arith::impl::ArithExpandOpsPassBase< DerivedT >::clonePass(), mlir::math::impl::MathExpandOpsPassBase< DerivedT >::clonePass(), mlir::cloneWithoutRegions(), mlir::sparse_tensor::SparseTensorLevel::collapseRangeBetween(), composedAffineMultiply(), mlir::ValueBoundsConstraintSet::computeBound(), mlir::ValueBoundsConstraintSet::computeConstantDelta(), mlir::linalg::computeContinuousTileSizes(), mlir::linalg::computeMultiTileSizes(), mlir::affine::computeSliceUnion(), mlir::linalg::computeTileOffsets(), mlir::linalg::computeTileSizes(), mlir::linalg::concat(), mlir::sparse_tensor::constantI1(), mlir::constFoldBinaryOp(), mlir::constFoldBinaryOp(), constructParametricallyTiledIndexSetHyperRect(), constructTiledIndexSetHyperRect(), constructTiledLoopNest(), convertAcoshOp(), convertAsinhOp(), convertAtanhOp(), convertCeilOp(), convertExp2fOp(), convertFmaFOp(), convertFPowIOp(), convertOperationImpl(), convertPowfOp(), convertRoundEvenOp(), convertRoundOp(), convertScalarToComplexDtype(), mlir::convertScalarToDtype(), convertScalarToFpDtype(), convertScalarToIntDtype(), convertSinhOp(), convertTanOp(), mlir::linalg::copyToGPUPrivateMemory(), mlir::linalg::copyToWorkgroupMemory(), mlir::tensor::ExtractSliceFromCollapseHelper::create(), mlir::tensor::ExtractSliceFromCollapseHelper::create(), create4x128BitSuffle(), mlir::arith::createArithExpandOpsPass(), mlir::arith::createArithExpandOpsPass(), createAsyncDispatchFunction(), mlir::createAsyncParallelForPass(), mlir::OpBuilder::createBlock(), mlir::tensor::createCanonicalRankReducingExtractSliceOp(), mlir::tensor::createCanonicalRankReducingInsertSliceOp(), mlir::memref::createCanonicalRankReducingSubViewOp(), createChoosePivot(), createCompareThenSwap(), mlir::impl::ConvertLinalgToAffineLoopsPassBase< DerivedT >::createConvertLinalgToAffineLoopsPass, createCtlzFunc(), mlir::tensor::createDynamicDimValues(), createFloatConst(), createFnDecl(), mlir::linalg::createFoldedDimOp(), createFullTiles(), createInBoundsCond(), createLinalgBodyCalculationForElementwiseOp(), mlir::math::createMathExpandOpsPass(), mlir::math::impl::MathExpandOpsPassBase< DerivedT >::createMathExpandOpsPass, createMemcpy(), createNewDynamicSizes(), mlir::linalg::createOrFoldDimOp(), mlir::vector::createOrFoldDimOp(), mlir::createOutlineShapeComputationPass(), mlir::tensor::createPadHighOp(), createParallelComputeFunction(), createPrivateMemRef(), createSeparationCondition(), createSplitPart(), createTypeCanonicalizedMemRefOperands(), createUnpackHiPd(), createUnpackHiPs(), createUnpackLoPd(), createUnpackLoPs(), mlir::shard::detail::defaultAddShardingAnnotations(), defaultAllocBufferCallBack(), defaultDeallocBufferCallBack(), delinearize(), dependsOn(), mlir::sparse_tensor::SparseIterator::deref(), mlir::sparse_tensor::SparseIterator::derefImpl(), mlir::presburger::FracMatrix::determinant(), mlir::affine::AffineValueMap::difference(), doAsyncDispatch(), mlir::linalg::GenerateLoopNest< LoopTy >::doit(), mlir::linalg::GenerateLoopNest< LoopTy >::doit(), mlir::linalg::GenerateLoopNest< LoopTy >::doit(), mlir::DominanceInfo::dominates(), mlir::DominanceInfo::dominates(), mlir::DominanceInfo::dominates(), doSequentialDispatch(), mlir::presburger::dotProduct(), mlir::Region::dropAllReferences(), mlir::tensor::dropGivenUnitDims(), dropRefIfNoUses(), mlir::linalg::dropUnitDims(), mlir::sparse_tensor::Merger::dumpBits(), emitIsPositiveIndexAssertion(), emitScalarImplementation(), mlir::sparse_tensor::SparseIterationSpace::extractIterator(), fillStructuredOpRegion(), mlir::sparse_tensor::I64BitSet::find_next(), findAncestorIteratorInRegion(), mlir::affine::findInnermostCommonBlockInScope(), mlir::detail::DominanceInfoBase< IsPostDom >::findNearestCommonDominator(), mlir::presburger::IntegerRelation::findSymbolicIntegerLexMax(), mlir::foldAttributesIntoMap(), foldExtractAfterInsert(), foldExtractAfterInsertSlice(), foldExtractFromExtractStrided(), foldExtractFromShapeCast(), foldExtractOpFromExtractChain(), foldExtractStridedOpFromInsertChain(), foldExtractStridedOpFromInsertChain(), foldIdentityOffsetSizeAndStrideOpInterface(), foldInsertAfterExtractSlice(), foldInsertAfterInsertSlice(), foldTransferInBoundsAttribute(), mlir::sparse_tensor::Merger::foreachTensorLoopId(), mlir::sparse_tensor::SparseIterator::forward(), mlir::sparse_tensor::SparseIterator::forwardIf(), mlir::sparse_tensor::SparseIterator::forwardImpl(), mlir::affine::fullyComposeAndComputeConstantDelta(), fuse(), fuse(), fuseIfLegal(), mlir::affine::fuseLoops(), mlir::linalg::fuseProducerOfTensor(), mlir::linalg::fuseProducerOfTensor(), mlir::xegpu::genBinOp(), genBuffers(), generateCopy(), generateLoopNestingName(), mlir::linalg::generateParallelLoopNest(), generateShiftedLoop(), mlir::sparse_tensor::SparseIterator::genForCond(), genIf(), mlir::sparse_tensor::SparseIterator::genInit(), genLoopWithIterator(), mlir::sparse_tensor::SparseIterator::genNotEnd(), mlir::sparse_tensor::SparseIterator::genNotEndImpl(), genWhenInBound(), mlir::sparse_tensor::SparseIterator::genWhileCond(), getAllTidLvlsInLatPoints(), mlir::arith::impl::ArithExpandOpsPassBase< DerivedT >::getArgument(), mlir::impl::SCFForLoopSpecializationBase< DerivedT >::getArgument(), mlir::math::impl::MathExpandOpsPassBase< DerivedT >::getArgument(), mlir::impl::SCFForLoopSpecializationBase< DerivedT >::getArgumentName(), mlir::getBlocksSortedByDominance(), getBoundedTileSize(), getCleanupLoopLowerBound(), mlir::tensor::getCollapsedExtractSliceInfo(), getCommonConstraints(), mlir::linalg::getConvolvedExpr(), mlir::sparse_tensor::SparseIterator::getCursorValTypes(), mlir::spirv::getDefaultResourceLimits(), mlir::impl::ConvertLinalgToLoopsPassBase< DerivedT >::getDependentDialects(), mlir::impl::OutlineShapeComputationPassBase< DerivedT >::getDependentDialects(), mlir::impl::SCFForLoopPeelingBase< DerivedT >::getDependentDialects(), mlir::nvgpu::impl::OptimizeSharedMemoryBase< DerivedT >::getDependentDialects(), mlir::arith::impl::ArithExpandOpsPassBase< DerivedT >::getDescription(), mlir::math::impl::MathExpandOpsPassBase< DerivedT >::getDescription(), mlir::tensor::getExpandedExtractSliceInfo(), getFullRankPaddingSizes(), getGenericOpLoopRange(), getI64ArrayAttr(), getIndicesForAccess(), getInputAndOutputIndices(), getInstAtPosition(), mlir::sparse_tensor::Merger::getLoopDependentLevel(), mlir::sparse_tensor::Merger::getLoopDependentLevelType(), mlir::FlatLinearConstraints::getLowerAndUpperBound(), mlir::sparse_tensor::Merger::getLvl(), mlir::sparse_tensor::Merger::getLvlType(), getMaskFormat(), mlir::shard::getMixedAsValues(), mlir::getMixedValues(), mlir::impl::SCFForLoopPeelingBase< DerivedT >::getName(), mlir::math::impl::MathExpandOpsPassBase< DerivedT >::getName(), mlir::arith::getNeutralElement(), mlir::affine::getNumCommonSurroundingLoops(), mlir::tensor::getOrCreateDestination(), mlir::tensor::getOrCreateDestinations(), getOrCreateOperandsMatchingResultTypes(), mlir::getOrCreateRanges(), mlir::getOrCreateStringConstant(), mlir::getOrDefineFunction(), getOverlappedMembers(), mlir::arith::impl::ArithExpandOpsPassBase< DerivedT >::getPassName(), mlir::math::impl::MathExtendToSupportedTypesBase< DerivedT >::getPassName(), getRangeFromOperandShape(), mlir::getReassociationIndicesAttribute(), getReturnOps(), mlir::bufferization::getReturnOps(), getSemanticsValue(), getSetDifference(), getSharedAddressSpaceAttribute(), mlir::getSimplifiedOfrAndStaticSizePair(), getSlice(), mlir::xegpu::uArch::SubgroupMatrixMultiplyAcc::getSupportedShapes(), mlir::linalg::getUnPackInverseSrcPerm(), mlir::getValueOrCreateCastToIndexLike(), mlir::getValueOrCreateConstantIndexOp(), mlir::getValueOrCreateConstantIndexOp(), mlir::getValueOrCreateConstantIntOp(), getZero(), happensBefore(), happensBefore(), mlir::sparse_tensor::Merger::hasAnySparse(), hasSameBitwidth(), mlir::sparse_tensor::Merger::hasSparseIdxReduction(), mlir::tosa::hasUniqueConstantScatterIndices(), hoistAffineIfOp(), mlir::linalg::hoistRedundantVectorTransfers(), hoistSubsetAtIterArg(), if(), mlir::intrange::inferAdd(), mlir::intrange::inferAnd(), inferContractionDimsImpl(), inferDivSRange(), inferDivURange(), mlir::inferExpandShapeOutputShape(), mlir::intrange::inferMul(), mlir::intrange::inferOr(), mlir::intrange::inferSub(), inlinePayload(), inlineRegionAndEmitStore(), mlir::affine::insertBackwardComputationSlice(), insertCopies(), insertCopyLoops(), mlir::scf::insideMutuallyExclusiveBranches(), invertCollapseShapeIndexing(), invertSliceIndexing(), mlir::isBatchMatvec(), mlir::isBatchVecmat(), isDivZeroOrOverflow(), isFunctionArgument(), mlir::sparse_tensor::Merger::isLvlWithNonTrivialIdxExp(), mlir::sparse_tensor::Merger::isOutTensor(), mlir::isRowMajorBatchMatmul(), TosaProfileCompliance::isSameTypeInfo(), mlir::memref::isSameViewOrTrivialAlias(), mlir::sparse_tensor::Merger::isSparseLvlWithNonTrivialIdxExp(), isTransposeMatrixLoadMap(), mlir::sparse_tensor::Merger::latGT(), mlir::sparse_tensor::SparseIterator::locate(), mlir::sparse_tensor::SparseIterator::locateImpl(), mlir::LLVM::lookupOrCreateAlignedAllocFn(), lookupOrCreateApFloatFn(), mlir::LLVM::lookupOrCreateApFloatPrintFn(), lookupOrCreateBinaryFn(), mlir::LLVM::lookupOrCreateFn(), mlir::LLVM::lookupOrCreateFreeFn(), mlir::LLVM::lookupOrCreateGenericAlignedAllocFn(), mlir::LLVM::lookupOrCreateGenericAllocFn(), mlir::LLVM::lookupOrCreateGenericFreeFn(), mlir::LLVM::lookupOrCreateMallocFn(), mlir::LLVM::lookupOrCreateMemRefCopyFn(), mlir::LLVM::lookupOrCreatePrintBF16Fn(), mlir::LLVM::lookupOrCreatePrintCloseFn(), mlir::LLVM::lookupOrCreatePrintCommaFn(), mlir::LLVM::lookupOrCreatePrintF16Fn(), mlir::LLVM::lookupOrCreatePrintF32Fn(), mlir::LLVM::lookupOrCreatePrintF64Fn(), mlir::LLVM::lookupOrCreatePrintI64Fn(), mlir::LLVM::lookupOrCreatePrintNewlineFn(), mlir::LLVM::lookupOrCreatePrintOpenFn(), mlir::LLVM::lookupOrCreatePrintStringFn(), mlir::LLVM::lookupOrCreatePrintU64Fn(), lookupOrCreateReservedFn(), lookupOrCreateSPIRVFn(), mlir::sparse_tensor::Merger::loop(), mlir::affine::loopUnrollByFactor(), mlir::loopUnrollByFactor(), mlir::affine::loopUnrollJamByFactor(), mlir::loopUnrollJamByFactor(), mlir::sparse_tensor::CodegenEnv::lt(), mlir::vector::makeArithReduction(), makeCanonicalAffineApplies(), mlir::affine::makeComposedAffineApply(), mlir::affine::makeComposedAffineApply(), mlir::affine::makeComposedAffineMin(), mlir::affine::makeComposedFoldedAffineApply(), mlir::affine::makeComposedFoldedAffineApply(), mlir::affine::makeComposedFoldedAffineMax(), mlir::affine::makeComposedFoldedAffineMin(), makeComposedFoldedMinMax(), mlir::affine::makeComposedFoldedMultiResultAffineApply(), makeComposedMinMax(), mlir::linalg::makeComposedPadHighOp(), makeIndependent(), mlir::linalg::makeMemRefCopyOp(), mlir::sparse_tensor::makeNonEmptySubSectIterator(), mlir::presburger::Simplex::makeProduct(), mlir::makeRegionIsolatedFromAbove(), mlir::sparse_tensor::makeSimpleIterator(), mlir::sparse_tensor::makeSparseTensorLevel(), mlir::sparse_tensor::makeSparseTensorLevel(), mlir::linalg::makeTiledLoopRanges(), mlir::sparse_tensor::makeTraverseSubSectIterator(), mlir::gpu::mapParallelOp(), CanonicalizeContractAdd< AddOpType >::matchAndRewrite(), DropUnitDimsFromScfForOp::matchAndRewrite(), IAddCarryFold::matchAndRewrite(), MulExtendedFold< spirv::SMulExtendedOp, true >::matchAndRewrite(), OuterProductOpLowering::matchAndRewrite(), mlir::linalg::RegionMatcher::matchAsScalarBinaryOp(), matchFullMask(), mlir::affine::materializeComputedBound(), mlir::math::impl::MathExpandOpsPassBase< DerivedT >::MathExpandOpsPassBase(), mayAlias(), mergeAndAlignVars(), mfmaOpToIntrinsic(), mfmaOpToScaledIntrinsic(), mlirBlockCreate(), mlirBlockDetach(), mlirBlockGetNumPredecessors(), mlirBlockGetPredecessor(), mlirLinalgFillBuiltinNamedOpRegion(), mlir::x86vector::avx2::intrin::mm256BlendPs(), mlir::x86vector::avx2::inline_asm::mm256BlendPsAsm(), mlir::x86vector::avx2::intrin::mm256Permute2f128Ps(), mlir::x86vector::avx2::intrin::mm256ShufflePs(), mlir::x86vector::avx2::intrin::mm256UnpackHiPs(), mlir::x86vector::avx2::intrin::mm256UnpackLoPs(), mlir::presburger::multiplyPolynomials(), mlir::scf::naivelyFuseParallelOps(), notifyBlockInsertions(), offsetFromMinCrd(), mlir::linalg::offsetIndices(), mlir::linalg::offsetIndices(), mlir::bufferization::OneShotAnalysisState::OneShotAnalysisState(), mlir::detail::DominanceInfoBase< IsPostDom >::operator=(), mlir::math::impl::MathExpandOpsPassBase< DerivedT >::operator=(), mlir::outlineIfOp(), padThroughLoopIterArg(), mlir::parallelLoopUnrollByFactors(), mlir::arith::parseFloatType(), mlir::shard::partitionFuncOp(), mlir::RewritePattern::Pattern(), mlir::sparse_tensor::SparseTensorLevel::peekCrdAt(), mlir::sparse_tensor::SparseTensorLevel::peekRangeAt(), peelForLoop(), mlir::bufferization::populateDynamicDimSizes(), mlir::math::populateExtendToSupportedTypesTypeConverter(), mlir::vector::populateVectorToVectorCanonicalizationPatterns(), mlir::PostDominanceInfo::postDominates(), mlir::PostDominanceInfo::postDominates(), printArgs(), printTransferAttrs(), promoteSingleIterReductionLoop(), mlir::linalg::promoteSubviewAsNewBuffer(), mlir::linalg::promoteSubViews(), promoteSubViews(), promoteSubViews(), mlir::DominanceInfo::properlyDominates(), mlir::DominanceInfo::properlyDominates(), mlir::DominanceInfo::properlyDominates(), mlir::PostDominanceInfo::properlyPostDominates(), mlir::PostDominanceInfo::properlyPostDominates(), reduce(), reduceIfNeeded(), mlir::nvgpu::registerOptimizeSharedMemory(), mlir::nvgpu::registerOptimizeSharedMemoryPass(), mlir::reifyDimOfResult(), mlir::affine::reifyIndexValueBound(), mlir::arith::reifyIndexValueBound(), reifyOrComputeDynamicSizes(), mlir::reifyResultShapes(), ReifyCollapseShapeOp::reifyResultShapes(), mlir::affine::reifyShapedValueDimBound(), mlir::arith::reifyShapedValueDimBound(), mlir::reifyShapeOfResult(), mlir::affine::reifyValueBound(), mlir::arith::reifyValueBound(), rewriteOneForallCommonImpl(), mlir::detail::sameOffsetsSizesAndStrides(), scaleAndAddForAssert(), mlir::impl::SCFForLoopPeelingBase< DerivedT >::SCFForLoopPeelingBase(), mlir::impl::SCFForLoopSpecializationBase< DerivedT >::SCFForLoopSpecializationBase(), mlir::impl::SCFForLoopSpecializationBase< DerivedT >::SCFForLoopSpecializationBase(), selectShardingOption(), mlir::sparse_tensor::ir_detail::DimSpec::setElideExpr(), mlir::sparse_tensor::ir_detail::LvlSpec::setElideVar(), setInsertionPointAfter(), setInterTileBoundsParametric(), setIntraTileBoundsParametric(), mlir::linalg::PadTilingInterfaceOptions::setPadToMultipleOf(), mlir::linalg::LinalgTilingOptions::setTileSizes(), signedCeilNonnegInputs(), mlir::sparse_tensor::Merger::simplifyCond(), sortMapIndices(), mlir::sparse_tensor::SparseIterationSpace::SparseIterationSpace(), mlir::sparse_tensor::SparseIterationSpace::SparseIterationSpace(), mlir::sparse_tensor::SparseIterationSpace::SparseIterationSpace(), specializeForLoopForUnrolling(), specializeParallelLoopForUnrolling(), mlir::linalg::splitReduction(), mlir::linalg::splitReductionByScaling(), stableTopologicalSort(), stripmineSink(), stripmineSink(), mlir::sparse_tensor::Merger::tensor(), mlir::linalg::tileLinalgOp(), tileLinalgOpImpl(), tileLinalgOpImpl(), mlir::linalg::tileReductionUsingForall(), mlir::linalg::transformIndexOps(), transposeToShuffle16x16(), transposeToShuffle1D(), truncToI32(), tryGetBlocksInSameRegion(), unpackOperandVector(), mlir::linalg::updateBoundsForCyclicDistribution(), mlir::sparse_tensor::SparseIterator::upperBound(), mlir::ValueBoundsConstraintSet::Variable::Variable(), mlir::ValueBoundsConstraintSet::Variable::Variable(), mlir::SimpleAffineExprFlattener::visitMulExpr(), wrapInExecuteRegion(), mlir::math::impl::MathExpandOpsPassBase< DerivedT >::~MathExpandOpsPassBase(), and mlir::impl::SCFForLoopSpecializationBase< DerivedT >::~SCFForLoopSpecializationBase().

result

Definition at line 2098 of file LinalgTransformOps.cpp.

Referenced by _mlir_apfloat_convert(), _mlir_apfloat_convert_from_int(), _mlir_apfloat_convert_to_int(), mlir::call_interface_impl::addArgAndResultAttrs(), mlir::call_interface_impl::addArgAndResultAttrs(), addBlockScaleProperties(), addBodyWithPayloadOp(), mlir::tracing::TagBreakpointManager::addBreakpoint(), mlir::affine::FlatAffineValueConstraints::addDomainFromSliceMaps(), mlir::bufferization::OneShotAnalysisState::addExtension(), mlir::transform::TransformState::addExtension(), mlir::presburger::Simplex::addInequality(), addInferredMultiplicandTypes(), mlir::detail::AttrTypeReplacerBase< Concrete >::addReplacement(), addShardOp(), mlir::AsmParser::addTypesToList(), mlir::AsmParser::addTypeToList(), mlir::AsmParserState::addUses(), mlir::AliasAnalysis::alias(), mlir::LocalAliasAnalysis::alias(), mlir::LocalAliasAnalysis::aliasImpl(), mlir::transform::TransformEachOpTrait< OpTy >::apply(), mlir::applyPermutationMap(), applySequenceBlock(), mlir::presburger::LinearTransform::applyTo(), mlir::transform::TransformState::applyTransform(), mlir::linalg::areElementwiseOpsFusable(), mlir::ROCDL::assembleIsa(), mlir::linalg::asShapeWithAnyValueAsDynamic(), mlir::python::PyMlirContext::attachDiagnosticHandler(), mlir::barePtrFuncArgTypeConverter(), binaryFolder(), bottomUpFromTerminatorsHeuristic(), bubbleDownCastsPassthroughOpImpl(), mlir::tensor::bubbleUpPadSlice(), mlir::bufferization::func_ext::CallOpInterface::bufferize(), mlir::linalg::bufferizeToAllocation(), mlir::linalg::bufferizeToAllocation(), mlir::affine::AffineDmaStartOp::build(), mlir::affine::AffineDmaWaitOp::build(), mlir::affine::NestedMatch::build(), mlir::arith::ConstantFloatOp::build(), mlir::arith::ConstantIndexOp::build(), mlir::arith::ConstantIntOp::build(), mlir::arith::ConstantIntOp::build(), mlir::arith::ConstantIntOp::build(), mlir::linalg::BatchMatmulTransposeAOp::build(), mlir::linalg::BatchMatmulTransposeAOp::build(), mlir::linalg::BatchMatmulTransposeAOp::build(), mlir::linalg::BatchMatmulTransposeBOp::build(), mlir::linalg::BatchMatmulTransposeBOp::build(), mlir::linalg::BatchMatmulTransposeBOp::build(), mlir::linalg::MatmulTransposeAOp::build(), mlir::linalg::MatmulTransposeAOp::build(), mlir::linalg::MatmulTransposeAOp::build(), mlir::linalg::MatmulTransposeBOp::build(), mlir::linalg::MatmulTransposeBOp::build(), mlir::linalg::MatmulTransposeBOp::build(), buildAttributeAPInt(), buildAvgPool2dOpWithQuantInfo(), buildConvOpWithQuantInfo(), buildDefaultRegistryFn(), mlir::tblgen::buildErrorStreamingString(), buildMatMulOpWithQuantInfo(), buildNegateOpWithQuantInfo(), buildPadOpWithQuantInfo(), buildSequentialConstant(), buildTransConvOpWithQuantInfo(), buildVariableOp(), cachedLookup(), calculateCycleEdges(), canonicalizeRegisterConstraints(), checkAssumptionForFusingConsumer(), checkAssumptionForLoop(), checkImplementationStatus(), mlir::affine::checkMemrefAccessDependence(), checkTransformationPreconditions(), cloneAndFuseFirstUse(), mlir::xegpu::impl::XeGPUBlockingBase< DerivedT >::clonePass(), mlir::coalescePerfectlyNestedSCFForLoops(), collectUnderlyingAddressValues(), mlir::spirv::combine(), mlir::presburger::PresburgerRelation::compose(), composeLegalityCallbacks(), computeBackwardSlice(), computeElementwiseMulImpl(), mlir::OperationEquivalence::computeHash(), mlir::presburger::IntegerRelation::computeReprWithOnlyDivLocals(), mlir::presburger::PresburgerRelation::computeReprWithOnlyDivLocals(), mlir::computeShapeRatio(), mlir::presburger::computeSingleVarRepr(), mlir::affine::computeSliceUnion(), computeStrides(), mlir::presburger::SymbolicLexSimplex::computeSymbolicIntegerLexMin(), mlir::presburger::PresburgerRelation::computeVolume(), concatArrayAttr(), mlir::detail::AffineBinaryOpExprStorage::construct(), mlir::detail::AffineConstantExprStorage::construct(), mlir::detail::AffineDimExprStorage::construct(), mlir::detail::FileLineColRangeAttrStorage::construct(), mlir::detail::TupleTypeStorage::construct(), mlir::query::matcher::RegistryManager::constructMatcher(), mlir::LLVMTypeConverter::convertCallingConventionType(), convertConstantOpMmaSync(), mlir::lsp::MLIRServer::convertFromBytecode(), mlir::convertFuncOpToLLVMFuncOp(), convertFuncOpTypes(), mlir::LLVMTypeConverter::convertFunctionSignature(), mlir::LLVMTypeConverter::convertFunctionSignature(), convertHostOrTargetOperation(), convertIntrinsicResult(), convertMixedValuesToInt(), convertMLIRAttributeToLLVM(), convertOmpTargetData(), convertOperationImpl(), convertRoundEvenOp(), convertRoundOp(), mlir::convertScalarToDtype(), convertTargetOpsInNest(), copyAPIntToArrayForBEmachine(), copyArrayRefInto(), copyArrayToAPIntForBEmachine(), mlir::StorageUniquer::StorageAllocator::copyInto(), mlir::StorageUniquer::StorageAllocator::copyInto(), mlir::affine::AffineDmaStartOp::create(), mlir::affine::AffineDmaWaitOp::create(), mlir::arith::ConstantFloatOp::create(), mlir::arith::ConstantIndexOp::create(), mlir::arith::ConstantIntOp::create(), mlir::arith::ConstantIntOp::create(), mlir::arith::ConstantIntOp::create(), mlir::OpBuilder::create(), mlir::Operation::create(), mlir::python::PyOperation::create(), mlir::arith::createArithExpandOpsPass(), mlir::createArithToAMDGPUConversionPass(), mlir::createArithToAMDGPUConversionPass(), mlir::impl::ArithToAMDGPUConversionPassBase< DerivedT >::createArithToAMDGPUConversionPass, mlir::createConvertAsyncToLLVMPass(), mlir::emitc::createExpression(), createInlinedCompareImplementation(), createLinalgBodyCalculationForElementwiseOp(), createNonLdMatrixLoads(), mlir::shard::createShardingPropagation(), createSingleEntryBlock(), createSplitPart(), mlir::xegpu::createVectorWithShapeFromValues(), mlir::irdl::createVerifier(), mlir::LivenessBlockInfo::currentlyLiveValues(), mlir::linalg::deduplicateOperandsAndRemoveDeadResults(), deduplicateOutputOperands(), mlir::shard::detail::defaultAddShardingAnnotations(), mlir::shard::detail::defaultGetShardingAnnotations(), dependsOnCarriedVals(), deriveStaticUpperBound(), dispatchParse(), mlir::Inliner::doInlining(), mlir::xegpu::doSCFStructuralTypeConversionWithTensorType(), mlir::Operation::dropAllUses(), mlir::linalg::dropUnitDims(), mlir::ValueBoundsConstraintSet::dump(), emit(), mlir::transform::expandTargetSpecification(), expandValue(), mlir::smt::exportSMTLIB(), extractBeneficiaryOps(), extractConvFilterSlices(), extractConvInputSlices(), extractConvResultSlices(), extractOperandTypes(), mlir::xegpu::extractVectorsWithShapeFromValue(), filterByValRefArgAttrs(), filterFuncAttributes(), mlir::LocationAttr::findInstanceOf(), mlir::LocationAttr::findInstanceOfOrUnknown(), mlir::presburger::IntegerRelation::findIntegerSample(), mlir::transform::TrackingListener::findReplacementOp(), mlir::presburger::IntegerRelation::findSymbolicIntegerLexMin(), findSymbolicIntegerLexOpt(), mlir::query::matcher::MatchFinder::flattenMatchedOps(), flattenValues(), flattenValues(), mlir::xegpu::flattenValues(), foldBinaryOpUnchecked(), foldCastOp(), mlir::op_definition_impl::foldTrait(), mlir::scf::forallToParallelLoop(), forEachScalarValue(), mlir::transform::detail::forwardTerminatorOperands(), forwardToUsers(), llvm::lsp::fromJSON(), mlir::lsp::fromJSON(), mlir::lsp::fromJSON(), mlir::linalg::fuseElementwiseOps(), mlir::sparse_tensor::FuncCallOrInlineGenerator< SubClass >::genCallOrInline(), mlir::OpState::genericParseProperties(), mlir::AffineMap::get(), mlir::DynamicOpDefinition::get(), mlir::LLVM::detail::LoopAnnotationTranslation::getAccessGroup(), mlir::linalg::getAffineResultPositions(), mlir::bufferization::OpWithUnstructuredControlFlowBufferizableOpInterfaceExternalModel< ConcreteModel, ConcreteOp >::getAliasingBranchOpOperands(), mlir::bufferization::BranchOpBufferizableOpInterfaceExternalModel< ConcreteModel, ConcreteOp >::getAliasingValues(), mlir::bufferization::func_ext::CallOpInterface::getAliasingValues(), mlir::linalg::getArityGroupAndKind(), mlir::presburger::MultiAffineFunction::getAsRelation(), mlir::impl::getAttrFromSortedRange(), mlir::MLIRContext::getAvailableDialects(), mlir::getBackwardSlice(), mlir::sparse_tensor::getBlockSize(), mlir::quant::UniformQuantizedSubChannelType::getBlockSizeInfo(), getBroadcastingMap(), mlir::bufferization::detail::getCallerOpOperands(), mlir::presburger::IntegerRelation::getConstantBoundOnDimSize64(), mlir::AffineMap::getConstantResults(), getConstraintPredicates(), mlir::tblgen::AttrOrTypeParameter::getDefaultValue(), mlir::Value::getDefiningOp(), mlir::affine::getDependenceComponents(), mlir::bufferization::impl::OwnershipBasedBufferDeallocationPassBase< DerivedT >::getDependentDialects(), mlir::vector::impl::LowerVectorMaskPassBase< DerivedT >::getDependentDialects(), mlir::xegpu::impl::XeGPUBlockingBase< DerivedT >::getDependentDialects(), mlir::memref::impl::NormalizeMemRefsPassBase< DerivedT >::getDescription(), mlir::xegpu::getDistributeLayoutAttr(), mlir::presburger::PresburgerRelation::getDomainSet(), mlir::presburger::getDynamicAPIntVec(), mlir::query::matcher::VariantMatcher::VariadicOpPayload::getDynMatcher(), mlir::presburger::IntegerRelation::getEmpty(), mlir::Token::getFloatingPointValue(), getForwardSliceImpl(), mlir::sparse_tensor::getFunc(), mlir::bufferization::func_ext::getFuncAnalysisState(), mlir::Token::getHashIdentifierNumber(), getIndicesForAccess(), mlir::getInnermostParallelLoops(), mlir::presburger::getInt64Vec(), mlir::Token::getIntTypeBitwidth(), mlir::tosa::ValueKnowledge::getKnowledgeFromType(), mlir::dataflow::AbstractSparseBackwardDataFlowAnalysis::getLatticeElements(), mlir::presburger::MultiAffineFunction::getLexSet(), mlir::getLinearizedDimensions(), mlir::LLVM::detail::getLLVMConstant(), mlir::MLIRContext::getLoadedDialects(), mlir::tblgen::Pattern::getLocation(), getMangledSortHelperFunc(), getMaxLoopDepth(), getMemoryFootprintBytes(), mlir::memref::getMixedSizes(), mlir::tensor::getMixedSizes(), mlir::AliasAnalysis::getModRef(), mlir::LocalAliasAnalysis::getModRef(), mlir::getMultiAffineFunctionFromMap(), mlir::AffineMap::getMultiDimMapWithTargets(), mlir::arith::impl::ArithExpandOpsPassBase< DerivedT >::getName(), mlir::impl::ArithToAMDGPUConversionPassBase< DerivedT >::getName(), mlir::impl::getNamedAttrFromSortedRange(), mlir::detail::OpResultImpl::getNextResultAtOffset(), mlir::tensor::getOrCreateDestinations(), getOrCreateFuncAnalysisState(), mlir::detail::OpResultImpl::getOwner(), mlir::linalg::getPackedOuterShapeWithoutTransposition(), mlir::arith::impl::ArithExpandOpsPassBase< DerivedT >::getPassName(), mlir::memref::impl::NormalizeMemRefsPassBase< DerivedT >::getPassName(), getPipelineStages(), getProducingInsertSliceLikeOp(), getProducingParallelInsertSlice(), mlir::presburger::PresburgerRelation::getRangeSet(), mlir::pdl_to_pdl_interp::PredicateBuilder::getResult(), mlir::tblgen::Operator::getResultDecorators(), mlir::shard::getResultShardings(), mlir::bufferization::getReturnOps(), getReturnTypes(), getSameBlockUsers(), getSetDifference(), getSharding(), mlir::shard::getSharding(), mlir::getSlice(), getSliceContract(), mlir::Token::getStringValue(), mlir::xegpu::uArch::SubgroupMatrixMultiplyAcc::getSupportedShapes(), getSymbolUsesImpl(), mlir::xegpu::getTemporaryLayoutName(), getTransferFoldableInnerUnitDims(), mlir::Token::getUInt64IntegerValue(), getUnderlyingObjectSet(), mlir::presburger::PresburgerRelation::getUniverse(), mlir::presburger::PresburgerSet::getUniverse(), mlir::Token::getUnsignedIntegerValue(), mlir::SideEffects::EffectInstance< Effect >::getValue(), getValueTypes(), handleError(), handleError(), handleMultidimensionalVectors(), mlir::InlinerInterface::handleResult(), handleResultImpl(), mlir::affine::hasDependence(), mlir::arm_sme::hasTileResult(), mlir::intrange::inferAdd(), mlir::intrange::inferCeilDivS(), mlir::intrange::inferCeilDivU(), mlir::intrange::inferDivS(), inferDivSRange(), mlir::intrange::inferDivU(), mlir::intrange::inferFloorDivS(), mlir::intrange::inferMul(), mlir::python::PyInferShapedTypeOpInterface::inferReturnTypeComponents(), mlir::python::PyInferTypeOpInterface::inferReturnTypes(), mlir::intrange::inferShapedDimOpInterface(), mlir::intrange::inferShl(), mlir::intrange::inferSub(), initTargetDefaultAttrs(), insertCasts(), mlir::bufferization::insertTensorCopies(), mlir::insideMutuallyExclusiveRegions(), mlir::presburger::IntegerRelation::intersect(), mlir::presburger::PresburgerRelation::intersect(), mlir::detail::AnalysisModel< AnalysisT >::invalidate(), mlir::sparse_tensor::inverseBlockSparsity(), mlir::sparse_tensor::isBlockSparsity(), isCompatibleImpl(), isContiguousLoadIdx(), mlir::Tester::isInteresting(), isLoopInvariantIdx(), mlir::affine::isOpwiseShiftValid(), isResultValueDead(), mlir::affine::isTilingValid(), mlir::Operation::isUsedOutsideOfBlock(), mlir::dataflow::PredecessorState::join(), mlir::tosa::ValueKnowledge::join(), linalgBroadcastAndMaybeExt(), linalgIntBroadcastExtSIAdd(), loadModule(), loadOperation(), mlir::IRMapping::lookup(), mlir::LLVM::ModuleTranslation::lookupOMPLoop(), mlir::CyclicReplacerCache< InT, OutT >::lookupOrInit(), mlir::CyclicReplacerCache< void *, const void * >::lookupOrInit(), mlir::detail::ConversionPatternRewriterImpl::lookupOrNull(), mlir::presburger::Simplex::makeProduct(), makeReductionGen(), makeRefDataPtrGen(), mlir::LLVM::ModuleImport::mapBlock(), mlir::LLVM::ModuleTranslation::mapBlock(), mlir::LLVM::ModuleTranslation::mapBlockAddress(), mlir::LLVM::ModuleTranslation::mapBranch(), mlir::LLVM::ModuleTranslation::mapCall(), mlir::LLVM::ModuleTranslation::mapFunction(), mlir::LLVM::ModuleTranslation::mapUnresolvedBlockAddress(), mlir::detail::constant_op_binder< AttrT >::match(), mlir::query::matcher::PredicateBackwardSliceMatcher< BaseMatcher, Filter >::match(), matchAndReplaceDepthwiseConv(), CmpFOpToAPFloatConversion::matchAndRewrite(), Convert1DExtractStridedSliceIntoExtractInsertChain::matchAndRewrite(), GPUAllReduceConversion::matchAndRewrite(), GPUSubgroupReduceConversion::matchAndRewrite(), mlir::ComposeCollapseOfExpandOp< CollapseOpTy, ExpandOpTy, CastOpTy, DimOpTy, TensorTy >::matchAndRewrite(), mlir::PatternApplicator::matchAndRewrite(), OuterProductOpLowering::matchAndRewrite(), TransposeIsReshape::matchAndRewrite(), ContractOpToElementwise::matchAndRewriteMaskableOp(), materializeBinaryNanCheckIfRequired(), mlir::shard::maybeInsertTargetShardingAnnotation(), maybePickPermanentLayout(), mayHaveEffect(), mlir::tosa::ValueKnowledge::meet(), mlir::presburger::IntegerRelation::mergeAndCompose(), mgpuModuleLoadJIT(), minMaxBy(), mlirAffineMapCompressUnusedSymbols(), mlirAsmStateCreateForValue(), mlirLinalgInferContractionDimensions(), mlirLinalgInferContractionDimensionsFromMaps(), mlirLinalgInferConvolutionDimensions(), mlirMergeSymbolsIntoFromClone(), mlirStringRefCreate(), moveAndReset(), mlir::moveOperationDependencies(), mlir::moveValueDefinitions(), mustReachAtInnermost(), mlir::AnalysisManager::nest(), mlir::affine::noDependence(), nvvmInferResultRanges(), GpuAsyncRegionPass::SingleTokenUseCallback::operator()(), mlir::CachedCyclicReplacer< InT, OutT >::operator()(), mlir::operator<<(), mlir::operator<<(), mlir::OptionalParseResult::OptionalParseResult(), mlir::OptionalParseResult::OptionalParseResult(), mlir::linalg::pack(), packFunctionArguments(), packValInto64Bits(), padTileShapeToSize(), mlir::affine::AffineDmaStartOp::parse(), mlir::affine::AffineDmaWaitOp::parse(), mlir::detail::DenseArrayAttrImpl< T >::parse(), mlir::FieldParser< std::optional< AttributeT >, std::enable_if_t< std::is_base_of< Attribute, AttributeT >::value, std::optional< AttributeT > > >::parse(), mlir::FieldParser< std::optional< IntT >, std::enable_if_t< std::is_integral< IntT >::value, std::optional< IntT > > >::parse(), mlir::OpState::parse(), parseAffineMinMaxOp(), mlir::OpAsmParser::parseArgument(), mlir::OpAsmParser::parseArgumentList(), parseArithmeticExtendedBinaryOp(), mlir::AsmParser::parseArrowTypeList(), mlir::detail::AsmParserImpl< BaseT >::parseArrowTypeList(), mlir::OpAsmParser::parseAssignmentList(), mlir::AsmParser::parseAttribute(), mlir::AsmParser::parseAttribute(), mlir::AsmParser::parseAttribute(), mlir::AsmParser::parseAttribute(), mlir::AsmParser::parseAttribute(), mlir::detail::AsmParserImpl< BaseT >::parseAttribute(), mlir::detail::Parser::parseAttribute(), parseAttributions(), parseBound(), parseCallTypeAndResolveOperands(), parseCmpOp(), mlir::AsmParser::parseColonType(), mlir::AsmParser::parseColonType(), mlir::detail::AsmParserImpl< BaseT >::parseColonType(), mlir::AsmParser::parseColonTypeList(), mlir::detail::AsmParserImpl< BaseT >::parseColonTypeList(), parseCommonGlobalAndAlias(), parseCommonStructuredOpParts(), mlir::AsmParser::parseCustomAttributeWithFallback(), mlir::AsmParser::parseCustomAttributeWithFallback(), mlir::AsmParser::parseCustomAttributeWithFallback(), mlir::detail::AsmParserImpl< BaseT >::parseCustomAttributeWithFallback(), mlir::AsmParser::parseCustomTypeWithFallback(), mlir::AsmParser::parseCustomTypeWithFallback(), mlir::detail::AsmParserImpl< BaseT >::parseCustomTypeWithFallback(), mlir::AsmParser::parseDecimalInteger(), mlir::detail::Parser::parseDecOrHexAttr(), parseDstStyleOp(), parseElementAttrHexValues(), mlir::AsmParser::parseFloat(), mlir::AsmParser::parseFloat(), mlir::detail::AsmParserImpl< BaseT >::parseFloat(), mlir::detail::AsmParserImpl< BaseT >::parseFloat(), mlir::detail::Parser::parseFloatFromIntegerLiteral(), mlir::detail::Parser::parseFloatFromLiteral(), mlir::function_interface_impl::parseFunctionOp(), mlir::OpAsmParser::parseGenericOperationAfterOpName(), mlir::AsmParser::parseInteger(), mlir::AsmParser::parseKeywordOrString(), mlir::AsmParser::parseKeywordType(), mlir::query::matcher::internal::Parser::parseMatcherExpression(), parseNamedStructuredOp(), parseNamedStructuredOpRegion(), parseOneResultSameOperandTypeOp(), mlir::OpAsmParser::parseOperand(), mlir::OpAsmParser::parseOperandList(), mlir::OpAsmParser::parseOperandList(), mlir::OpAsmParser::parseOptionalArgument(), mlir::AsmParser::parseOptionalArrowTypeList(), mlir::detail::AsmParserImpl< BaseT >::parseOptionalArrowTypeList(), mlir::AsmParser::parseOptionalAttrDict(), mlir::detail::AsmParserImpl< BaseT >::parseOptionalAttrDict(), mlir::AsmParser::parseOptionalAttrDictWithKeyword(), mlir::detail::AsmParserImpl< BaseT >::parseOptionalAttrDictWithKeyword(), mlir::AsmParser::parseOptionalAttribute(), mlir::AsmParser::parseOptionalAttribute(), mlir::AsmParser::parseOptionalAttribute(), mlir::AsmParser::parseOptionalAttribute(), mlir::AsmParser::parseOptionalAttribute(), mlir::AsmParser::parseOptionalAttribute(), mlir::detail::AsmParserImpl< BaseT >::parseOptionalAttribute(), mlir::detail::AsmParserImpl< BaseT >::parseOptionalAttribute(), mlir::detail::AsmParserImpl< BaseT >::parseOptionalAttribute(), mlir::detail::AsmParserImpl< BaseT >::parseOptionalAttribute(), mlir::detail::Parser::parseOptionalAttribute(), mlir::detail::Parser::parseOptionalAttribute(), mlir::AsmParser::parseOptionalColonTypeList(), mlir::detail::AsmParserImpl< BaseT >::parseOptionalColonTypeList(), mlir::AsmParser::parseOptionalDecimalInteger(), mlir::AsmParser::parseOptionalDecimalInteger(), mlir::detail::AsmParserImpl< BaseT >::parseOptionalDecimalInteger(), mlir::detail::Parser::parseOptionalDecimalInteger(), mlir::AsmParser::parseOptionalInteger(), mlir::AsmParser::parseOptionalInteger(), mlir::detail::AsmParserImpl< BaseT >::parseOptionalInteger(), mlir::detail::Parser::parseOptionalInteger(), mlir::AsmParser::parseOptionalKeywordOrString(), mlir::detail::AsmParserImpl< BaseT >::parseOptionalKeywordOrString(), mlir::detail::Parser::parseOptionalKeywordOrString(), mlir::OpAsmParser::parseOptionalLocationSpecifier(), mlir::OpAsmParser::parseOptionalOperand(), parseOptionalStaticSlice(), mlir::AsmParser::parseOptionalSymbolName(), mlir::AsmParser::parseOptionalSymbolName(), mlir::detail::AsmParserImpl< BaseT >::parseOptionalSymbolName(), mlir::AsmParser::parseOptionalType(), mlir::detail::AsmParserImpl< BaseT >::parseOptionalType(), mlir::Op< ConcreteType, Traits >::parseProperties(), mlir::AsmParser::parseResourceHandle(), mlir::detail::Parser::parseResourceHandle(), parseSameOperandTypeVariadicToBoolOp(), parseStorageType(), mlir::detail::Parser::parseStridedLayoutAttr(), mlir::AsmParser::parseSymbolName(), mlir::AsmParser::parseSymbolName(), parseTargetAllocMemOp(), mlir::OpAsmParser::parseTrailingOperandList(), mlir::AsmParser::parseType(), mlir::AsmParser::parseType(), mlir::detail::AsmParserImpl< BaseT >::parseType(), mlir::AsmParser::parseTypeList(), mlir::linalg::partitionLinalgOpWithShardedReduction(), mlir::shard::partitionOperation(), performReplaceValue(), mlir::populateAMDGPUTypeAndAttributeConversions(), populateDialectLLVMSubmodule(), populateDialectSMTSubmodule(), populateTransformInterpreterSubmodule(), mlir::presburger::Matrix< T >::postMultiplyWithColumn(), mlir::presburger::Matrix< T >::preMultiplyWithRow(), mlir::pdl_to_pdl_interp::OptimalBranching::preOrderTraversal(), mlir::Liveness::print(), mlir::pdll::ods::Context::print(), mlir::Value::printAsOperand(), printConstantOp(), mlir::OpAsmPrinter::printFunctionalType(), printFunctionBody(), printOperation(), produceSliceErrorMsg(), produceSubViewErrorMsg(), pruneNonTransposedDims(), pyListToVector(), mlir::quant::UniformQuantizedValueConverter::quantizeFloatToInt(), mlir::presburger::IntegerRelation::rangeProduct(), mlir::DialectBytecodeReader::readAttribute(), mlir::DialectBytecodeReader::readAttribute(), readBits(), mlir::DialectBytecodeReader::readBlob(), mlir::DialectBytecodeReader::readBool(), mlir::DialectBytecodeReader::readList(), mlir::DialectBytecodeReader::readOptionalAttribute(), mlir::DialectBytecodeReader::readResourceHandle(), mlir::readResourceHandle(), mlir::DialectBytecodeReader::readSignedVarInt(), mlir::DialectBytecodeReader::readSignedVarInts(), mlir::DialectBytecodeReader::readString(), mlir::DialectBytecodeReader::readType(), mlir::DialectBytecodeReader::readType(), mlir::DialectBytecodeReader::readVarInt(), mlir::DialectBytecodeReader::readVarIntWithFlag(), mlir::xegpu::recoverTemporaryLayouts(), mlir::xegpu::recoverTemporaryLayoutsDeprecated(), reduceMatchAndRewriteHelper(), mlir::reifyResultShapes(), mlir::xegpu::removeLayoutAttrs(), replaceConstantUsesOf(), replaceElementImpl(), mlir::detail::AttrTypeReplacerBase< Concrete >::replaceElementsIn(), replaceForAllWithNewSignature(), mlir::detail::ConversionPatternRewriterImpl::replaceOp(), replaceSubElements(), reshapeLoad(), reshapeStore(), mlir::Liveness::resolveLiveness(), mlir::OpAsmParser::resolveOperand(), mlir::OpAsmParser::resolveOperands(), mlir::OpAsmParser::resolveOperands(), mlir::OpAsmParser::resolveOperands(), resolveValues(), mlir::ResultRange::ResultRange(), mlir::linalg::rewriteInDestinationPassingStyle(), mlir::linalg::rewriteInIm2Col(), mlir::linalg::rewriteInIm2Col(), mlir::linalg::rewriteInIm2Col(), rewriteOneForallCommonImpl(), mlir::PassManager::run(), mlir::dataflow::RunLivenessAnalysis::RunLivenessAnalysis(), scalarizeVectorOpHelper(), mlir::MutableAffineMap::setResult(), shouldBeInlined(), mlir::LLVM::DIExpressionRewriter::simplify(), mlir::presburger::PresburgerRelation::simplify(), mlir::tblgen::FmtObjectBase::sstr(), mlir::StateStack::stackWalk(), mlir::dataflow::staticallyNonNegative(), staticallyOutOfBounds(), mlir::tblgen::FmtObjectBase::str(), mlir::LLVMTypeConverter::structFuncArgTypeConverter, mlir::structFuncArgTypeConverter(), mlir::presburger::PresburgerRelation::subtract(), subtractExprs(), tiebreakLex(), tileAndFuseConsumerOfSlicesImpl(), tileLinalgOpImpl(), mlir::linalg::tileReductionUsingForall(), transformToStructuredCFBranches(), mlir::LLVM::detail::DebugImporter::translate(), translateDataLayout(), mlir::LLVM::detail::DebugImporter::translateLoc(), tryApply(), tryToParseIntListImpl(), mlir::TypeRange::TypeRange(), mlir::presburger::PresburgerRelation::unionSet(), unpackOperandVector(), unpackSingleIndexResultPayloadOperations(), unpackSingleIndexResultPayloadOperations(), mlir::vector::unrollVectorOp(), unwrap(), mlir::ReductionNode::update(), updateCalls(), updateControlFlowOps(), updateOp(), mlir::ResultRange::use_empty(), mlir::presburger::MultiAffineFunction::valueAt(), vectorizeAsLinalgGeneric(), vectorizeOneOp(), mlir::irdl::ConstraintVerifier::verify(), verifyAllToAllOperandAndResultShape(), mlir::detail::verifyDestinationStyleOpInterface(), verifyGatherOperandAndResultShape(), mlir::verifyInBoundsSlice(), mlir::detail::verifyInferredResultTypes(), mlir::transform::detail::verifyParamProducerTransformOpTrait(), verifyQuantifierRegions(), mlir::OpTrait::impl::verifySameOperandsAndResultElementType(), verifyScatterOrSliceOperandAndResultShape(), mlir::detail::verifySymbolTable(), mlir::transform::detail::verifyTransformOpInterface(), visit(), mlir::dataflow::LivenessAnalysis::visitBranchOperand(), mlir::dataflow::AbstractSparseBackwardDataFlowAnalysis::visitCallableOperation(), visitOp(), mlir::dataflow::IntegerRangeAnalysis::visitOperation(), mlir::dataflow::StridedMetadataRangeAnalysis::visitOperation(), mlir::Block::walk(), mlir::detail::walk(), mlir::detail::walk(), mlir::detail::walk(), mlir::Region::walk(), walkSymbolTable(), walkSymbolTable(), widenOp(), wrapExternalFunction(), xegpu::getTemporaryLayout< mlir::OpResult >(), xegpu::removeLayoutAttr< mlir::OpResult >(), xegpu::setTemporaryLayout< mlir::OpResult >(), and mlir::SimpleAffineExprFlattener::~SimpleAffineExprFlattener().

target

Definition at line 2100 of file LinalgTransformOps.cpp.

Referenced by mlir::transform::gpu::alterGpuLaunch(), applyConversion(), applyTilingToAll(), mlir::transform::detail::applyTransformToEach(), mlir::ROCDL::assembleIsa(), buildPredicateList(), mlir::bufferization::castOrReallocMemRefValue(), mlir::impl::ConvertAsyncToLLVMPassBase< DerivedT >::classof(), mlir::impl::LinalgDetensorizePassBase< DerivedT >::classof(), mlir::math::impl::MathExtendToSupportedTypesBase< DerivedT >::classof(), mlir::arith::impl::ArithIntRangeOptsBase< DerivedT >::clonePass(), mlir::impl::ConvertAsyncToLLVMPassBase< DerivedT >::clonePass(), mlir::impl::LinalgDetensorizePassBase< DerivedT >::clonePass(), mlir::impl::LowerSparseOpsToForeachBase< DerivedT >::clonePass(), mlir::impl::PreSparsificationRewriteBase< DerivedT >::clonePass(), mlir::impl::SparseBufferRewriteBase< DerivedT >::clonePass(), mlir::tosa::impl::TosaNarrowF64ToF32PassBase< TosaNarrowF64ToF32 >::clonePass(), mlir::configureAMXLegalizeForExportTarget(), mlir::configureArmSMEToLLVMConversionLegality(), mlir::configureArmSVELegalizeForExportTarget(), mlir::configureGpuToNVVMConversionLegality(), mlir::configureGpuToROCDLConversionLegality(), mlir::configureOpenMPToLLVMConversionLegality(), mlir::configureParallelLoopToGPULegality(), mlir::configureX86VectorLegalizeForExportTarget(), contract(), mlir::convertAffineLoopNestToGPULaunch(), mlir::memref::createExpandOpsPass(), mlir::quant::createNormalizeQuantTypes(), DEFINE_C_API_STRUCT(), definiteFailureHelper(), doit(), mlir::xegpu::doSCFStructuralTypeConversionWithTensorType(), mlir::transform::expandTargetSpecification(), findPayloadRoot(), mlir::transform::gpu::findTopLevelForallOp(), mlir::fuseIndependentSiblingForallLoops(), mlir::fuseIndependentSiblingForLoops(), mlir::SPIRVConversionTarget::get(), mlir::impl::ConvertArmSMEToLLVMBase< DerivedT >::getArgument(), mlir::spirv::impl::SPIRVCompositeTypeLayoutPassBase< DerivedT >::getArgument(), mlir::impl::ConvertArmSMEToLLVMBase< DerivedT >::getArgumentName(), mlir::impl::LowerSparseOpsToForeachBase< DerivedT >::getArgumentName(), mlir::impl::PreSparsificationRewriteBase< DerivedT >::getArgumentName(), mlir::impl::SparseBufferRewriteBase< DerivedT >::getArgumentName(), mlir::impl::ConvertAsyncToLLVMPassBase< DerivedT >::getDependentDialects(), mlir::impl::LowerSparseOpsToForeachBase< DerivedT >::getDependentDialects(), mlir::impl::PreSparsificationRewriteBase< DerivedT >::getDependentDialects(), mlir::memref::impl::ExpandReallocPassBase< DerivedT >::getDependentDialects(), mlir::quant::impl::NormalizeQuantTypesBase< DerivedT >::getDependentDialects(), mlir::impl::LowerSparseOpsToForeachBase< DerivedT >::getDescription(), mlir::impl::SparseBufferRewriteBase< DerivedT >::getDescription(), mlir::spirv::impl::SPIRVCompositeTypeLayoutPassBase< DerivedT >::getDescription(), mlir::spirv::getMemorySpaceToStorageClassTarget(), mlir::impl::SparseBufferRewriteBase< DerivedT >::getName(), mlir::spirv::impl::SPIRVCompositeTypeLayoutPassBase< DerivedT >::getName(), mlir::LLVM::ModuleToObject::getOrCreateTargetMachine(), mlir::impl::SparseBufferRewriteBase< DerivedT >::getPassName(), mlir::LLVM::detail::getTargetMachine(), isForallWithIdenticalConfiguration(), isForWithIdenticalConfiguration(), isOpSibling(), mlir::OperationConverter::legalizeOperations(), mlir::transform::gpu::mapNestedForallToThreadsImpl(), mlir::transform::detail::mergeSymbolsInto(), MLIR_DECLARE_CAPI_DIALECT_REGISTRATION(), mlirGPUObjectAttrGet(), mlirGPUObjectAttrGetWithKernels(), mlirMergeSymbolsIntoFromClone(), mlirRegionTakeBody(), NB_MODULE(), mlir::OperationConverter::OperationConverter(), mlir::impl::SparseAssemblerBase< DerivedT >::operator=(), mlir::spirv::parseSwitchOpCases(), mlir::amdgpu::populateAmdgpuEmulateAtomicsPatterns(), mlir::populateAsyncFuncToAsyncRuntimeConversionPatterns(), mlir::populateAsyncStructuralTypeConversionsAndLegality(), mlir::cf::populateCFStructuralTypeConversionsAndLegality(), mlir::cf::populateCFStructuralTypeConversionTarget(), mlir::populateConversionTargetFromOperation(), mlir::populateConversionTargetFromOperation(), mlir::ConvertToEmitCPatternInterface::populateConvertToEmitCConversionPatterns(), mlir::ConvertToLLVMPatternInterface::populateConvertToLLVMConversionPatterns(), mlir::arith::populateEmulateUnsupportedFloatsLegality(), mlir::math::populateExtendToSupportedTypesConversionTarget(), mlir::math::populateExtendToSupportedTypesTypeConverter(), mlir::populateOpConvertToLLVMConversionPatterns(), mlir::scf::populateSCFStructuralTypeConversionsAndLegality(), mlir::scf::populateSCFStructuralTypeConversionTarget(), populateTransformInterpreterSubmodule(), mlir::populateXeVMToLLVMConversionPatterns(), mlir::tensor::preservesStaticInformation(), mlir::spirv::Deserializer::processBranch(), mlir::affine::promoteSingleIterationLoops(), remapArgumentEffects(), remapEffects(), mlir::shard::reshard(), mlir::shard::reshard(), ConvertMathToROCDLPass::runOnOperation(), setOptionalCommandlineArguments(), sortDependentLoops(), stripmineSink(), stripmineSink(), mlir::affine::tile(), mlir::tile(), mlir::transform::tileToForallOpImpl(), unpackOptionalValues(), updateSymbolAndAllUses(), mlir::wasmssa::detail::verifyLabelLevelInterface(), mlir::spirv::Deserializer::wireUpBlockArgument(), mlir::impl::LowerSparseOpsToForeachBase< DerivedT >::~LowerSparseOpsToForeachBase(), and mlir::impl::SparseAssemblerBase< DerivedT >::~SparseAssemblerBase().

TypeRange

Definition at line 2099 of file LinalgTransformOps.cpp.

Referenced by buildStructuredOp(), mlir::detail::ConversionPatternRewriterImpl::buildUnresolvedMaterialization(), createAsyncDispatchFunction(), createHeapSortFunc(), mlir::LLVM::createPrintStrCall(), createQuickSortFunc(), doSequentialDispatch(), mlir::query::extractFunction(), genEndInsert(), mlir::linalg::generalizeNamedOp(), genExpand(), mlir::sparse_tensor::genTuple(), mlir::spirv::StructType::getElementTypes(), getParallelComputeFunctionType(), getReplacementValues(), legalizeUnresolvedMaterialization(), mlir::LLVMTypeConverter::LLVMTypeConverter(), mlir::detail::ConversionPatternRewriterImpl::lookupOrDefault(), mlir::detail::ConversionPatternRewriterImpl::lookupOrNull(), IntToFpConversion< OpTy >::matchAndRewrite(), mlir::GPUReturnOpLowering::matchAndRewrite(), mlir::linalg::LinalgOpToLibraryCallRewrite::matchAndRewrite(), matchAndRewriteSortOp(), outlineKernelFuncImpl(), packRankedMemRefDesc(), packUnrankedMemRefDesc(), mlir::printSemiFunctionType(), mlir::detail::ConversionPatternRewriterImpl::replaceOp(), mlir::sparse_tensor::SparsificationAndBufferizationPass::runDenseBufferization(), mlir::SparseIterationTypeConverter::SparseIterationTypeConverter(), mlir::linalg::splitReduction(), and mlir::detail::verifyTypesAlongControlFlowEdges().

ValueRange

Definition at line 2103 of file LinalgTransformOps.cpp.

Referenced by addNodeToMDG(), addResumeFunction(), mlir::affine::affineParallelize(), mlir::transform::TransformEachOpTrait< OpTy >::apply(), buildAffineLoopFromConstants(), buildAffineLoopNestImpl(), mlir::bufferization::buildDeallocationLibraryFunction(), mlir::scf::buildLoopNest(), checkAndNestUnderRewriteOp(), mlir::computeLinearIndex(), createAsyncDispatchFunction(), createParallelComputeFunction(), createQuickSortFunc(), doSequentialDispatch(), mlir::query::extractFunction(), foldExtractFromBroadcast(), fuseWithReshapeByExpansion(), genCoIterateBranchNest(), mlir::sparse_tensor::genCoIteration(), mlir::linalg::generalizeNamedOp(), genLoopWithIterator(), mlir::sparse_tensor::SparseIterator::getCursor(), mlir::impl::OutlineShapeComputationPassBase< DerivedT >::getDependentDialects(), getReplacementValues(), mlir::ValueShapeRange::getValues(), linalgBroadcastAndMaybeExt(), linalgIntBroadcastExtSIAdd(), mlir::detail::ConversionPatternRewriterImpl::lookupOrDefault(), mlir::detail::ConversionPatternRewriterImpl::lookupOrNull(), mlir::loopUnrollByFactor(), ExecuteRegionForwardingEliminator::matchAndRewrite(), movePaddingToFillOrGenericOp(), outlineKernelFuncImpl(), mlir::parallelLoopUnrollByFactors(), mlir::detail::ConversionPatternRewriterImpl::remapValues(), mlir::detail::ConversionPatternRewriterImpl::replaceOp(), mlir::linalg::rewriteAsPaddedOp(), mlir::linalg::rewriteAsPaddedOp(), mlir::linalg::rewriteInDestinationPassingStyle(), mlir::linalg::rewriteInDestinationPassingStyle(), mlir::linalg::splitReduction(), and mlir::linalg::splitReductionByScaling().