555 lines
22 KiB
C++
555 lines
22 KiB
C++
//===- SparseTensorCodegen.cpp - Sparse tensor primitives conversion ------===//
|
|
//
|
|
// 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
|
|
//
|
|
//===----------------------------------------------------------------------===//
|
|
//
|
|
// A pass that converts sparse tensor types and primitives to actual compiler
|
|
// visible buffers and actual compiler IR that implements these primitives on
|
|
// the selected sparse tensor storage schemes. This pass provides an alternative
|
|
// to the SparseTensorConversion pass, eliminating the dependence on a runtime
|
|
// support library, and providing much more opportunities for subsequent
|
|
// compiler optimization of the generated code.
|
|
//
|
|
//===----------------------------------------------------------------------===//
|
|
|
|
#include "CodegenUtils.h"
|
|
|
|
#include "mlir/Dialect/Bufferization/IR/Bufferization.h"
|
|
#include "mlir/Dialect/Func/IR/FuncOps.h"
|
|
#include "mlir/Dialect/MemRef/IR/MemRef.h"
|
|
#include "mlir/Dialect/SparseTensor/IR/SparseTensor.h"
|
|
#include "mlir/Dialect/SparseTensor/Transforms/Passes.h"
|
|
#include "mlir/Dialect/Tensor/IR/Tensor.h"
|
|
#include "mlir/Transforms/DialectConversion.h"
|
|
|
|
using namespace mlir;
|
|
using namespace mlir::sparse_tensor;
|
|
|
|
namespace {
|
|
|
|
//===----------------------------------------------------------------------===//
|
|
// Helper methods.
|
|
//===----------------------------------------------------------------------===//
|
|
|
|
/// Reorders stored dimension to original dimension.
|
|
static unsigned toOrig(const SparseTensorEncodingAttr &enc, unsigned i) {
|
|
auto order = enc.getDimOrdering();
|
|
if (order) {
|
|
assert(order.isPermutation());
|
|
return order.getDimPosition(i);
|
|
}
|
|
return i;
|
|
}
|
|
|
|
/// Reorders original dimension to stored dimension.
|
|
static unsigned toStored(const SparseTensorEncodingAttr &enc, unsigned i) {
|
|
auto order = enc.getDimOrdering();
|
|
if (order) {
|
|
assert(order.isPermutation());
|
|
return order.getPermutedPosition(i);
|
|
}
|
|
return i;
|
|
}
|
|
|
|
/// Flatten a list of operands that may contain sparse tensors.
|
|
static void flattenOperands(ValueRange operands,
|
|
SmallVectorImpl<Value> &flattened) {
|
|
// In case of
|
|
// sparse_tensor, c, sparse_tensor
|
|
// ==>
|
|
// memref ..., c, memref ...
|
|
for (auto operand : operands) {
|
|
if (auto cast =
|
|
dyn_cast<UnrealizedConversionCastOp>(operand.getDefiningOp());
|
|
cast && getSparseTensorEncoding(cast->getResultTypes()[0]))
|
|
// An unrealized_conversion_cast will be inserted by type converter to
|
|
// inter-mix the gap between 1:N conversion between sparse tensors and
|
|
// fields. In this case, take the operands in the cast and replace the
|
|
// sparse tensor output with the flattened type array.
|
|
flattened.append(cast.getOperands().begin(), cast.getOperands().end());
|
|
else
|
|
flattened.push_back(operand);
|
|
}
|
|
}
|
|
|
|
/// Maps a sparse tensor type to the appropriate compounded buffers.
|
|
static Optional<LogicalResult>
|
|
convertSparseTensorType(Type type, SmallVectorImpl<Type> &fields) {
|
|
auto enc = getSparseTensorEncoding(type);
|
|
if (!enc)
|
|
return llvm::None;
|
|
// Construct the basic types.
|
|
auto context = type.getContext();
|
|
unsigned idxWidth = enc.getIndexBitWidth();
|
|
unsigned ptrWidth = enc.getPointerBitWidth();
|
|
RankedTensorType rType = type.cast<RankedTensorType>();
|
|
Type indexType = IndexType::get(context);
|
|
Type idxType = idxWidth ? IntegerType::get(context, idxWidth) : indexType;
|
|
Type ptrType = ptrWidth ? IntegerType::get(context, ptrWidth) : indexType;
|
|
Type eltType = rType.getElementType();
|
|
//
|
|
// Sparse tensor storage for rank-dimensional tensor is organized as a
|
|
// single compound type with the following fields:
|
|
//
|
|
// struct {
|
|
// memref<rank x index> dimSizes ; size in each dimension
|
|
// ; per-dimension d:
|
|
// ; if dense:
|
|
// <nothing>
|
|
// ; if compresed:
|
|
// memref<? x ptr> pointers-d ; pointers for sparse dim d
|
|
// memref<? x idx> indices-d ; indices for sparse dim d
|
|
// ; if singleton:
|
|
// memref<? x idx> indices-d ; indices for singleton dim d
|
|
// memref<? x eltType> values ; values
|
|
// };
|
|
//
|
|
unsigned rank = rType.getShape().size();
|
|
// The dimSizes array.
|
|
fields.push_back(MemRefType::get({rank}, indexType));
|
|
// Per-dimension storage.
|
|
for (unsigned r = 0; r < rank; r++) {
|
|
// Dimension level types apply in order to the reordered dimension.
|
|
// As a result, the compound type can be constructed directly in the given
|
|
// order. Clients of this type know what field is what from the sparse
|
|
// tensor type.
|
|
switch (enc.getDimLevelType()[r]) {
|
|
case SparseTensorEncodingAttr::DimLevelType::Dense:
|
|
break; // no fields
|
|
case SparseTensorEncodingAttr::DimLevelType::Compressed:
|
|
case SparseTensorEncodingAttr::DimLevelType::CompressedNu:
|
|
case SparseTensorEncodingAttr::DimLevelType::CompressedNo:
|
|
case SparseTensorEncodingAttr::DimLevelType::CompressedNuNo:
|
|
fields.push_back(MemRefType::get({ShapedType::kDynamicSize}, ptrType));
|
|
fields.push_back(MemRefType::get({ShapedType::kDynamicSize}, idxType));
|
|
break;
|
|
case SparseTensorEncodingAttr::DimLevelType::Singleton:
|
|
case SparseTensorEncodingAttr::DimLevelType::SingletonNu:
|
|
case SparseTensorEncodingAttr::DimLevelType::SingletonNo:
|
|
case SparseTensorEncodingAttr::DimLevelType::SingletonNuNo:
|
|
fields.push_back(MemRefType::get({ShapedType::kDynamicSize}, idxType));
|
|
break;
|
|
}
|
|
}
|
|
// The values array.
|
|
fields.push_back(MemRefType::get({ShapedType::kDynamicSize}, eltType));
|
|
return success();
|
|
}
|
|
|
|
// Returns field index of sparse tensor type for pointers/indices, when set.
|
|
static unsigned getFieldIndex(Type type, unsigned ptrDim, unsigned idxDim) {
|
|
auto enc = getSparseTensorEncoding(type);
|
|
assert(enc);
|
|
RankedTensorType rType = type.cast<RankedTensorType>();
|
|
unsigned field = 1; // start at DimSizes;
|
|
unsigned ptr = 0;
|
|
unsigned idx = 0;
|
|
for (unsigned r = 0, rank = rType.getShape().size(); r < rank; r++) {
|
|
switch (enc.getDimLevelType()[r]) {
|
|
case SparseTensorEncodingAttr::DimLevelType::Dense:
|
|
break; // no fields
|
|
case SparseTensorEncodingAttr::DimLevelType::Compressed:
|
|
case SparseTensorEncodingAttr::DimLevelType::CompressedNu:
|
|
case SparseTensorEncodingAttr::DimLevelType::CompressedNo:
|
|
case SparseTensorEncodingAttr::DimLevelType::CompressedNuNo:
|
|
if (ptr++ == ptrDim)
|
|
return field;
|
|
field++;
|
|
if (idx++ == idxDim)
|
|
return field;
|
|
field++;
|
|
break;
|
|
case SparseTensorEncodingAttr::DimLevelType::Singleton:
|
|
case SparseTensorEncodingAttr::DimLevelType::SingletonNu:
|
|
case SparseTensorEncodingAttr::DimLevelType::SingletonNo:
|
|
case SparseTensorEncodingAttr::DimLevelType::SingletonNuNo:
|
|
if (idx++ == idxDim)
|
|
return field;
|
|
field++;
|
|
break;
|
|
}
|
|
}
|
|
llvm_unreachable("failed to find ptr/idx field index");
|
|
return -1;
|
|
}
|
|
|
|
/// Create allocation operation.
|
|
static Value createAllocation(OpBuilder &builder, Location loc, Type type,
|
|
Value sz) {
|
|
auto memType = MemRefType::get({ShapedType::kDynamicSize}, type);
|
|
return builder.create<memref::AllocOp>(loc, memType, sz);
|
|
}
|
|
|
|
/// Creates allocation for each field in sparse tensor type.
|
|
///
|
|
/// TODO: for efficiency, we will need heuristis to make educated guesses
|
|
/// on the required final sizes; also, we will need an improved
|
|
/// memory allocation scheme with capacity and reallocation
|
|
///
|
|
static void createAllocFields(OpBuilder &builder, Location loc, Type type,
|
|
ValueRange dynSizes,
|
|
SmallVectorImpl<Value> &fields) {
|
|
auto enc = getSparseTensorEncoding(type);
|
|
assert(enc);
|
|
// Construct the basic types.
|
|
unsigned idxWidth = enc.getIndexBitWidth();
|
|
unsigned ptrWidth = enc.getPointerBitWidth();
|
|
RankedTensorType rType = type.cast<RankedTensorType>();
|
|
Type indexType = builder.getIndexType();
|
|
Type idxType = idxWidth ? builder.getIntegerType(idxWidth) : indexType;
|
|
Type ptrType = ptrWidth ? builder.getIntegerType(ptrWidth) : indexType;
|
|
Type eltType = rType.getElementType();
|
|
auto shape = rType.getShape();
|
|
unsigned rank = shape.size();
|
|
bool allDense = true;
|
|
Value one = constantIndex(builder, loc, 1);
|
|
Value linear = one;
|
|
Value heuristic = one; // FIX, see TODO above
|
|
// Build original sizes.
|
|
SmallVector<Value, 8> sizes;
|
|
for (unsigned r = 0, o = 0; r < rank; r++) {
|
|
if (ShapedType::isDynamic(shape[r]))
|
|
sizes.push_back(dynSizes[o++]);
|
|
else
|
|
sizes.push_back(constantIndex(builder, loc, shape[r]));
|
|
}
|
|
// The dimSizes array.
|
|
Value dimSizes =
|
|
builder.create<memref::AllocOp>(loc, MemRefType::get({rank}, indexType));
|
|
fields.push_back(dimSizes);
|
|
// Per-dimension storage.
|
|
for (unsigned r = 0; r < rank; r++) {
|
|
// Get the original dimension (ro) for the current stored dimension.
|
|
unsigned ro = toOrig(enc, r);
|
|
builder.create<memref::StoreOp>(loc, sizes[ro], dimSizes,
|
|
constantIndex(builder, loc, r));
|
|
linear = builder.create<arith::MulIOp>(loc, linear, sizes[ro]);
|
|
// Allocate fiels.
|
|
switch (enc.getDimLevelType()[r]) {
|
|
case SparseTensorEncodingAttr::DimLevelType::Dense:
|
|
break; // no fields
|
|
case SparseTensorEncodingAttr::DimLevelType::Compressed:
|
|
case SparseTensorEncodingAttr::DimLevelType::CompressedNu:
|
|
case SparseTensorEncodingAttr::DimLevelType::CompressedNo:
|
|
case SparseTensorEncodingAttr::DimLevelType::CompressedNuNo:
|
|
fields.push_back(createAllocation(builder, loc, ptrType, heuristic));
|
|
fields.push_back(createAllocation(builder, loc, idxType, heuristic));
|
|
allDense = false;
|
|
break;
|
|
case SparseTensorEncodingAttr::DimLevelType::Singleton:
|
|
case SparseTensorEncodingAttr::DimLevelType::SingletonNu:
|
|
case SparseTensorEncodingAttr::DimLevelType::SingletonNo:
|
|
case SparseTensorEncodingAttr::DimLevelType::SingletonNuNo:
|
|
fields.push_back(createAllocation(builder, loc, idxType, heuristic));
|
|
allDense = false;
|
|
break;
|
|
}
|
|
}
|
|
// The values array. For all-dense, the full length is required.
|
|
// In all other case, we resort to the heuristical initial value.
|
|
Value valuesSz = allDense ? linear : heuristic;
|
|
fields.push_back(createAllocation(builder, loc, eltType, valuesSz));
|
|
}
|
|
|
|
/// Returns integral constant, if defined.
|
|
static Optional<int64_t> getConstantInt(Value val) {
|
|
if (auto constantOp = val.getDefiningOp<arith::ConstantOp>())
|
|
return constantOp.getValue().cast<IntegerAttr>().getInt();
|
|
return {};
|
|
}
|
|
|
|
//===----------------------------------------------------------------------===//
|
|
// Codegen rules.
|
|
//===----------------------------------------------------------------------===//
|
|
|
|
/// Sparse tensor storage conversion rule for returns.
|
|
class SparseReturnConverter : public OpConversionPattern<func::ReturnOp> {
|
|
public:
|
|
using OpConversionPattern::OpConversionPattern;
|
|
LogicalResult
|
|
matchAndRewrite(func::ReturnOp op, OpAdaptor adaptor,
|
|
ConversionPatternRewriter &rewriter) const override {
|
|
SmallVector<Value, 8> flattened;
|
|
flattenOperands(adaptor.getOperands(), flattened);
|
|
// Create a return with the flattened value extracted from sparse tensors.
|
|
rewriter.replaceOpWithNewOp<func::ReturnOp>(op, flattened);
|
|
return success();
|
|
}
|
|
};
|
|
|
|
/// Sparse tensor storage conversion rule for calls.
|
|
class SparseCallConverter : public OpConversionPattern<func::CallOp> {
|
|
public:
|
|
// The default CallOp converter can not handle 1:N type conversion.
|
|
using OpConversionPattern::OpConversionPattern;
|
|
LogicalResult
|
|
matchAndRewrite(func::CallOp op, OpAdaptor adaptor,
|
|
ConversionPatternRewriter &rewriter) const override {
|
|
Location loc = op.getLoc();
|
|
// In case of:
|
|
// sparse_tensor, f, sparse_tensor = call @foo(...)
|
|
// ==>
|
|
// memref..., f, memref = call @foo(...) replace with
|
|
// cast(memref...)->sparse_tensor, f, cast(memref...)->sparse_tensor
|
|
SmallVector<Type, 8> finalRetTy;
|
|
if (failed(typeConverter->convertTypes(op.getResultTypes(), finalRetTy)))
|
|
return failure();
|
|
|
|
// (1) Genereates new call with flattened return value.
|
|
SmallVector<Value, 8> flattened;
|
|
flattenOperands(adaptor.getOperands(), flattened);
|
|
auto newCall = rewriter.create<func::CallOp>(loc, op.getCallee(),
|
|
finalRetTy, flattened);
|
|
// (2) Create cast operation for sparse tensor returns.
|
|
SmallVector<Value, 4> castedRet;
|
|
// Tracks the offset of current return value (of the orignal call)
|
|
// relative to the new call (after sparse tensor flattening);
|
|
unsigned retOffset = 0;
|
|
// Temporal buffer to hold the flattened list of type for
|
|
// a sparse tensor.
|
|
SmallVector<Type, 8> sparseFlat;
|
|
for (auto ret : op.getResults()) {
|
|
assert(retOffset < newCall.getNumResults());
|
|
auto retType = ret.getType();
|
|
if (failed(typeConverter->convertType(retType, sparseFlat)))
|
|
// This should never happen.
|
|
llvm_unreachable("Failed to convert type in sparse tensor codegen");
|
|
|
|
// Converted types can not be empty when the type conversion succeed.
|
|
assert(!sparseFlat.empty());
|
|
if (sparseFlat.size() > 1) {
|
|
auto flatSize = sparseFlat.size();
|
|
ValueRange sparseElem(iterator_range<ResultRange::iterator>(
|
|
newCall.result_begin() + retOffset,
|
|
newCall.result_begin() + retOffset + flatSize));
|
|
auto castOp = rewriter.create<UnrealizedConversionCastOp>(
|
|
loc, TypeRange({retType}), sparseElem);
|
|
castedRet.push_back(castOp.getResult(0));
|
|
retOffset += flatSize;
|
|
} else {
|
|
// If this is an 1:1 conversion, no need for casting.
|
|
castedRet.push_back(newCall.getResult(retOffset));
|
|
retOffset++;
|
|
}
|
|
sparseFlat.clear();
|
|
}
|
|
|
|
assert(castedRet.size() == op.getNumResults());
|
|
rewriter.replaceOp(op, castedRet);
|
|
return success();
|
|
}
|
|
};
|
|
|
|
/// Sparse codegen rule for dimension accesses.
|
|
class SparseDimOpConverter : public OpConversionPattern<tensor::DimOp> {
|
|
public:
|
|
using OpConversionPattern::OpConversionPattern;
|
|
LogicalResult
|
|
matchAndRewrite(tensor::DimOp op, OpAdaptor adaptor,
|
|
ConversionPatternRewriter &rewriter) const override {
|
|
// Only rewrite annotated DimOp with constant index.
|
|
auto enc = getSparseTensorEncoding(op.getSource().getType());
|
|
if (!enc)
|
|
return failure();
|
|
Optional<int64_t> index = getConstantInt(adaptor.getIndex());
|
|
if (!index)
|
|
return failure();
|
|
// Access into static dimension can query original type directly.
|
|
// Note that this is typically already done by DimOp's folding.
|
|
Location loc = op->getLoc();
|
|
auto shape = op.getSource().getType().cast<RankedTensorType>().getShape();
|
|
if (!ShapedType::isDynamic(shape[*index])) {
|
|
rewriter.replaceOp(op, constantIndex(rewriter, loc, shape[*index]));
|
|
return success();
|
|
}
|
|
// Any other query can consult the dimSizes array at field 0 using,
|
|
// accounting for the reordering applied to the sparse storage.
|
|
auto tuple = llvm::cast<UnrealizedConversionCastOp>(
|
|
adaptor.getSource().getDefiningOp());
|
|
rewriter.replaceOpWithNewOp<memref::LoadOp>(
|
|
op, tuple.getInputs().front(),
|
|
constantIndex(rewriter, loc, toStored(enc, *index)));
|
|
return success();
|
|
}
|
|
};
|
|
|
|
/// Sparse codegen rule for trivial tensor casts.
|
|
class SparseCastConverter : public OpConversionPattern<tensor::CastOp> {
|
|
public:
|
|
using OpConversionPattern::OpConversionPattern;
|
|
LogicalResult
|
|
matchAndRewrite(tensor::CastOp op, OpAdaptor adaptor,
|
|
ConversionPatternRewriter &rewriter) const override {
|
|
// Only rewrite identically annotated source/dest.
|
|
auto encDst = getSparseTensorEncoding(op.getType());
|
|
auto encSrc = getSparseTensorEncoding(op.getSource().getType());
|
|
if (!encDst || encDst != encSrc)
|
|
return failure();
|
|
rewriter.replaceOp(op, adaptor.getOperands());
|
|
return success();
|
|
}
|
|
};
|
|
|
|
/// Sparse codgen rule for the alloc operator.
|
|
class SparseTensorAllocConverter
|
|
: public OpConversionPattern<bufferization::AllocTensorOp> {
|
|
public:
|
|
using OpConversionPattern::OpConversionPattern;
|
|
LogicalResult
|
|
matchAndRewrite(bufferization::AllocTensorOp op, OpAdaptor adaptor,
|
|
ConversionPatternRewriter &rewriter) const override {
|
|
RankedTensorType resType = op.getType();
|
|
auto enc = getSparseTensorEncoding(resType);
|
|
if (!enc)
|
|
return failure();
|
|
if (op.getCopy())
|
|
return rewriter.notifyMatchFailure(op, "tensor copy not implemented");
|
|
|
|
// Construct allocation for each field.
|
|
Location loc = op.getLoc();
|
|
SmallVector<Value, 8> fields;
|
|
createAllocFields(rewriter, loc, resType, adaptor.getOperands(), fields);
|
|
rewriter.replaceOpWithNewOp<UnrealizedConversionCastOp>(
|
|
op, TypeRange{resType}, fields);
|
|
return success();
|
|
}
|
|
};
|
|
|
|
/// Sparse codegen rule for the dealloc operator.
|
|
class SparseTensorDeallocConverter
|
|
: public OpConversionPattern<bufferization::DeallocTensorOp> {
|
|
public:
|
|
using OpConversionPattern::OpConversionPattern;
|
|
LogicalResult
|
|
matchAndRewrite(bufferization::DeallocTensorOp op, OpAdaptor adaptor,
|
|
ConversionPatternRewriter &rewriter) const override {
|
|
auto enc = getSparseTensorEncoding(op.getTensor().getType());
|
|
if (!enc)
|
|
return failure();
|
|
|
|
// Replace the sparse tensor deallocation with field deallocations.
|
|
Location loc = op.getLoc();
|
|
auto tuple = llvm::cast<UnrealizedConversionCastOp>(
|
|
adaptor.getTensor().getDefiningOp());
|
|
for (auto input : tuple.getInputs())
|
|
// Deallocate every buffer used to store the sparse tensor handler.
|
|
rewriter.create<memref::DeallocOp>(loc, input);
|
|
|
|
rewriter.eraseOp(op);
|
|
return success();
|
|
}
|
|
};
|
|
|
|
/// Sparse codegen rule for tensor rematerialization.
|
|
class SparseTensorLoadConverter : public OpConversionPattern<LoadOp> {
|
|
public:
|
|
using OpConversionPattern::OpConversionPattern;
|
|
LogicalResult
|
|
matchAndRewrite(LoadOp op, OpAdaptor adaptor,
|
|
ConversionPatternRewriter &rewriter) const override {
|
|
if (op.getHasInserts()) {
|
|
// Finalize any pending insertions.
|
|
// TODO: implement
|
|
}
|
|
rewriter.replaceOp(op, adaptor.getOperands());
|
|
return success();
|
|
}
|
|
};
|
|
|
|
/// Base class for getter-like operations, e.g., to_indices, to_pointers.
|
|
template <typename SourceOp, typename Base>
|
|
class SparseGetterOpConverter : public OpConversionPattern<SourceOp> {
|
|
public:
|
|
using OpAdaptor = typename SourceOp::Adaptor;
|
|
using OpConversionPattern<SourceOp>::OpConversionPattern;
|
|
LogicalResult
|
|
matchAndRewrite(SourceOp op, OpAdaptor adaptor,
|
|
ConversionPatternRewriter &rewriter) const override {
|
|
// Replace the requested pointer access with corresponding field.
|
|
// The cast_op is inserted by type converter to intermix 1:N type
|
|
// conversion.
|
|
auto tuple = llvm::cast<UnrealizedConversionCastOp>(
|
|
adaptor.getTensor().getDefiningOp());
|
|
auto idx = Base::getIndexForOp(tuple, op);
|
|
if (!idx)
|
|
// Failed to get the index.
|
|
return failure();
|
|
auto fields = tuple.getInputs();
|
|
assert(*idx < fields.size());
|
|
rewriter.replaceOp(op, fields[*idx]);
|
|
return success();
|
|
}
|
|
};
|
|
|
|
/// Sparse codegen rule for pointer accesses.
|
|
class SparseToPointersConverter
|
|
: public SparseGetterOpConverter<ToPointersOp, SparseToPointersConverter> {
|
|
public:
|
|
using SparseGetterOpConverter::SparseGetterOpConverter;
|
|
// Callback for SparseGetterOpConverter.
|
|
static Optional<unsigned> getIndexForOp(UnrealizedConversionCastOp /*tuple*/,
|
|
ToPointersOp op) {
|
|
Optional<int64_t> dim = getConstantInt(op.getDim());
|
|
if (!dim)
|
|
return llvm::None; // variable dim
|
|
return getFieldIndex(op.getTensor().getType(), /*ptrDim=*/*dim, -1);
|
|
}
|
|
};
|
|
|
|
/// Sparse codegen rule for index accesses.
|
|
class SparseToIndicesConverter
|
|
: public SparseGetterOpConverter<ToIndicesOp, SparseToIndicesConverter> {
|
|
public:
|
|
using SparseGetterOpConverter::SparseGetterOpConverter;
|
|
// Callback for SparseGetterOpConverter.
|
|
static Optional<unsigned> getIndexForOp(UnrealizedConversionCastOp /*tuple*/,
|
|
ToIndicesOp op) {
|
|
Optional<int64_t> dim = getConstantInt(op.getDim());
|
|
if (!dim)
|
|
return llvm::None; // variable dim
|
|
return getFieldIndex(op.getTensor().getType(), -1, /*idxDim=*/*dim);
|
|
}
|
|
};
|
|
|
|
/// Sparse codegen rule for value accesses.
|
|
class SparseToValuesConverter
|
|
: public SparseGetterOpConverter<ToValuesOp, SparseToValuesConverter> {
|
|
public:
|
|
using SparseGetterOpConverter::SparseGetterOpConverter;
|
|
// Callback for SparseGetterOpConverter.
|
|
static Optional<unsigned> getIndexForOp(UnrealizedConversionCastOp tuple,
|
|
ToValuesOp /*op*/) {
|
|
// The last field holds the value buffer.
|
|
return tuple.getInputs().size() - 1;
|
|
}
|
|
};
|
|
|
|
} // namespace
|
|
|
|
//===----------------------------------------------------------------------===//
|
|
// Sparse tensor type conversion into an actual buffer.
|
|
//===----------------------------------------------------------------------===//
|
|
|
|
mlir::SparseTensorTypeToBufferConverter::SparseTensorTypeToBufferConverter() {
|
|
addConversion([](Type type) { return type; });
|
|
addConversion(convertSparseTensorType);
|
|
}
|
|
|
|
//===----------------------------------------------------------------------===//
|
|
// Public method for populating conversion rules.
|
|
//===----------------------------------------------------------------------===//
|
|
|
|
/// Populates the given patterns list with conversion rules required for
|
|
/// the sparsification of linear algebra operations.
|
|
void mlir::populateSparseTensorCodegenPatterns(TypeConverter &typeConverter,
|
|
RewritePatternSet &patterns) {
|
|
patterns.add<SparseReturnConverter, SparseCallConverter, SparseDimOpConverter,
|
|
SparseCastConverter, SparseTensorAllocConverter,
|
|
SparseTensorDeallocConverter, SparseToPointersConverter,
|
|
SparseToIndicesConverter, SparseToValuesConverter,
|
|
SparseTensorLoadConverter>(typeConverter, patterns.getContext());
|
|
}
|