- abs(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs an "abs" operation on a matrix on the GPU
- acos(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs an "acos" operation on a matrix on the GPU
- acquireDeviceModifyDense() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- acquireDeviceModifySparse() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- acquireDeviceRead(String) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- acquireHostRead(String) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
if the data is allocated on the GPU and is dirty, it is copied back to the host memory
- AdaptivePartialBlock - Class in org.apache.sysml.runtime.matrix.data
-
Writable used in ReblockMR for intermediate results.
- AdaptivePartialBlock() - Constructor for class org.apache.sysml.runtime.matrix.data.AdaptivePartialBlock
-
- AdaptivePartialBlock(PartialBlock) - Constructor for class org.apache.sysml.runtime.matrix.data.AdaptivePartialBlock
-
- add(long, Pointer) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
Add a pointer to the rmvar-ed list
- add(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Add a value to a matrix cell (r,c).
- add(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- add(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- add(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- add(int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
Add a value to a specified column with awareness of
potential insertions.
- add(int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowScalar
-
- add(int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- addBias(double[], double[], double, int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
- AddDummyWeightConverter - Class in org.apache.sysml.runtime.matrix.data
-
- AddDummyWeightConverter() - Constructor for class org.apache.sysml.runtime.matrix.data.AddDummyWeightConverter
-
- addIDToDataFrame(Dataset<Row>, SparkSession, String) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
Add element indices as new column to DataFrame
- addReadLock() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- addResult(String, Data) - Method in class org.apache.sysml.api.jmlc.ResultVariables
-
Add the output variable name and generated output data to the ResultVariable
object.
- AddRowID() - Constructor for class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt.AddRowID
-
- addWriteLock() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- adjustRowIndicesMax(int[], double[], BinaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixOuterAgg
-
This function adjusts indices to be leveraged in uarimaxXX functions.
- adjustRowIndicesMin(int[], double[], BinaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixOuterAgg
-
This function adjusts indices to be leveraged in uariminXX functions.
- aggByKeyStable(JavaPairRDD<MatrixIndexes, MatrixBlock>, AggregateOperator) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
- aggByKeyStable(JavaPairRDD<MatrixIndexes, MatrixBlock>, AggregateOperator, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
- aggByKeyStable(JavaPairRDD<MatrixIndexes, MatrixBlock>, AggregateOperator, int, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
- aggregate(long, long, double) - Method in class org.apache.sysml.runtime.matrix.data.CTableMap
-
- aggregateBinary(MatrixCharacteristics, MatrixCharacteristics, AggregateBinaryOperator, MatrixCharacteristics) - Static method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- AggregateBinaryGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- aggregateBinaryMatrix(MatrixBlock, MatrixBlock, MatrixBlock, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixAgg
-
Core incremental matrix aggregate (ak+) as used in mapmult, tsmm,
cpmm, etc.
- aggregateBinaryMatrix(MatrixBlock, MatrixBlock, AggregateOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixAgg
-
Core incremental matrix aggregate (ak+) as used for uack+ and acrk+.
- aggregateBinaryOperations(MatrixBlock, MatrixBlock, MatrixBlock, AggregateBinaryOperator) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- aggregateBinaryOperations(MatrixIndexes, MatrixBlock, MatrixIndexes, MatrixBlock, MatrixBlock, AggregateBinaryOperator) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- aggregateBinaryOperations(MatrixIndexes, MatrixBlock, MatrixIndexes, MatrixBlock, MatrixBlock, AggregateBinaryOperator) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- aggregateBinaryOperations(MatrixBlock, MatrixBlock, MatrixBlock, AggregateBinaryOperator) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- aggregateMatrix(MatrixBlock, MatrixBlock, double[], int[], BinaryOperator, AggregateUnaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixOuterAgg
-
- aggregatePartialResults(SpoofCellwise.AggOp[], MatrixBlock, MatrixBlock) - Static method in class org.apache.sysml.runtime.codegen.SpoofMultiAggregate
-
- aggregateTernary(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, AggregateTernaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixAgg
-
- aggregateTernary(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, AggregateTernaryOperator, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixAgg
-
- aggregateTernaryOperations(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, AggregateTernaryOperator, boolean) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- aggregateTernaryOperations(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, AggregateTernaryOperator, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- AggregateTernarySPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- aggregateUnary(MatrixCharacteristics, AggregateUnaryOperator, MatrixCharacteristics) - Static method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- AggregateUnaryGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
Implements aggregate unary instructions for CUDA
- aggregateUnaryMatrix(MatrixBlock, MatrixBlock, AggregateUnaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixAgg
-
- aggregateUnaryMatrix(MatrixBlock, MatrixBlock, AggregateUnaryOperator, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixAgg
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, int, MatrixIndexes, boolean) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, int, MatrixIndexes) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, int, MatrixIndexes) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, int, MatrixIndexes, boolean) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, int, MatrixIndexes) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, int, MatrixIndexes, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, int, MatrixIndexes) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, int, MatrixIndexes, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, int, MatrixIndexes) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, int, MatrixIndexes, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, int, MatrixIndexes) - Method in class org.apache.sysml.runtime.matrix.data.WeightedCell
-
- AggregateUnarySPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- AggregateUnarySPInstruction(SPInstruction.SPType, AggregateUnaryOperator, AggregateOperator, CPOperand, CPOperand, AggBinaryOp.SparkAggType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.AggregateUnarySPInstruction
-
- AggregateUnarySPInstruction.RDDUAggFunction2 - Class in org.apache.sysml.runtime.instructions.spark
-
Similar to RDDUAggFunction but single output block.
- aggStable(JavaPairRDD<MatrixIndexes, MatrixBlock>, AggregateOperator) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
Single block aggregation over pair rdds with corrections for numerical stability.
- aggStable(JavaRDD<MatrixBlock>, AggregateOperator) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
Single block aggregation over rdds with corrections for numerical stability.
- algo - Variable in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNNConvolutionAlgorithm
-
- ALL_SUPPORTED_DATA_TYPES - Static variable in class org.apache.sysml.api.mlcontext.MLContextUtil
-
All data types supported by the MLContext API.
- allocate(Pointer, long) - Method in class org.apache.sysml.runtime.instructions.gpu.context.CudaMemoryAllocator
-
Allocate memory on the device.
- allocate(String, long) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Invokes memory manager's malloc method
- allocate(Pointer, long) - Method in interface org.apache.sysml.runtime.instructions.gpu.context.GPUMemoryAllocator
-
Allocate memory on the device.
- allocate(Pointer, long) - Method in class org.apache.sysml.runtime.instructions.gpu.context.UnifiedMemoryAllocator
-
Allocate memory on the device.
- allocate(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Allocate the underlying data structure holding non-zero values
of row r if necessary.
- allocate(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Allocate the underlying data structure holding non-zero values
of row r if necessary, w/ given size.
- allocate(int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Allocate the underlying data structure holding non-zero values
of row r w/ the specified estimated nnz and max nnz.
- allocate(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- allocate(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- allocate(int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- allocate(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- allocate(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- allocate(int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- allocate(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- allocate(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- allocate(int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- allocateAndFillDense(double) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Allocates a dense matrix of size obtained from the attached matrix metadata
and fills it up with a single value
- allocateAndResetSparseBlock(boolean, SparseBlock.Type) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- allocateBlock() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- allocateDenseBlock() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- allocateDenseBlock(boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- allocateDenseBlockUnsafe(int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
This should be called only in the read and write functions for CP
This function should be called before calling any setValueDenseUnsafe()
- allocateDenseOrSparse(int, int, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- allocateDenseOrSparse(long, long, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- allocateEmpty(GPUContext, long, long) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.CSRPointer
-
Factory method to allocate an empty CSR Sparse matrix on the GPU
- allocateForDgeam(GPUContext, cusparseHandle, CSRPointer, CSRPointer, int, int) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.CSRPointer
-
Estimates the number of non zero elements from the results of a sparse cusparseDgeam operation
C = a op(A) + b op(B)
- allocateForMatrixMultiply(GPUContext, cusparseHandle, CSRPointer, int, CSRPointer, int, int, int, int) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.CSRPointer
-
Estimates the number of non-zero elements from the result of a sparse matrix multiplication C = A * B
and returns the
CSRPointer
to C with the appropriate GPU memory.
- allocateSparseAndEmpty() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Allocates a sparse and empty
GPUObject
This is the result of operations that are both non zero matrices.
- allocateSparseRowsBlock() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- allocateSparseRowsBlock(boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- allocator - Variable in class org.apache.sysml.runtime.instructions.gpu.context.GPUMemoryManager
-
- allocDVector(int, boolean) - Static method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- allocIVector(int, boolean) - Static method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- allocVector(int, boolean) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- allocVector(int, boolean, double) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- ALLOW_CACHE_CONSCIOUS_ROWSUMS - Static variable in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- ALLOW_DDC_ENCODING - Static variable in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- ALLOW_SHARED_DDC1_DICTIONARY - Static variable in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- allPointers - Variable in class org.apache.sysml.runtime.instructions.gpu.context.GPUMemoryManager
-
To record size of all allocated pointers allocated by above memory managers
- append(MatrixBlock, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- append(MatrixBlock, MatrixBlock, boolean) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- append(MatrixValue, ArrayList<IndexedMatrixValue>, int, int, boolean, boolean, int) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- append(MatrixValue, ArrayList<IndexedMatrixValue>, int, int, boolean, boolean, int) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- append(FrameBlock, FrameBlock, boolean) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Appends the given argument frameblock 'that' to this frameblock by
creating a deep copy to prevent side effects.
- append(MatrixBlock, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- append(MatrixBlock, MatrixBlock, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- append(MatrixBlock[], MatrixBlock, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- append(MatrixValue, ArrayList<IndexedMatrixValue>, int, int, boolean, boolean, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- append(MatrixValue, ArrayList<IndexedMatrixValue>, int, int, boolean, boolean, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- append(MatrixValue, ArrayList<IndexedMatrixValue>, int, int, boolean, boolean, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- append(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Append a value to the end of the physical representation.
- append(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- append(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- append(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- append(int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
Appends a value to the end of the sparse row.
- append(int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowScalar
-
- append(int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- appendColumn(String[]) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Append a column of value type STRING as the last column of
the data frame.
- appendColumn(boolean[]) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Append a column of value type BOOLEAN as the last column of
the data frame.
- appendColumn(long[]) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Append a column of value type INT as the last column of
the data frame.
- appendColumn(double[]) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Append a column of value type DOUBLE as the last column of
the data frame.
- appendColumns(double[][]) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Append a set of column of value type DOUBLE at the end of the frame
in order to avoid repeated allocation with appendColumns.
- AppendGAlignedSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- AppendGAlignedSPInstruction.ShiftColumnIndex - Class in org.apache.sysml.runtime.instructions.spark
-
- AppendGSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- AppendGSPInstruction.MergeWithShiftedBlocks - Class in org.apache.sysml.runtime.instructions.spark
-
- AppendGSPInstruction.ShiftMatrix - Class in org.apache.sysml.runtime.instructions.spark
-
- AppendMSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- AppendMSPInstruction(Operator, CPOperand, CPOperand, CPOperand, CPOperand, boolean, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.AppendMSPInstruction
-
- appendRow(Object[]) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Append a row to the end of the data frame, where all row fields
are boxed objects according to the schema.
- appendRow(String[]) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Append a row to the end of the data frame, where all row fields
are string encoded.
- appendRow(int, SparseRow) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- appendRow(int, SparseRow, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- appendRowToSparse(SparseBlock, MatrixBlock, int, int, int, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- AppendRSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- AppendRSPInstruction(Operator, CPOperand, CPOperand, CPOperand, boolean, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.AppendRSPInstruction
-
- appendStatistics(StringBuilder) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
- appendToSparse(MatrixBlock, int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- appendToSparse(MatrixBlock, int, int, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- appendValue(DblArray, IntArrayList) - Method in class org.apache.sysml.runtime.compress.utils.DblArrayIntListHashMap
-
- appendValue(double, IntArrayList) - Method in class org.apache.sysml.runtime.compress.utils.DoubleIntListHashMap
-
- appendValue(int) - Method in class org.apache.sysml.runtime.compress.utils.IntArrayList
-
- appendValue(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Append value is only used when values are appended at the end of each row for the sparse representation
This can only be called, when the caller knows the access pattern of the block
- applyScalarOp(ScalarOperator) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
Method for use by subclasses.
- applyScalarOp(ScalarOperator, double, int) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- argVals - Variable in class org.apache.sysml.api.DMLOptions
-
- ArithmeticBinaryGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- ArithmeticBinaryGPUInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.gpu.ArithmeticBinaryGPUInstruction
-
- asin(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs an "asin" operation on a matrix on the GPU
- asMatrixCharacteristics() - Method in class org.apache.sysml.api.mlcontext.Metadata
-
Convert the metadata to a MatrixCharacteristics object.
- AssignRowIDMRReturn() - Constructor for class org.apache.sysml.runtime.matrix.CSVReblockMR.AssignRowIDMRReturn
-
- atan(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs an "atan" operation on a matrix on the GPU
- AVAILABLE_GPUS - Static variable in class org.apache.sysml.runtime.instructions.gpu.context.GPUContextPool
-
GPUs to use, can specify -1 to use all, comma separated list of GPU numbers, a specific GPU or a range
- axpy(ExecutionContext, GPUContext, String, MatrixObject, MatrixObject, String, double) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs daxpy operation
- C - Variable in class org.apache.sysml.runtime.matrix.data.DnnParameters
-
- cacheBinaryCellRDD(JavaPairRDD<MatrixIndexes, MatrixCell>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.AggregateUnarySPInstruction.RDDUAggFunction2
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.AppendGAlignedSPInstruction.ShiftColumnIndex
-
- call(Tuple2<MatrixIndexes, Tuple2<Iterable<MatrixBlock>, Iterable<MatrixBlock>>>) - Method in class org.apache.sysml.runtime.instructions.spark.AppendGSPInstruction.MergeWithShiftedBlocks
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.AppendGSPInstruction.ShiftMatrix
-
- call(MatrixBlock) - Method in class org.apache.sysml.runtime.instructions.spark.BinUaggChainSPInstruction.RDDBinUaggChainFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.BuiltinNarySPInstruction.PadBlocksFunction
-
- call(MatrixBlock) - Method in class org.apache.sysml.runtime.instructions.spark.CompressionSPInstruction.CompressionFunction
-
- call(MatrixBlock) - Method in class org.apache.sysml.runtime.instructions.spark.CtableSPInstruction.MapJoinSignature1
-
- call(Tuple2<MatrixBlock, MatrixBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.CtableSPInstruction.MapJoinSignature2
-
- call(Tuple2<Tuple2<MatrixBlock, MatrixBlock>, MatrixBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.CtableSPInstruction.MapJoinSignature3
-
- call(Iterator<Tuple2<Long, FrameBlock>>) - Method in class org.apache.sysml.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeBuild2Function
-
- call(Iterator<Tuple2<Long, FrameBlock>>) - Method in class org.apache.sysml.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeBuildFunction
-
- call(Tuple2<Integer, Iterable<FrameBlock.ColumnMetadata>>) - Method in class org.apache.sysml.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeGroup2Function
-
- call(Tuple2<Integer, Iterable<Object>>) - Method in class org.apache.sysml.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeGroupFunction
-
- call(WeightedCell) - Method in class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.CreateMatrixCell
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDMapGroupedAggFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDMapGroupedAggFunction2
-
- call(Tuple2<MatrixIndexes, Tuple2<MatrixBlock, MatrixBlock>>) - Method in class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDRemoveEmptyFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDRemoveEmptyFunctionInMem
-
- call(MatrixBlock) - Method in class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDReplaceFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDRExpandFunction
-
- call(Tuple2<Long, FrameBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTransformApplyFunction
-
- call(Tuple2<Long, FrameBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTransformApplyOffsetFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTransformDecodeExpandFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTransformDecodeFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.SpoofSPInstruction.ReplicateRightFactorFunction
-
- call(Tuple2<Long, FrameBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils.LongFrameToLongWritableFrameFunction
-
- call(Tuple2<LongWritable, FrameBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils.LongWritableFrameToLongFrameFunction
-
- call(Tuple2<LongWritable, Text>) - Method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils.LongWritableTextToLongTextFunction
-
- call(Tuple2<LongWritable, FrameBlock>) - Method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils.LongWritableToSerFunction
-
- call(Iterator<Tuple2<MatrixIndexes, MatrixCell>>) - Method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtils.BinaryCellToBinaryBlockFunction
-
- call(Row) - Method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtils.DataFrameExtractIDFunction
-
- call(Tuple2<Row, Long>) - Method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt.AddRowID
-
- call() - Method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNRelu.ReluBackward
-
- canAllocate(long) - Method in class org.apache.sysml.runtime.instructions.gpu.context.CudaMemoryAllocator
-
Check if there is enough memory to allocate a pointer of given size
- canAllocate(long) - Method in interface org.apache.sysml.runtime.instructions.gpu.context.GPUMemoryAllocator
-
Check if there is enough memory to allocate a pointer of given size
- canAllocate(long) - Method in class org.apache.sysml.runtime.instructions.gpu.context.UnifiedMemoryAllocator
-
Check if there is enough memory to allocate a pointer of given size
- capacity() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Get the total length of allocated blocks.
- capacity() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- capacity() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- capacity() - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- cardRatio - Variable in class org.apache.sysml.runtime.compress.cocode.PlanningCoCoder.GroupableColInfo
-
- CastSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- cbind(ExecutionContext, GPUContext, String, MatrixObject, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- ceil(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs an "ceil" operation on a matrix on the GPU
- CellIndex(int, int) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixValue.CellIndex
-
- CellIndex3() - Constructor for class org.apache.sysml.runtime.matrix.data.LibMatrixDNNHelper.CellIndex3
-
- CentralMomentSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- chainMatrixMultOperations(MatrixBlock, MatrixBlock, MatrixBlock, MapMultChain.ChainType) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- chainMatrixMultOperations(MatrixBlock, MatrixBlock, MatrixBlock, MapMultChain.ChainType, int) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- chainMatrixMultOperations(MatrixBlock, MatrixBlock, MatrixBlock, MapMultChain.ChainType) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- chainMatrixMultOperations(MatrixBlock, MatrixBlock, MatrixBlock, MapMultChain.ChainType, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- channelSums(GPUContext, String, MatrixObject, MatrixObject, long, long) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Perform channel_sums operations: out = rowSums(matrix(colSums(A), rows=C, cols=HW))
- channelSums(MatrixBlock, MatrixBlock, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
Perform channel sum operation
- checkBinaryAppendInputCharacteristics(SparkExecutionContext, boolean, boolean, boolean) - Method in class org.apache.sysml.runtime.instructions.spark.BinarySPInstruction
-
- checkInputParameterType(String, Object) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Verify that the type of input parameter value is supported.
- checkInputValueType(String, Object) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Verify that the type of input value is supported.
- checkInputValueTypes(Map<String, Object>) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Verify that the types of input values are supported.
- checkMatrixMatrixBinaryCharacteristics(SparkExecutionContext) - Method in class org.apache.sysml.runtime.instructions.spark.BinarySPInstruction
-
- checkNaN() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Checks for existing NaN values in the matrix block.
- checkNonZeros() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Basic debugging primitive to check correctness of nnz.
- checkNumFields(String, int) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
- checkNumFields(String[], int) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
- checkNumFields(String[], int, int) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
- checkNumFields(String, int, int) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
- CheckpointSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- checkResult(int) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaKernels
-
- checkReturnStatus() - Method in class org.apache.sysml.runtime.matrix.JobReturn
-
- checkScriptHasTypeAndString() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Check that the Script object has a type (DML or PYDML) and a string
representing the content of the Script.
- checkSparseRows() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- checkSparseRows(int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Basic debugging primitive to check sparse block column ordering.
- checkStatus(int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNN
-
Convenience method for checking the status of CuDNN kernel.
- checkType(MatrixValue) - Static method in class org.apache.sysml.runtime.matrix.data.MatrixPackedCell
-
- checkValidity(int, int, long, boolean) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Validate the correctness of the internal data structures of the different
sparse block implementations.
- checkValidity(int, int, long, boolean) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- checkValidity(int, int, long, boolean) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- checkValidity(int, int, long, boolean) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- clean - Variable in class org.apache.sysml.api.DMLOptions
-
- cleanupAfterExecution() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Perform any necessary cleanup operations after program execution.
- cleanupBlock(boolean, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Allows to cleanup all previously allocated sparserows or denseblocks.
- cleanupHadoopExecution(DMLConfig) - Static method in class org.apache.sysml.api.DMLScript
-
- cleanupJob(JobContext) - Method in class org.apache.sysml.runtime.matrix.data.MultipleOutputCommitter
-
- CleanupMapper() - Constructor for class org.apache.sysml.runtime.matrix.CleanupMR.CleanupMapper
-
- CleanupMR - Class in org.apache.sysml.runtime.matrix
-
- CleanupMR.CleanupMapper - Class in org.apache.sysml.runtime.matrix
-
- cleanupRuntimeInstructions(ArrayList<Instruction>, String...) - Static method in class org.apache.sysml.api.jmlc.JMLCUtils
-
Cleanup runtime instructions, removing rmvar instructions for
any of the given output variable names.
- cleanupRuntimeInstructions(ArrayList<Instruction>, HashSet<String>) - Static method in class org.apache.sysml.api.jmlc.JMLCUtils
-
Cleanup runtime instructions, removing rmvar instructions for
any of the given output variable names.
- cleanupRuntimeProgram(Program, String[]) - Static method in class org.apache.sysml.api.jmlc.JMLCUtils
-
Removes rmvar instructions that would remove any of the given outputs.
- cleanupRuntimeProgram() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
If maintainSymbolTable
is true, delete all 'remove variable'
instructions so as to maintain the values in the symbol table, which are
useful when working interactively in an environment such as the Spark
Shell.
- cleanupThreadLocalMemory() - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- cleanupThreadLocalMemory() - Static method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- clearAll() - Method in class org.apache.sysml.api.mlcontext.Script
-
Clear the script string, inputs, outputs, and symbol table.
- clearAll() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
- clearClassCache() - Static method in class org.apache.sysml.runtime.codegen.CodegenUtils
-
- clearClassCache(Class<?>) - Static method in class org.apache.sysml.runtime.codegen.CodegenUtils
-
- clearData(String, boolean) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Clears the data associated with this
GPUObject
instance
- clearDensePointer() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Removes the dense pointer and potential soft reference
- clearInputs() - Method in class org.apache.sysml.api.mlcontext.Script
-
Clear the inputs.
- clearIO() - Method in class org.apache.sysml.api.mlcontext.Script
-
Clear the inputs and outputs, but not the symbol table.
- clearIOS() - Method in class org.apache.sysml.api.mlcontext.Script
-
Clear the inputs, outputs, and symbol table.
- clearMemory() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
- clearMemory() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUMemoryManager
-
Clear the allocated GPU objects
- clearOutputs() - Method in class org.apache.sysml.api.mlcontext.Script
-
Clear the outputs.
- clearParameters() - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Remove all current values bound to input or output variables.
- clearShadowPointer() - Method in class org.apache.sysml.runtime.instructions.gpu.context.ShadowBuffer
-
Removes the content from shadow buffer
- clearSymbolTable() - Method in class org.apache.sysml.api.mlcontext.Script
-
Clear the symbol table.
- clearTemporaryMemory() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
- clearTemporaryMemory() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUMemoryManager
-
Clears up the memory used by non-dirty pointers.
- clen - Variable in class org.apache.sysml.runtime.codegen.SpoofOperator.SideInput
-
- clen - Variable in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- clens - Variable in class org.apache.sysml.runtime.matrix.CSVReblockMR.AssignRowIDMRReturn
-
- clone(boolean) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Creates a cloned instance of the prepared script, which
allows for concurrent execution without side effects.
- clone() - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
- clone(int) - Method in class org.apache.sysml.runtime.instructions.gpu.context.CSRPointer
-
- clone() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- clone() - Method in class org.apache.sysml.runtime.matrix.MetaData
-
- clone() - Method in class org.apache.sysml.runtime.matrix.MetaDataFormat
-
- clone() - Method in class org.apache.sysml.runtime.matrix.MetaDataNumItemsByEachReducer
-
- close() - Method in class org.apache.sysml.api.jmlc.Connection
-
Close connection to SystemML, which clears the
thread-local DML and compiler configurations.
- close() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Closes the mlcontext, which includes the cleanup of static and local
state as well as scratch space and buffer pool cleanup.
- close() - Method in class org.apache.sysml.runtime.matrix.CleanupMR.CleanupMapper
-
- close() - Method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNNConvolutionAlgorithm
-
Deallocates the tensor and filter descriptors as well as allocated workspace
- close() - Method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNNInputRowFetcher
-
Deallocates temporary pointer
- close() - Method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNNPoolingDescriptors
-
- close() - Method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNNRnnAlgorithm
-
- close(Reporter) - Method in class org.apache.sysml.runtime.matrix.data.UnPaddedOutputFormat.UnpaddedRecordWriter
-
- CM_N_COVCell - Class in org.apache.sysml.runtime.matrix.data
-
- CM_N_COVCell() - Constructor for class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- CMCOVMR - Class in org.apache.sysml.runtime.matrix
-
- cmOperations(CMOperator) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- cmOperations(CMOperator, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- cmOperations(CMOperator) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- cmOperations(CMOperator, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- CodegenUtils - Class in org.apache.sysml.runtime.codegen
-
- CodegenUtils() - Constructor for class org.apache.sysml.runtime.codegen.CodegenUtils
-
- col2imOverSingleImage(int, MatrixBlock, DnnParameters) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNIm2Col
-
- ColGroup - Class in org.apache.sysml.runtime.compress
-
Class that stores information about a column group within a compressed matrix
block.
- ColGroup(int[], int) - Constructor for class org.apache.sysml.runtime.compress.ColGroup
-
Main constructor.
- ColGroup(List<Integer>, int) - Constructor for class org.apache.sysml.runtime.compress.ColGroup
-
Convenience constructor for converting indices to a more compact format.
- ColGroup.ColGroupRowIterator - Class in org.apache.sysml.runtime.compress
-
Base class for column group row iterators.
- ColGroup.CompressionType - Enum in org.apache.sysml.runtime.compress
-
- ColGroupDDC - Class in org.apache.sysml.runtime.compress
-
Class to encapsulate information about a column group that is encoded with
dense dictionary encoding (DDC).
- ColGroupDDC() - Constructor for class org.apache.sysml.runtime.compress.ColGroupDDC
-
- ColGroupDDC(int[], int, UncompressedBitmap) - Constructor for class org.apache.sysml.runtime.compress.ColGroupDDC
-
- ColGroupDDC(int[], int, double[]) - Constructor for class org.apache.sysml.runtime.compress.ColGroupDDC
-
- ColGroupDDC1 - Class in org.apache.sysml.runtime.compress
-
Class to encapsulate information about a column group that is encoded with
dense dictionary encoding (DDC) using 1 byte codes.
- ColGroupDDC1() - Constructor for class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- ColGroupDDC1(int[], int, UncompressedBitmap) - Constructor for class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- ColGroupDDC1(int[], int, double[], byte[]) - Constructor for class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- ColGroupDDC2 - Class in org.apache.sysml.runtime.compress
-
Class to encapsulate information about a column group that is encoded with
dense dictionary encoding (DDC) using 2 byte codes.
- ColGroupDDC2() - Constructor for class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- ColGroupDDC2(int[], int, UncompressedBitmap) - Constructor for class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- ColGroupDDC2(int[], int, double[], char[]) - Constructor for class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- ColGroupOffset - Class in org.apache.sysml.runtime.compress
-
Base class for column groups encoded with various types of bitmap encoding.
- ColGroupOffset() - Constructor for class org.apache.sysml.runtime.compress.ColGroupOffset
-
- ColGroupOffset(int[], int, UncompressedBitmap) - Constructor for class org.apache.sysml.runtime.compress.ColGroupOffset
-
Main constructor.
- ColGroupOffset(int[], int, boolean, double[]) - Constructor for class org.apache.sysml.runtime.compress.ColGroupOffset
-
Constructor for subclass methods that need to create shallow copies
- ColGroupOffset.OffsetRowIterator - Class in org.apache.sysml.runtime.compress
-
- ColGroupOffset.OffsetValueIterator - Class in org.apache.sysml.runtime.compress
-
- ColGroupOffset.ZeroValueIterator - Class in org.apache.sysml.runtime.compress
-
- ColGroupOLE - Class in org.apache.sysml.runtime.compress
-
Class to encapsulate information about a column group that is encoded with
simple lists of offsets for each set of distinct values.
- ColGroupOLE() - Constructor for class org.apache.sysml.runtime.compress.ColGroupOLE
-
- ColGroupOLE(int[], int, UncompressedBitmap) - Constructor for class org.apache.sysml.runtime.compress.ColGroupOLE
-
Main constructor.
- ColGroupOLE(int[], int, boolean, double[], char[], int[]) - Constructor for class org.apache.sysml.runtime.compress.ColGroupOLE
-
- ColGroupRLE - Class in org.apache.sysml.runtime.compress
-
A group of columns compressed with a single run-length encoded bitmap.
- ColGroupRLE() - Constructor for class org.apache.sysml.runtime.compress.ColGroupRLE
-
- ColGroupRLE(int[], int, UncompressedBitmap) - Constructor for class org.apache.sysml.runtime.compress.ColGroupRLE
-
Main constructor.
- ColGroupRLE(int[], int, boolean, double[], char[], int[]) - Constructor for class org.apache.sysml.runtime.compress.ColGroupRLE
-
- ColGroupRowIterator() - Constructor for class org.apache.sysml.runtime.compress.ColGroup.ColGroupRowIterator
-
- ColGroupUncompressed - Class in org.apache.sysml.runtime.compress
-
Column group type for columns that are stored as dense arrays of doubles.
- ColGroupUncompressed() - Constructor for class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
- ColGroupUncompressed(List<Integer>, MatrixBlock) - Constructor for class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
Main constructor.
- ColGroupUncompressed(List<ColGroup>) - Constructor for class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
Constructor for creating temporary decompressed versions of one or more
compressed column groups.
- ColGroupUncompressed(int[], int, MatrixBlock) - Constructor for class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
Constructor for internal use.
- ColGroupValue - Class in org.apache.sysml.runtime.compress
-
Base class for column groups encoded with value dictionary.
- ColGroupValue() - Constructor for class org.apache.sysml.runtime.compress.ColGroupValue
-
- ColGroupValue(int[], int, UncompressedBitmap) - Constructor for class org.apache.sysml.runtime.compress.ColGroupValue
-
Stores the headers for the individual bitmaps.
- ColGroupValue(int[], int, double[]) - Constructor for class org.apache.sysml.runtime.compress.ColGroupValue
-
Constructor for subclass methods that need to create shallow copies
- colInd - Variable in class org.apache.sysml.runtime.instructions.gpu.context.CSRPointer
-
integer array of nnz values' column indices
- ColIndexes(int[]) - Constructor for class org.apache.sysml.runtime.compress.cocode.PlanningCoCodingGroup.ColIndexes
-
- colLower - Variable in class org.apache.sysml.runtime.instructions.spark.IndexingSPInstruction
-
- colsKnown() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- column - Variable in class org.apache.sysml.runtime.matrix.data.MatrixValue.CellIndex
-
- ColumnGroupPartitioner - Class in org.apache.sysml.runtime.compress.cocode
-
- ColumnGroupPartitioner() - Constructor for class org.apache.sysml.runtime.compress.cocode.ColumnGroupPartitioner
-
- ColumnGroupPartitionerBinPacking - Class in org.apache.sysml.runtime.compress.cocode
-
Column group partitioning with bin packing heuristic.
- ColumnGroupPartitionerBinPacking() - Constructor for class org.apache.sysml.runtime.compress.cocode.ColumnGroupPartitionerBinPacking
-
- ColumnGroupPartitionerStatic - Class in org.apache.sysml.runtime.compress.cocode
-
Column group partitioning with static distribution heuristic.
- ColumnGroupPartitionerStatic() - Constructor for class org.apache.sysml.runtime.compress.cocode.ColumnGroupPartitionerStatic
-
- columnMajorDenseToRowMajorSparse(GPUContext, cusparseHandle, Pointer, int, int) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Convenience method to convert a CSR matrix to a dense matrix on the GPU
Since the allocated matrix is temporary, bookkeeping is not updated.
- ColumnMetadata(long) - Constructor for class org.apache.sysml.runtime.matrix.data.FrameBlock.ColumnMetadata
-
- ColumnMetadata(long, String) - Constructor for class org.apache.sysml.runtime.matrix.data.FrameBlock.ColumnMetadata
-
- ColumnMetadata(FrameBlock.ColumnMetadata) - Constructor for class org.apache.sysml.runtime.matrix.data.FrameBlock.ColumnMetadata
-
- colUpper - Variable in class org.apache.sysml.runtime.instructions.spark.IndexingSPInstruction
-
- comb_instructions - Variable in class org.apache.sysml.runtime.matrix.CombineMR.InnerReducer
-
- COMBINE_INSTRUCTION - Static variable in class org.apache.sysml.runtime.matrix.SortMR
-
- CombineMR - Class in org.apache.sysml.runtime.matrix
-
- CombineMR.InnerReducer - Class in org.apache.sysml.runtime.matrix
-
- commitTask(TaskAttemptContext) - Method in class org.apache.sysml.runtime.matrix.data.MultipleOutputCommitter
-
- compact(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Re-allocate physical row if physical size exceeds
logical size plus resize factor.
- compact(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- compact(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- compact(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- compact() - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
In-place compaction of non-zero-entries; removes zero entries
and shifts non-zero entries to the left if necessary.
- compact() - Method in class org.apache.sysml.runtime.matrix.data.SparseRowScalar
-
- compact() - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- compactEmptyBlock() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- compactEmptyBlock() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- Comparator() - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes.Comparator
-
- Comparator() - Constructor for class org.apache.sysml.runtime.matrix.data.TripleIndexes.Comparator
-
- compare(GPUObject, GPUObject) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUMemoryManager.EvictionPolicyBasedComparator
-
- compare(RDDSortUtils.ValueIndexPair, RDDSortUtils.ValueIndexPair) - Method in class org.apache.sysml.runtime.instructions.spark.utils.RDDSortUtils.IndexComparator
-
- compare(RDDSortUtils.ValuesIndexPair, RDDSortUtils.ValuesIndexPair) - Method in class org.apache.sysml.runtime.instructions.spark.utils.RDDSortUtils.IndexComparator2
-
- compare(DnnParameters) - Method in class org.apache.sysml.runtime.matrix.data.DnnParameters
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixIndexes
-
- compare(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysml.runtime.matrix.data.MatrixIndexes
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes.Comparator
-
- compare(TaggedFirstSecondIndexes, TaggedFirstSecondIndexes) - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes.Comparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.sysml.runtime.matrix.data.TripleIndexes.Comparator
-
- compare(TripleIndexes, TripleIndexes) - Method in class org.apache.sysml.runtime.matrix.data.TripleIndexes.Comparator
-
- compareTo(CSVReblockMR.OffsetCount) - Method in class org.apache.sysml.runtime.matrix.CSVReblockMR.OffsetCount
-
- compareTo(Object) - Method in class org.apache.sysml.runtime.matrix.CSVReblockMR.OffsetCount
-
- compareTo(AdaptivePartialBlock) - Method in class org.apache.sysml.runtime.matrix.data.AdaptivePartialBlock
-
- compareTo(Object) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- compareTo(Object) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- compareTo(MatrixCell) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- compareTo(Object) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- compareTo(MatrixIndexes) - Method in class org.apache.sysml.runtime.matrix.data.MatrixIndexes
-
- compareTo(Object) - Method in class org.apache.sysml.runtime.matrix.data.MatrixPackedCell
-
- compareTo(PartialBlock) - Method in class org.apache.sysml.runtime.matrix.data.PartialBlock
-
- compareTo(Tagged) - Method in class org.apache.sysml.runtime.matrix.data.Tagged
-
- compareTo(TaggedFirstSecondIndexes) - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes
-
- compareTo(TaggedMatrixIndexes) - Method in class org.apache.sysml.runtime.matrix.data.TaggedMatrixIndexes
-
- compareTo(TaggedTripleIndexes) - Method in class org.apache.sysml.runtime.matrix.data.TaggedTripleIndexes
-
- compareTo(TripleIndexes) - Method in class org.apache.sysml.runtime.matrix.data.TripleIndexes
-
- compareTo(Object) - Method in class org.apache.sysml.runtime.matrix.data.WeightedCell
-
- compareTo(Object) - Method in class org.apache.sysml.runtime.matrix.data.WeightedPair
-
- compile(Script) - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- compile(Script, boolean) - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Compile a DML or PYDML script.
- compileClass(String, String) - Static method in class org.apache.sysml.runtime.codegen.CodegenUtils
-
- COMPLEX_DATA_TYPES - Static variable in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Complex data types supported by the MLContext API.
- compress() - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
Compress the contents of this matrix block.
- compress(int) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
Compress block.
- CompressedMatrixBlock - Class in org.apache.sysml.runtime.compress
-
Experimental version of MatrixBlock that allows a compressed internal
representation.
- CompressedMatrixBlock() - Constructor for class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- CompressedMatrixBlock(int, int, boolean) - Constructor for class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
Main constructor for building a block from scratch.
- CompressedMatrixBlock(MatrixBlock) - Constructor for class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
"Copy" constructor to populate this compressed block with the
uncompressed contents of a conventional block.
- CompressedMatrixBlock.CompressionStatistics - Class in org.apache.sysml.runtime.compress
-
- CompressedSizeEstimator - Class in org.apache.sysml.runtime.compress.estim
-
Base class for all compressed size estimators
- CompressedSizeEstimator(MatrixBlock) - Constructor for class org.apache.sysml.runtime.compress.estim.CompressedSizeEstimator
-
- CompressedSizeEstimator.SizeEstimationFactors - Class in org.apache.sysml.runtime.compress.estim
-
- CompressedSizeEstimatorExact - Class in org.apache.sysml.runtime.compress.estim
-
Exact compressed size estimator (examines entire dataset).
- CompressedSizeEstimatorExact(MatrixBlock) - Constructor for class org.apache.sysml.runtime.compress.estim.CompressedSizeEstimatorExact
-
- CompressedSizeEstimatorSample - Class in org.apache.sysml.runtime.compress.estim
-
- CompressedSizeEstimatorSample(MatrixBlock, int) - Constructor for class org.apache.sysml.runtime.compress.estim.CompressedSizeEstimatorSample
-
- CompressedSizeInfo - Class in org.apache.sysml.runtime.compress.estim
-
A helper reusable object for maintaining bitmap sizes
- CompressedSizeInfo(int, int, long, long, long) - Constructor for class org.apache.sysml.runtime.compress.estim.CompressedSizeInfo
-
- CompressionFunction() - Constructor for class org.apache.sysml.runtime.instructions.spark.CompressionSPInstruction.CompressionFunction
-
- CompressionSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- CompressionSPInstruction.CompressionFunction - Class in org.apache.sysml.runtime.instructions.spark
-
- CompressionStatistics() - Constructor for class org.apache.sysml.runtime.compress.CompressedMatrixBlock.CompressionStatistics
-
- CompressionStatistics(double, double, double, double, double) - Constructor for class org.apache.sysml.runtime.compress.CompressedMatrixBlock.CompressionStatistics
-
- ComputationSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- ComputationSPInstruction(SPInstruction.SPType, Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.ComputationSPInstruction
-
- ComputationSPInstruction(SPInstruction.SPType, Operator, CPOperand, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.ComputationSPInstruction
-
- computeColMxx(MatrixBlock, Builtin, boolean) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
NOTE: Shared across OLE/RLE/DDC because value-only computation.
- computeColSums(MatrixBlock, KahanFunction) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC
-
- computeColSums(MatrixBlock, KahanFunction) - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- computeColSums(MatrixBlock, KahanFunction) - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
- computeColSums(MatrixBlock, KahanFunction) - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- computeDimension(HashMap<Byte, MatrixCharacteristics>, MRInstruction) - Static method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- computeIQMCorrection(double, double, double, double, double, double) - Static method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- computeMatrixCharacteristics(JavaPairRDD<MatrixIndexes, MatrixCell>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
Utility to compute dimensions and non-zeros in a given RDD of binary cells.
- computeMxx(MatrixBlock, Builtin, boolean) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
NOTE: Shared across OLE/RLE/DDC because value-only computation.
- computeNNZ(GPUContext, Pointer, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Utility to compute number of non-zeroes on the GPU
- computeNNZperBlock(long, long, int, int, double) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDatagen
-
Deprecated.
- computeOffsets(boolean[]) - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
Utility function of sparse-unsafe operations.
- computeRowMxx(MatrixBlock, Builtin, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC
-
- computeRowMxx(MatrixBlock, Builtin, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- computeRowMxx(MatrixBlock, Builtin, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
- computeRowMxx(MatrixBlock, Builtin, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- computeRowSums(MatrixBlock, KahanFunction, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC
-
- computeRowSums(MatrixBlock, KahanFunction, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- computeRowSums(ColGroupDDC1[], MatrixBlock, KahanFunction, int, int) - Static method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- computeRowSums(MatrixBlock, KahanFunction, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- computeRowSums(MatrixBlock, KahanFunction, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- computeRowSums(MatrixBlock, KahanFunction, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
- computeRowSums(MatrixBlock, KahanFunction, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- computeSizeEstimationFactors(UncompressedBitmap, boolean) - Method in class org.apache.sysml.runtime.compress.estim.CompressedSizeEstimator
-
- computeSum(MatrixBlock, KahanFunction) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC
-
- computeSum(MatrixBlock, KahanFunction) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- computeSum(MatrixBlock, KahanFunction) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- computeSum(MatrixBlock, KahanFunction) - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- computeSum(MatrixBlock, KahanFunction) - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
- computeSum(MatrixBlock, KahanFunction) - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- computeTensorIndexes(int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNHelper
-
- computeTensorIndexes(int, int, int, LibMatrixDNNHelper.CellIndex3) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNHelper
-
Computes tensor indexes from a linearized column index such that
the column index is equal to ix1*NM + ix2*M + ix3
- computeZeroIndicatorVector() - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- computeZeroIndicatorVector() - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
Utility function of sparse-unsafe operations.
- computeZeroIndicatorVector() - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- config - Variable in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- configFile - Variable in class org.apache.sysml.api.DMLOptions
-
- ConfigurableAPI - Interface in org.apache.sysml.api
-
This interface defines the programmatic access to dml configuration properties
(as defined in SystemML-config.xml) to ensure API consistency across all APIs.
- configure(JobConf) - Method in class org.apache.sysml.runtime.matrix.CleanupMR.CleanupMapper
-
- configure(JobConf) - Method in class org.apache.sysml.runtime.matrix.CombineMR.InnerReducer
-
- configure(JobConf) - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes.FirstIndexPartitioner
-
- configure(JobConf) - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes.FirstIndexRangePartitioner
-
- configure(JobConf) - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes.TagPartitioner
-
- configure(JobConf) - Method in class org.apache.sysml.runtime.matrix.data.TripleIndexes.FirstTwoIndexesPartitioner
-
- Connection - Class in org.apache.sysml.api.jmlc
-
Interaction with SystemML using the JMLC (Java Machine Learning Connector) API is initiated with
a
Connection
object.
- Connection() - Constructor for class org.apache.sysml.api.jmlc.Connection
-
Connection constructor, the starting point for any other JMLC API calls.
- Connection(CompilerConfig.ConfigType...) - Constructor for class org.apache.sysml.api.jmlc.Connection
-
Connection constructor, the starting point for any other JMLC API calls.
- Connection(DMLConfig, CompilerConfig.ConfigType...) - Constructor for class org.apache.sysml.api.jmlc.Connection
-
Connection constructor, the starting point for any other JMLC API calls.
- Connection(DMLConfig) - Constructor for class org.apache.sysml.api.jmlc.Connection
-
Connection constructor, the starting point for any other JMLC API calls.
- constructHops() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Construct DAGs of high-level operators (HOPs) for each block of
statements.
- constructLops() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Construct DAGs of low-level operators (LOPs) based on the DAGs of
high-level operators (HOPs).
- constructParameterMap(String[]) - Static method in class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction
-
- containsAllZeroValue() - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- containsSeq() - Method in class org.apache.sysml.runtime.codegen.SpoofCellwise
-
- conv2d(GPUContext, String, MatrixObject, MatrixObject, MatrixObject, int, int, int, int, int, int, int, int, int, int, int, int, int, double) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNN
-
Performs a 2D convolution
- conv2d(MatrixBlock, MatrixBlock, MatrixBlock, DnnParameters) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
This method performs convolution (i.e.
- conv2d(MatrixBlock, MatrixBlock, MatrixBlock, DnnParameters) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixNative
-
This method performs convolution (i.e.
- conv2dBackwardData(GPUContext, String, MatrixObject, MatrixObject, MatrixObject, int, int, int, int, int, int, int, int, int, int, int, int, int, double) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNN
-
This method computes the backpropogation errors for previous layer of convolution operation
- conv2dBackwardData(MatrixBlock, MatrixBlock, MatrixBlock, DnnParameters) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
This method computes the backpropogation errors for previous layer of convolution operation
- conv2dBackwardData(MatrixBlock, MatrixBlock, MatrixBlock, DnnParameters) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixNative
-
This method computes the backpropagation errors for previous layer of convolution operation
- conv2dBackwardFilter(GPUContext, String, MatrixObject, MatrixObject, MatrixObject, int, int, int, int, int, int, int, int, int, int, int, int, int, double) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNN
-
This method computes the backpropogation errors for filter of convolution operation
- conv2dBackwardFilter(MatrixBlock, MatrixBlock, MatrixBlock, DnnParameters) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
This method computes the backpropogation errors for filter of convolution operation
- conv2dBackwardFilter(MatrixBlock, MatrixBlock, MatrixBlock, DnnParameters) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixNative
-
This method computes the backpropogation errors for filter of convolution operation
- conv2dBiasAdd(GPUContext, String, MatrixObject, MatrixObject, MatrixObject, MatrixObject, int, int, int, int, int, int, int, int, int, int, int, int, int, double) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNN
-
Does a 2D convolution followed by a bias_add
- convert(Writable, Writable) - Method in class org.apache.sysml.runtime.matrix.data.AddDummyWeightConverter
-
- convert(MatrixIndexes, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.BinaryBlockToBinaryCellConverter
-
- convert(MatrixIndexes, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.BinaryBlockToRowBlockConverter
-
- convert(MatrixIndexes, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.BinaryBlockToTextCellConverter
-
Before calling convert, please make sure to setBlockSize(brlen, bclen);
- convert(MatrixIndexes, MatrixCell) - Method in class org.apache.sysml.runtime.matrix.data.BinaryCellToRowBlockConverter
-
- convert(MatrixIndexes, MatrixCell) - Method in class org.apache.sysml.runtime.matrix.data.BinaryCellToTextConverter
-
- convert(K1, V1) - Method in interface org.apache.sysml.runtime.matrix.data.Converter
-
- convert(Writable, Writable) - Method in class org.apache.sysml.runtime.matrix.data.IdenticalConverter
-
- convert(LongWritable, Text) - Method in class org.apache.sysml.runtime.matrix.data.TextCellToRowBlockConverter
-
- convert(LongWritable, Text) - Method in class org.apache.sysml.runtime.matrix.data.TextToBinaryCellConverter
-
- convert(MatrixIndexes, WeightedCell) - Method in class org.apache.sysml.runtime.matrix.data.WeightedCellToSortInputConverter
-
- CONVERT_MCSR_TO_CSR_ON_DEEP_SERIALIZE - Static variable in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- convertDFSchemaToFrameSchema(StructType, String[], Expression.ValueType[], boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
NOTE: regarding the support of vector columns, we make the following
schema restriction: single vector column, which allows inference of
the vector length without data access and covers the common case.
- Converter<K1 extends org.apache.hadoop.io.Writable,V1 extends org.apache.hadoop.io.Writable,K2 extends org.apache.hadoop.io.Writable,V2 extends org.apache.hadoop.io.Writable> - Interface in org.apache.sysml.runtime.matrix.data
-
- ConverterUtils - Class in org.apache.sysml.runtime.compress.utils
-
- ConverterUtils() - Constructor for class org.apache.sysml.runtime.compress.utils.ConverterUtils
-
- convertFrameSchemaToDFSchema(Expression.ValueType[], boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
This function will convert Frame schema into DataFrame schema
- convertInputParametersForParser(Map<String, Object>, ScriptType) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Converts non-string basic input parameter values to strings to pass to
the parser.
- convertInputType(String, Object) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Convert input types to internal SystemML representations
- convertInputType(String, Object, Metadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Convert input types to internal SystemML representations
- convertMBtoPy4JDenseArr(MatrixBlock) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- convertPy4JArrayToMB(byte[], long, long) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- convertPy4JArrayToMB(byte[], int, int) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- convertPy4JArrayToMB(byte[], long, long, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- convertPy4JArrayToMB(byte[], int, int, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- convertSciPyCOOToMB(byte[], byte[], byte[], long, long, long) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- convertSciPyCOOToMB(byte[], byte[], byte[], int, int, int) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- convertToDoubleMatrix(String, String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input string representation of a matrix in csv or textcell format
into a dense double array.
- convertToDoubleMatrix(String, int, int) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input string representation of a matrix in textcell format
into a dense double array.
- convertToDoubleMatrix(InputStream, int, int) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input stream of a string matrix in textcell format
into a dense double array.
- convertToDoubleMatrix(InputStream, int, int, String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input stream of a string matrix in csv or textcell format
into a dense double array.
- convertToFrame(String, String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input string representation of a frame in csv or textcell format
into a frame block.
- convertToFrame(InputStream, String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input stream of a string frame in csv or textcell format
into a frame block.
- convertToFrame(String, int, int) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input string representation of a frame in textcell format
into a frame block.
- convertToFrame(InputStream, int, int) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input stream of a string frame in textcell format
into a frame block.
- convertToFrame(InputStream, int, int, String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input stream of a frame in csv or textcell format
into a frame block.
- convertToMatrix(String, String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input string representation of a matrix in csv or textcell format
into a matrix block.
- convertToMatrix(InputStream, String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input stream of a string matrix in csv or textcell format
into a matrix block.
- convertToMatrix(String, int, int) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input string representation of a matrix in textcell format
into a matrix block.
- convertToMatrix(InputStream, int, int) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input stream of a string matrix in textcell format
into a matrix block.
- convertToMatrix(InputStream, int, int, String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input stream of a string matrix in csv or textcell format
into a matrix block.
- convertToStringFrame(String, String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input string representation of a frame in csv or textcell format
into a dense string array.
- convertToStringFrame(String, int, int) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input stream of a string frame in textcell format
into a dense string array.
- convertToStringFrame(InputStream, int, int) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input stream of a string frame in textcell format
into a dense string array.
- convertToStringFrame(InputStream, int, int, String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input stream of a string frame in csv or textcell format
into a dense string array.
- CONVOLUTION_PREFERENCE - Static variable in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNN
-
- coordinateMatrixToBinaryBlock(JavaSparkContext, CoordinateMatrix, MatrixCharacteristics, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
Example usage:
- coordinateMatrixToBinaryBlock(SparkContext, CoordinateMatrix, MatrixCharacteristics, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- copy(MatrixValue, boolean) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- copy(MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- copy(FrameBlock) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- copy(int, int, int, int, FrameBlock) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- copy(MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- copy(MatrixValue, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- copy(int, int, int, int, MatrixBlock, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
In-place copy of matrix src into the index range of the existing current matrix.
- copy(MatrixValue, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- copy(MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- copy(MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- copy(MatrixValue, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- copy(SparseRow) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- copy(MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.WeightedCell
-
- copy(MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.WeightedPair
-
- copyBinaryBlockMatrix(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
Creates a partitioning-preserving deep copy of the input matrix RDD, where
the indexes and values are copied.
- copyBinaryBlockMatrix(JavaPairRDD<MatrixIndexes, MatrixBlock>, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
Creates a partitioning-preserving copy of the input matrix RDD.
- copyColGroup(ColGroup) - Static method in class org.apache.sysml.runtime.compress.utils.ConverterUtils
-
Copy col group instance with deep copy of column indices but
shallow copy of actual contents;
- copyFromDeviceToHost(String, boolean, boolean) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Copies the data from device to host.
- copyNonZerosToUpperTriangle(MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysml.runtime.compress.utils.LinearAlgebraUtils
-
- copyPtrToHost(CSRPointer, int, long, int[], int[]) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.CSRPointer
-
Static method to copy a CSR sparse matrix from Device to host
- copyRowBlocks(MatrixBlock, int, MatrixBlock, int, int, int) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- copyRowBlocks(MatrixBlock, long, MatrixBlock, int, int, int) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- copyRowBlocks(MatrixBlock, int, MatrixBlock, long, long, long) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- copyRowBlocks(MatrixBlock, long, MatrixBlock, long, long, long) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- copyShallow(MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- copySparseBlock(SparseBlock.Type, SparseBlock, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.SparseBlockFactory
-
- copyToDevice(GPUContext, CSRPointer, int, long, int[], int[], double[]) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.CSRPointer
-
Static method to copy a CSR sparse matrix from Host to Device
- copyUpperToLowerTriangle(MatrixBlock) - Static method in class org.apache.sysml.runtime.compress.utils.LinearAlgebraUtils
-
- copyUpperToLowerTriangle(MatrixBlock) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
Used for all version of TSMM where the result is known to be symmetric.
- cos(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs an "cos" operation on a matrix on the GPU
- cosh(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs an "cosh" operation on a matrix on the GPU
- count - Variable in class org.apache.sysml.runtime.matrix.CSVReblockMR.OffsetCount
-
- countAgg(double[], int[], int[], int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixAgg
-
- countAgg(double[], int[], int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixAgg
-
- countCompiledMRJobsAndSparkInstructions() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Count the number of compiled MR Jobs/Spark Instructions in the runtime
program and set this value in the statistics.
- counterFile - Variable in class org.apache.sysml.runtime.matrix.CSVReblockMR.AssignRowIDMRReturn
-
- countNonZeros() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Compute the number of non-zero values, which potentially
makes a full pass over the underlying blocks.
- countNonZeros(int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Compute the number of non-zero values for the given row,
which potentially makes a full pass over the underlying row.
- countNonZeros(int, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Compute the number of non-zero values, which potentially
makes a full pass over the underlying blocks in the row range.
- countNonZeros() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- countNonZeros(int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- countNonZeros(int, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- countNonZeros() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- countNonZeros(int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- countNonZeros(int, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- countNonZerosPerRow(int[], int, int) - Method in class org.apache.sysml.runtime.compress.ColGroup
-
Count the number of non-zeros per row
- countNonZerosPerRow(int[], int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC
-
- countNonZerosPerRow(int[], int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- countNonZerosPerRow(int[], int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- countNonZerosPerRow(int[], int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
- countNonZerosPerRow(int[], int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- countNonZerosPerRow(int[], int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
- countNonZerosPerRow(int, int) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- CovarianceSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- covOperations(COVOperator, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- covOperations(COVOperator, MatrixBlock, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- covOperations(COVOperator, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- covOperations(COVOperator, MatrixBlock, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- CPInstructionParser - Class in org.apache.sysml.runtime.instructions
-
- CPInstructionParser() - Constructor for class org.apache.sysml.runtime.instructions.CPInstructionParser
-
- CpmmSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
Cpmm: cross-product matrix multiplication operation (distributed matrix multiply
by join over common dimension and subsequent aggregation of partial results).
- CREATE_SKIPLIST - Static variable in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- createAndInitializeExecutionContext() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Create an execution context and set its variables to be the symbol table
of the script.
- createColName(int) - Static method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- createColNames(int) - Static method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- createColNames(int, int) - Static method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- createCompressedBitmaps(int, int, char[][]) - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- createDenseBlock(int, int) - Static method in class org.apache.sysml.runtime.matrix.data.DenseBlockFactory
-
- createDenseBlock(double[], int, int) - Static method in class org.apache.sysml.runtime.matrix.data.DenseBlockFactory
-
- createDenseBlock(DenseBlock.Type, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.DenseBlockFactory
-
- createGPUObject(MatrixObject) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Instantiates a new
GPUObject
initialized with the given
MatrixObject
.
- createInstance(Class<?>) - Static method in class org.apache.sysml.runtime.codegen.CodegenUtils
-
- CreateMatrixCell(int, Operator) - Constructor for class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.CreateMatrixCell
-
- createObject(Class<? extends MatrixValue>) - Static method in class org.apache.sysml.runtime.matrix.data.TaggedMatrixValue
-
- createOutputFilePathAndName(String) - Method in class org.apache.sysml.udf.PackageFunction
-
- createRandomMatrixGenerator(String, int, int, int, int, double, double, double, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDatagen
-
- createSideInput(MatrixBlock) - Static method in class org.apache.sysml.runtime.codegen.CodegenUtils
-
- createSparseBlock(int) - Static method in class org.apache.sysml.runtime.matrix.data.SparseBlockFactory
-
- createSparseBlock(SparseBlock.Type, int) - Static method in class org.apache.sysml.runtime.matrix.data.SparseBlockFactory
-
- createSparseBlock(SparseBlock.Type, SparseRow) - Static method in class org.apache.sysml.runtime.matrix.data.SparseBlockFactory
-
- createSparseSideInputs(SpoofOperator.SideInput[]) - Static method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- createSparseSideInputs(SpoofOperator.SideInput[], boolean) - Static method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- CSRPointer - Class in org.apache.sysml.runtime.instructions.gpu.context
-
Compressed Sparse Row (CSR) format for CUDA
Generalized matrix multiply is implemented for CSR format in the cuSparse library among other operations
Since we assume that the matrix is stored with zero-based indexing (i.e.
- CSVInputInfo - Static variable in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- CSVOutputInfo - Static variable in class org.apache.sysml.runtime.matrix.data.OutputInfo
-
- CSVReblockMR - Class in org.apache.sysml.runtime.matrix
-
- CSVReblockMR.AssignRowIDMRReturn - Class in org.apache.sysml.runtime.matrix
-
- CSVReblockMR.BlockRow - Class in org.apache.sysml.runtime.matrix
-
- CSVReblockMR.OffsetCount - Class in org.apache.sysml.runtime.matrix
-
- CSVReblockSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- CSVReblockSPInstruction(Operator, CPOperand, CPOperand, int, int, boolean, String, boolean, double, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.CSVReblockSPInstruction
-
- csvToBinaryBlock(JavaSparkContext, JavaPairRDD<LongWritable, Text>, MatrixCharacteristics, Expression.ValueType[], boolean, String, boolean, double) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- csvToBinaryBlock(JavaSparkContext, JavaRDD<String>, MatrixCharacteristics, Expression.ValueType[], boolean, String, boolean, double) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- csvToBinaryBlock(JavaSparkContext, JavaPairRDD<LongWritable, Text>, MatrixCharacteristics, boolean, String, boolean, double) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtils
-
- csvToBinaryBlock(JavaSparkContext, JavaRDD<String>, MatrixCharacteristics, boolean, String, boolean, double) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtils
-
Example usage:
- csvToRowRDD(JavaSparkContext, String, String, Expression.ValueType[]) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- csvToRowRDD(JavaSparkContext, JavaRDD<String>, String, Expression.ValueType[]) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- CTableMap - Class in org.apache.sysml.runtime.matrix.data
-
Ctable map is an abstraction for the hashmap used for ctable's hash group-by
because this structure is passed through various interfaces.
- CTableMap() - Constructor for class org.apache.sysml.runtime.matrix.data.CTableMap
-
- CTableMap(LongLongDoubleHashMap.EntryType) - Constructor for class org.apache.sysml.runtime.matrix.data.CTableMap
-
- ctableOperations(Operator, double, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- ctableOperations(Operator, double, double, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- ctableOperations(Operator, MatrixIndexes, double, boolean, int, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- ctableOperations(Operator, MatrixValue, double, boolean, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- ctableOperations(Operator, MatrixValue, MatrixValue, CTableMap) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- ctableOperations(Operator, MatrixValue, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- ctableOperations(Operator, MatrixValue, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- ctableOperations(Operator, MatrixValue, double, boolean, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- ctableOperations(Operator, double, double, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- ctableOperations(Operator, MatrixIndexes, double, boolean, int, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- ctableOperations(Operator, double, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- ctableOperations(Operator, double, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
D = ctable(A,v2,W)
this <- A; scalarThat <- v2; that2 <- W; result <- D
(i1,j1,v1) from input1 (this)
(v2) from sclar_input2 (scalarThat)
(i3,j3,w) from input3 (that2)
- ctableOperations(Operator, double, double, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
D = ctable(A,v2,w)
this <- A; scalar_that <- v2; scalar_that2 <- w; result <- D
(i1,j1,v1) from input1 (this)
(v2) from sclar_input2 (scalarThat)
(w) from scalar_input3 (scalarThat2)
- ctableOperations(Operator, MatrixIndexes, double, boolean, int, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Specific ctable case of ctable(seq(...),X), where X is the only
matrix input.
- ctableOperations(Operator, MatrixValue, double, boolean, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
D = ctable(A,B,w)
this <- A; that <- B; scalar_that2 <- w; result <- D
(i1,j1,v1) from input1 (this)
(i1,j1,v2) from input2 (that)
(w) from scalar_input3 (scalarThat2)
NOTE: This method supports both vectors and matrices.
- ctableOperations(Operator, MatrixValue, MatrixValue, CTableMap) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
D = ctable(A,B,W)
this <- A; that <- B; that2 <- W; result <- D
(i1,j1,v1) from input1 (this)
(i1,j1,v2) from input2 (that)
(i1,j1,w) from input3 (that2)
- ctableOperations(Operator, MatrixValue, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- ctableOperations(Operator, MatrixValue, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- ctableOperations(Operator, MatrixValue, double, boolean, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- ctableOperations(Operator, double, double, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- ctableOperations(Operator, MatrixIndexes, double, boolean, int, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- ctableOperations(Operator, double, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- ctableOperations(Operator, MatrixValue, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- ctableOperations(Operator, MatrixValue, double, boolean, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- ctableOperations(Operator, double, double, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- ctableOperations(Operator, MatrixIndexes, double, boolean, int, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- ctableOperations(Operator, double, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- ctableSeqOperations(MatrixValue, double, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- ctableSeqOperations(MatrixValue, double, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
D = ctable(seq,A,w)
this <- seq; thatMatrix <- A; thatScalar <- w; result <- D
(i1,j1,v1) from input1 (this)
(i1,j1,v2) from input2 (that)
(w) from scalar_input3 (scalarThat2)
- CtableSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- CtableSPInstruction.MapJoinSignature1 - Class in org.apache.sysml.runtime.instructions.spark
-
- CtableSPInstruction.MapJoinSignature2 - Class in org.apache.sysml.runtime.instructions.spark
-
- CtableSPInstruction.MapJoinSignature3 - Class in org.apache.sysml.runtime.instructions.spark
-
- cublasaxpy(cublasHandle, int, Pointer, Pointer, int, Pointer, int) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cublasaxpy(cublasHandle, int, Pointer, Pointer, int, Pointer, int) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cublasaxpy(cublasHandle, int, Pointer, Pointer, int, Pointer, int) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cublasdot(cublasHandle, int, Pointer, int, Pointer, int, Pointer) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cublasdot(cublasHandle, int, Pointer, int, Pointer, int, Pointer) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cublasdot(cublasHandle, int, Pointer, int, Pointer, int, Pointer) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cublasgeam(cublasHandle, int, int, int, int, Pointer, Pointer, int, Pointer, Pointer, int, Pointer, int) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cublasgeam(cublasHandle, int, int, int, int, Pointer, Pointer, int, Pointer, Pointer, int, Pointer, int) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cublasgeam(cublasHandle, int, int, int, int, Pointer, Pointer, int, Pointer, Pointer, int, Pointer, int) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cublasgemm(cublasHandle, int, int, int, int, int, Pointer, Pointer, int, Pointer, int, Pointer, Pointer, int) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cublasgemm(cublasHandle, int, int, int, int, int, Pointer, Pointer, int, Pointer, int, Pointer, Pointer, int) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cublasgemm(cublasHandle, int, int, int, int, int, Pointer, Pointer, int, Pointer, int, Pointer, Pointer, int) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cublasgemv(cublasHandle, int, int, int, Pointer, Pointer, int, Pointer, int, Pointer, Pointer, int) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cublasgemv(cublasHandle, int, int, int, Pointer, Pointer, int, Pointer, int, Pointer, Pointer, int) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cublasgemv(cublasHandle, int, int, int, Pointer, Pointer, int, Pointer, int, Pointer, Pointer, int) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cublassyrk(cublasHandle, int, int, int, int, Pointer, Pointer, int, Pointer, Pointer, int) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cublassyrk(cublasHandle, int, int, int, int, Pointer, Pointer, int, Pointer, Pointer, int) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cublassyrk(cublasHandle, int, int, int, int, Pointer, Pointer, int, Pointer, Pointer, int) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cublastrsm(cublasHandle, int, int, int, int, int, int, Pointer, Pointer, int, Pointer, int) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cublastrsm(cublasHandle, int, int, int, int, int, int, Pointer, Pointer, int, Pointer, int) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cublastrsm(cublasHandle, int, int, int, int, int, int, Pointer, Pointer, int, Pointer, int) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cudaFreeHelper(String, Pointer, boolean) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Does cudaFree calls, lazily.
- cudaGetDevice() - Static method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Returns which device is currently being used.
- CudaMemoryAllocator - Class in org.apache.sysml.runtime.instructions.gpu.context
-
- CudaMemoryAllocator() - Constructor for class org.apache.sysml.runtime.instructions.gpu.context.CudaMemoryAllocator
-
- CudaSupportFunctions - Interface in org.apache.sysml.runtime.matrix.data
-
DESIGN DOCUMENTATION FOR SUPPORTING LOWER PRECISION:
1.
- cudaSupportFunctions - Static variable in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- CUDNN_DATA_TYPE - Static variable in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- cudnnGetConvolutionBackwardDataAlgorithm(GPUContext, String, int, int, int, int, int, int, int, int, int, int, int, int, int, long) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNNConvolutionAlgorithm
-
Factory method to get the algorithm wrapper for convolution backward data
- cudnnGetConvolutionBackwardFilterAlgorithm(GPUContext, String, int, int, int, int, int, int, int, int, int, int, int, int, int, long) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNNConvolutionAlgorithm
-
Factory method to get the algorithm wrapper for convolution backward filter
- cudnnGetConvolutionForwardAlgorithm(GPUContext, String, int, int, int, int, int, int, int, int, int, int, int, int, int, long) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNNConvolutionAlgorithm
-
Factory method to get the algorithm wrapper for convolution forward
- cudnnPoolingBackwardDescriptors(GPUContext, String, int, int, int, int, int, int, int, int, int, int, int, int, int, LibMatrixDNN.PoolingType) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNNPoolingDescriptors
-
Get descriptors for maxpooling backward operation
- cudnnPoolingDescriptors(GPUContext, String, int, int, int, int, int, int, int, int, int, int, int, int, int, LibMatrixDNN.PoolingType) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNNPoolingDescriptors
-
Get descriptors for maxpooling operation
- cumaggregateUnaryMatrix(MatrixBlock, MatrixBlock, UnaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixAgg
-
- cumaggregateUnaryMatrix(MatrixBlock, MatrixBlock, UnaryOperator, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixAgg
-
- CumSumProd - Class in org.apache.sysml.udf.lib
-
Variant of cumsum:
Computes following two functions:
- CumSumProd() - Constructor for class org.apache.sysml.udf.lib.CumSumProd
-
- CumulativeAggregateSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- CumulativeOffsetSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- cusolverDngeqrf(cusolverDnHandle, int, int, Pointer, int, Pointer, Pointer, int, Pointer) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cusolverDngeqrf(cusolverDnHandle, int, int, Pointer, int, Pointer, Pointer, int, Pointer) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusolverDngeqrf(cusolverDnHandle, int, int, Pointer, int, Pointer, Pointer, int, Pointer) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusolverDngeqrf_bufferSize(cusolverDnHandle, int, int, Pointer, int, int[]) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cusolverDngeqrf_bufferSize(cusolverDnHandle, int, int, Pointer, int, int[]) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusolverDngeqrf_bufferSize(cusolverDnHandle, int, int, Pointer, int, int[]) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusolverDnormqr(cusolverDnHandle, int, int, int, int, int, Pointer, int, Pointer, Pointer, int, Pointer, int, Pointer) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cusolverDnormqr(cusolverDnHandle, int, int, int, int, int, Pointer, int, Pointer, Pointer, int, Pointer, int, Pointer) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusolverDnormqr(cusolverDnHandle, int, int, int, int, int, Pointer, int, Pointer, Pointer, int, Pointer, int, Pointer) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusparsecsr2csc(cusparseHandle, int, int, int, Pointer, Pointer, Pointer, Pointer, Pointer, Pointer, int, int) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cusparsecsr2csc(cusparseHandle, int, int, int, Pointer, Pointer, Pointer, Pointer, Pointer, Pointer, int, int) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusparsecsr2csc(cusparseHandle, int, int, int, Pointer, Pointer, Pointer, Pointer, Pointer, Pointer, int, int) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusparsecsr2dense(cusparseHandle, int, int, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, int) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cusparsecsr2dense(cusparseHandle, int, int, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, int) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusparsecsr2dense(cusparseHandle, int, int, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, int) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusparsecsrgeam(cusparseHandle, int, int, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cusparsecsrgeam(cusparseHandle, int, int, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusparsecsrgeam(cusparseHandle, int, int, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusparsecsrgemm(cusparseHandle, int, int, int, int, int, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cusparsecsrgemm(cusparseHandle, int, int, int, int, int, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusparsecsrgemm(cusparseHandle, int, int, int, int, int, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusparsecsrmm2(cusparseHandle, int, int, int, int, int, int, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, int, Pointer, Pointer, int) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cusparsecsrmm2(cusparseHandle, int, int, int, int, int, int, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, int, Pointer, Pointer, int) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusparsecsrmm2(cusparseHandle, int, int, int, int, int, int, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, int, Pointer, Pointer, int) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusparsecsrmv(cusparseHandle, int, int, int, int, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, Pointer, Pointer) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cusparsecsrmv(cusparseHandle, int, int, int, int, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, Pointer, Pointer) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusparsecsrmv(cusparseHandle, int, int, int, int, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, Pointer, Pointer) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusparsedense2csr(cusparseHandle, int, int, cusparseMatDescr, Pointer, int, Pointer, Pointer, Pointer, Pointer) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cusparsedense2csr(cusparseHandle, int, int, cusparseMatDescr, Pointer, int, Pointer, Pointer, Pointer, Pointer) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusparsedense2csr(cusparseHandle, int, int, cusparseMatDescr, Pointer, int, Pointer, Pointer, Pointer, Pointer) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusparsennz(cusparseHandle, int, int, int, cusparseMatDescr, Pointer, int, Pointer, Pointer) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- cusparsennz(cusparseHandle, int, int, int, cusparseMatDescr, Pointer, int, Pointer, Pointer) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusparsennz(cusparseHandle, int, int, int, cusparseMatDescr, Pointer, int, Pointer, Pointer) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- customKernelSuffix - Static variable in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- DArrayIListEntry(DblArray, IntArrayList) - Constructor for class org.apache.sysml.runtime.compress.utils.DblArrayIntListHashMap.DArrayIListEntry
-
- data - Variable in class org.apache.sysml.runtime.matrix.CSVReblockMR.BlockRow
-
- DataFrameExtractIDFunction(int) - Constructor for class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtils.DataFrameExtractIDFunction
-
- dataFrameToBinaryBlock(JavaSparkContext, Dataset<Row>, MatrixCharacteristics, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- dataFrameToBinaryBlock(JavaSparkContext, Dataset<Row>, MatrixCharacteristics, boolean, Pair<String[], Expression.ValueType[]>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- dataFrameToBinaryBlock(JavaSparkContext, Dataset<Row>, MatrixCharacteristics, boolean, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtils
-
- dataFrameToFrameBinaryBlocks(Dataset<Row>, FrameMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a DataFrame
to a JavaPairRDD<Long, FrameBlock>
binary-block frame.
- dataFrameToFrameObject(Dataset<Row>) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a DataFrame
to a FrameObject
.
- dataFrameToFrameObject(Dataset<Row>, FrameMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a DataFrame
to a FrameObject
.
- dataFrameToMatrixBinaryBlocks(Dataset<Row>) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a DataFrame
to a
JavaPairRDD<MatrixIndexes, MatrixBlock>
binary-block matrix.
- dataFrameToMatrixBinaryBlocks(Dataset<Row>, MatrixMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a DataFrame
to a
JavaPairRDD<MatrixIndexes, MatrixBlock>
binary-block matrix.
- dataFrameToMatrixObject(Dataset<Row>) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a DataFrame
to a MatrixObject
.
- dataFrameToMatrixObject(Dataset<Row>, MatrixMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a DataFrame
to a MatrixObject
.
- DataGenMR - Class in org.apache.sysml.runtime.matrix
-
Rand MapReduce job which creates random objects.
- DataPartitionMR - Class in org.apache.sysml.runtime.matrix
-
- DATATYPE_PREFIX - Static variable in class org.apache.sysml.runtime.instructions.Instruction
-
- dataTypePointerTo(double) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- DblArray - Class in org.apache.sysml.runtime.compress.utils
-
Helper class used for bitmap extraction.
- DblArray() - Constructor for class org.apache.sysml.runtime.compress.utils.DblArray
-
- DblArray(double[]) - Constructor for class org.apache.sysml.runtime.compress.utils.DblArray
-
- DblArray(DblArray) - Constructor for class org.apache.sysml.runtime.compress.utils.DblArray
-
- DblArray(double[], boolean) - Constructor for class org.apache.sysml.runtime.compress.utils.DblArray
-
- DblArrayIntListHashMap - Class in org.apache.sysml.runtime.compress.utils
-
This class provides a memory-efficient replacement for
HashMap<DblArray,IntArrayList>
for restricted use cases.
- DblArrayIntListHashMap() - Constructor for class org.apache.sysml.runtime.compress.utils.DblArrayIntListHashMap
-
- DblArrayIntListHashMap.DArrayIListEntry - Class in org.apache.sysml.runtime.compress.utils
-
- ddat - Variable in class org.apache.sysml.runtime.codegen.SpoofOperator.SideInput
-
- deallocate() - Method in class org.apache.sysml.runtime.instructions.gpu.context.CSRPointer
-
Calls cudaFree lazily on the allocated Pointer
instances
- deallocate(boolean) - Method in class org.apache.sysml.runtime.instructions.gpu.context.CSRPointer
-
Calls cudaFree lazily or eagerly on the allocated Pointer
instances
- debug - Variable in class org.apache.sysml.api.DMLOptions
-
- decompress() - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
Decompress block.
- decompress(int) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
Decompress block.
- decompressToBlock(MatrixBlock, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroup
-
Decompress the contents of this column group into the specified full
matrix block.
- decompressToBlock(MatrixBlock, int[]) - Method in class org.apache.sysml.runtime.compress.ColGroup
-
Decompress the contents of this column group into uncompressed packed
columns
- decompressToBlock(MatrixBlock, int) - Method in class org.apache.sysml.runtime.compress.ColGroup
-
Decompress to block.
- decompressToBlock(MatrixBlock, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC
-
- decompressToBlock(MatrixBlock, int[]) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC
-
- decompressToBlock(MatrixBlock, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC
-
- decompressToBlock(MatrixBlock, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- decompressToBlock(MatrixBlock, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- decompressToBlock(MatrixBlock, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- decompressToBlock(MatrixBlock, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- decompressToBlock(MatrixBlock, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- decompressToBlock(MatrixBlock, int[]) - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- decompressToBlock(MatrixBlock, int) - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- decompressToBlock(MatrixBlock, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
- decompressToBlock(MatrixBlock, int[]) - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
- decompressToBlock(MatrixBlock, int) - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
- decompressToBlock(MatrixBlock, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- decompressToBlock(MatrixBlock, int[]) - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- decompressToBlock(MatrixBlock, int) - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- decompressToBlock(MatrixBlock, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
- decompressToBlock(MatrixBlock, int[]) - Method in class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
- decompressToBlock(MatrixBlock, int) - Method in class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
- DEFAULT_FILENAME - Static variable in class org.apache.sysml.udf.Matrix
-
- DEFAULT_INPLACE_SPARSEBLOCK - Static variable in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- DEFAULT_SPARSEBLOCK - Static variable in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- DEFAULT_TMP - Static variable in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- defaultOptions - Static variable in class org.apache.sysml.api.DMLOptions
-
- deleteIndexRange(int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Deletes all non-zero values of the given column range [cl,cu) in row r.
- deleteIndexRange(int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- deleteIndexRange(int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- deleteIndexRange(int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- deleteIndexRange(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- deleteRemoveVariableInstructions(Program) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Delete the 'remove variable' instructions from a runtime program.
- DenseBlock - Class in org.apache.sysml.runtime.matrix.data
-
This DenseBlock is an abstraction for different dense, row-major
matrix formats.
- DenseBlock() - Constructor for class org.apache.sysml.runtime.matrix.data.DenseBlock
-
- denseBlock - Variable in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- DenseBlock.Type - Enum in org.apache.sysml.runtime.matrix.data
-
- DenseBlockDRB - Class in org.apache.sysml.runtime.matrix.data
-
- DenseBlockDRB(int, int) - Constructor for class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- DenseBlockDRB(double[], int, int) - Constructor for class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- DenseBlockFactory - Class in org.apache.sysml.runtime.matrix.data
-
- DenseBlockFactory() - Constructor for class org.apache.sysml.runtime.matrix.data.DenseBlockFactory
-
- DenseBlockLDRB - Class in org.apache.sysml.runtime.matrix.data
-
- DenseBlockLDRB(int, int) - Constructor for class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- DenseBlockLDRB(int, int, int) - Constructor for class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- denseColumnMajorToRowMajor() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Convenience method.
- denseRowMajorToColumnMajor() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Convenience method.
- denseScalarOperationsInPlace(ScalarOperator) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- denseScalarOperationsInPlace(ScalarOperator) - Method in class org.apache.sysml.runtime.matrix.data.WeightedCell
-
- denseToSparse() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Converts this GPUObject from dense to sparse format.
- denseTranspose(ExecutionContext, GPUContext, String, Pointer, Pointer, long, long) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Computes C = t(A)
- deriveAggregateOperatorCorrectionLocation(String) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
- deriveAggregateOperatorOpcode(String) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
- descr - Variable in class org.apache.sysml.runtime.instructions.gpu.context.CSRPointer
-
descriptor of matrix, only CUSPARSE_MATRIX_TYPE_GENERAL supported
- destroy() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Destroys this GPUContext object.
- determineFrameFormatIfNeeded(Dataset<Row>, FrameMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
If the FrameFormat of the DataFrame has not been explicitly specified,
attempt to determine the proper FrameFormat.
- determineMatrixFormatIfNeeded(Dataset<Row>, MatrixMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
If the MatrixFormat of the DataFrame has not been explicitly specified,
attempt to determine the proper MatrixFormat.
- determineNumReducers(long[], long[], int, long) - Static method in class org.apache.sysml.runtime.matrix.MMCJMR
-
Determine number of reducers based on configured number of reducers, number of results groups
and input data divided by blocksize (as heuristic for useful degree of parallelism).
- determineNumReducers(long[], long[], int, long) - Static method in class org.apache.sysml.runtime.matrix.WriteCSVMR
-
- determineOutputTypeAsString(LocalVariableMap, String) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Obtain a symbol table output type as a String
- deviceCopy(String, Pointer, Pointer, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs a deep copy of input device double pointer corresponding to matrix
- deviceToHost(GPUContext, Pointer, double[], String, boolean) - Method in interface org.apache.sysml.runtime.matrix.data.CudaSupportFunctions
-
- deviceToHost(GPUContext, Pointer, double[], String, boolean) - Method in class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- deviceToHost(GPUContext, Pointer, double[], String, boolean) - Method in class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- DF_ID_COLUMN - Static variable in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtils
-
- diag(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
- DIListEntry(double, IntArrayList) - Constructor for class org.apache.sysml.runtime.compress.utils.DoubleIntListHashMap.DIListEntry
-
- dimsKnown() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- dimsKnown(boolean) - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- dirty - Variable in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
whether the block attached to this
GPUContext
is dirty on the device and needs to be copied back to host
- displayInputParameters() - Method in class org.apache.sysml.api.mlcontext.Script
-
Display the script input parameters.
- displayInputs(String, Map<String, Object>, LocalVariableMap) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Obtain a display of script inputs.
- displayInputs() - Method in class org.apache.sysml.api.mlcontext.Script
-
Display the script inputs.
- displayInputVariables() - Method in class org.apache.sysml.api.mlcontext.Script
-
Display the script input variables.
- displayMap(String, Map<String, Object>) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Display the keys and values in a Map
- displayOutputs(String, Set<String>, LocalVariableMap) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Obtain a display of the script outputs.
- displayOutputs(Set<String>, LocalVariableMap) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Obtain a display of the script outputs.
- displayOutputs() - Method in class org.apache.sysml.api.mlcontext.Script
-
Display the script outputs.
- displayOutputVariables() - Method in class org.apache.sysml.api.mlcontext.Script
-
Display the script output variables.
- displaySet(String, Set<String>) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Display the values in a Set
- displaySymbolTable(String, LocalVariableMap) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Display the keys and values in the symbol table
- displaySymbolTable(LocalVariableMap) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Display the keys and values in the symbol table
- displaySymbolTable() - Method in class org.apache.sysml.api.mlcontext.Script
-
Display the script symbol table.
- dml(String) - Static method in class org.apache.sysml.api.mlcontext.ScriptFactory
-
Create a DML Script object based on a string.
- DML_FILE_PATH_ANTLR_PARSER - Static variable in class org.apache.sysml.api.DMLScript
-
- DMLException - Exception in org.apache.sysml.api
-
Exception occurring in the DML framework.
- DMLException() - Constructor for exception org.apache.sysml.api.DMLException
-
- DMLException(String) - Constructor for exception org.apache.sysml.api.DMLException
-
- DMLException(Throwable) - Constructor for exception org.apache.sysml.api.DMLException
-
- DMLException(String, Throwable) - Constructor for exception org.apache.sysml.api.DMLException
-
- dmlFromFile(String) - Static method in class org.apache.sysml.api.mlcontext.ScriptFactory
-
Create a DML Script object based on a string path to a file.
- dmlFromInputStream(InputStream) - Static method in class org.apache.sysml.api.mlcontext.ScriptFactory
-
Create a DML Script object based on an input stream.
- dmlFromLocalFile(File) - Static method in class org.apache.sysml.api.mlcontext.ScriptFactory
-
Creates a DML Script object based on a file in the local file system.
- dmlFromResource(String) - Static method in class org.apache.sysml.api.mlcontext.ScriptFactory
-
Create a DML Script object based on a resource path.
- dmlFromString(String) - Static method in class org.apache.sysml.api.mlcontext.ScriptFactory
-
Create a DML Script object based on a string.
- dmlFromUrl(String) - Static method in class org.apache.sysml.api.mlcontext.ScriptFactory
-
Create a DML Script object based on a URL path.
- dmlFromUrl(URL) - Static method in class org.apache.sysml.api.mlcontext.ScriptFactory
-
Create a DML Script object based on a URL.
- DMLOptions - Class in org.apache.sysml.api
-
Set of DMLOptions that can be set through the command line
and
MLContext
The values have been initialized with the default values
Despite there being a DML and PyDML, this class is named DMLOptions
to keep it consistent with
DMLOptions
and
DMLOptions
- DMLOptions(Options) - Constructor for class org.apache.sysml.api.DMLOptions
-
- dmlProgram - Variable in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- DMLRuntimeException - Exception in org.apache.sysml.runtime
-
This exception should be thrown to flag runtime errors -- DML equivalent to java.lang.RuntimeException.
- DMLRuntimeException(String) - Constructor for exception org.apache.sysml.runtime.DMLRuntimeException
-
- DMLRuntimeException(Exception) - Constructor for exception org.apache.sysml.runtime.DMLRuntimeException
-
- DMLRuntimeException(String, Exception) - Constructor for exception org.apache.sysml.runtime.DMLRuntimeException
-
- DMLScript - Class in org.apache.sysml.api
-
- DMLScript() - Constructor for class org.apache.sysml.api.DMLScript
-
- DMLScript.EvictionPolicy - Enum in org.apache.sysml.api
-
Eviction policies for eviction of GPU objects.
- DMLScript.RUNTIME_PLATFORM - Enum in org.apache.sysml.api
-
- DMLScriptException - Exception in org.apache.sysml.runtime
-
This exception should be thrown to flag DML Script errors.
- DMLScriptException(String) - Constructor for exception org.apache.sysml.runtime.DMLScriptException
-
This is the only valid constructor for DMLScriptException.
- dmlTranslator - Variable in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- DnnGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- DnnGPUInstruction(CPOperand, CPOperand, CPOperand, String, String, double) - Constructor for class org.apache.sysml.runtime.instructions.gpu.DnnGPUInstruction
-
- DnnGPUInstruction(CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, String, String, double) - Constructor for class org.apache.sysml.runtime.instructions.gpu.DnnGPUInstruction
-
- DnnGPUInstruction(CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, String, String, double) - Constructor for class org.apache.sysml.runtime.instructions.gpu.DnnGPUInstruction
-
- DnnGPUInstruction(CPOperand, CPOperand, CPOperand, CPOperand, String, String, double) - Constructor for class org.apache.sysml.runtime.instructions.gpu.DnnGPUInstruction
-
- DnnGPUInstruction(CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, String, String, double) - Constructor for class org.apache.sysml.runtime.instructions.gpu.DnnGPUInstruction
-
- DnnGPUInstruction(CPOperand, CPOperand, CPOperand, CPOperand, String, String, ArrayList<CPOperand>, ArrayList<CPOperand>, ArrayList<CPOperand>, ArrayList<CPOperand>, double) - Constructor for class org.apache.sysml.runtime.instructions.gpu.DnnGPUInstruction
-
- DnnGPUInstruction(CPOperand, CPOperand, CPOperand, String, String, ArrayList<CPOperand>, ArrayList<CPOperand>, ArrayList<CPOperand>, ArrayList<CPOperand>, double) - Constructor for class org.apache.sysml.runtime.instructions.gpu.DnnGPUInstruction
-
- DnnGPUInstruction(CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, String, String, double) - Constructor for class org.apache.sysml.runtime.instructions.gpu.DnnGPUInstruction
-
- DnnParameters - Class in org.apache.sysml.runtime.matrix.data
-
This class is container that stores parameters required for executing following operations:
conv2d, conv2d_backward_data, conv2d_backward_filter, maxpooling, maxpooling_backward
- DnnParameters(long, long, long, long, long, long, long, long, long, long, long, int) - Constructor for class org.apache.sysml.runtime.matrix.data.DnnParameters
-
- DnnParameters(int, int, int, int, int, int, int, int, int, int, int, int) - Constructor for class org.apache.sysml.runtime.matrix.data.DnnParameters
-
- DnnSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- doesDataFrameLookLikeMatrix(Dataset<Row>) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Examine the DataFrame schema to determine whether the data appears to be
a matrix.
- doesSymbolTableContainFrameObject(LocalVariableMap, String) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Determine if the symbol table contains a FrameObject with the given
variable name.
- doesSymbolTableContainMatrixObject(LocalVariableMap, String) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Determine if the symbol table contains a MatrixObject with the given
variable name.
- dotProduct(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- dotProduct(double[], double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- dotProduct(double[], double[], int) - Static method in class org.apache.sysml.runtime.compress.utils.LinearAlgebraUtils
-
- dotProduct(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.compress.utils.LinearAlgebraUtils
-
- dotProduct(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- dotProduct(double[], double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- double2float(GPUContext, Pointer, Pointer, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- DoubleIntListHashMap - Class in org.apache.sysml.runtime.compress.utils
-
This class provides a memory-efficient replacement for
HashMap<Double,IntArrayList>
for restricted use cases.
- DoubleIntListHashMap() - Constructor for class org.apache.sysml.runtime.compress.utils.DoubleIntListHashMap
-
- DoubleIntListHashMap.DIListEntry - Class in org.apache.sysml.runtime.compress.utils
-
- doubleMatrixToMatrixObject(String, double[][]) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a two-dimensional double array to a MatrixObject
.
- doubleMatrixToMatrixObject(String, double[][], MatrixMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a two-dimensional double array to a MatrixObject
.
- DoublePrecisionCudaSupportFunctions - Class in org.apache.sysml.runtime.matrix.data
-
- DoublePrecisionCudaSupportFunctions() - Constructor for class org.apache.sysml.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- dropLastRowsOrColumns(PartialAggregate.CorrectionLocationType) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- dxDesc - Variable in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNNPoolingDescriptors
-
- dyDesc - Variable in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNNPoolingDescriptors
-
- DynamicProjectMatrixCP - Class in org.apache.sysml.udf.lib
-
- DynamicProjectMatrixCP() - Constructor for class org.apache.sysml.udf.lib.DynamicProjectMatrixCP
-
- DynamicReadMatrixCP - Class in org.apache.sysml.udf.lib
-
- DynamicReadMatrixCP() - Constructor for class org.apache.sysml.udf.lib.DynamicReadMatrixCP
-
- DynamicReadMatrixRcCP - Class in org.apache.sysml.udf.lib
-
- DynamicReadMatrixRcCP() - Constructor for class org.apache.sysml.udf.lib.DynamicReadMatrixRcCP
-
- DynamicWriteMatrixCP - Class in org.apache.sysml.udf.lib
-
Deprecated.
- DynamicWriteMatrixCP() - Constructor for class org.apache.sysml.udf.lib.DynamicWriteMatrixCP
-
Deprecated.
- fieldDisplay(Object) - Method in class org.apache.sysml.api.mlcontext.Metadata
-
- filename - Variable in class org.apache.sysml.runtime.instructions.Instruction
-
- filename - Variable in class org.apache.sysml.runtime.matrix.CSVReblockMR.OffsetCount
-
- fileOffset - Variable in class org.apache.sysml.runtime.matrix.CSVReblockMR.OffsetCount
-
- filePath - Variable in class org.apache.sysml.api.DMLOptions
-
- findClass(String) - Method in class org.apache.sysml.runtime.codegen.ByteClassLoader
-
- findCocodesByPartitioning(CompressedSizeEstimator, List<Integer>, CompressedSizeInfo[], int, int) - Static method in class org.apache.sysml.runtime.compress.cocode.PlanningCoCoder
-
- findMRInstructions(int) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
Search whether or not this MR job contains at least one
MR instruction with specified line number parameter
- findSmallestFile(JobConf, String) - Static method in class org.apache.sysml.runtime.matrix.CSVReblockMR
-
Method to find the first (part)file in the order given by fs.listStatus()
among all (part)files in inpathPath
.
- FINEGRAINED_STATISTICS - Static variable in class org.apache.sysml.api.DMLScript
-
- first - Variable in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes
-
- FirstIndexPartitioner() - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes.FirstIndexPartitioner
-
- FirstIndexRangePartitioner() - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes.FirstIndexRangePartitioner
-
- FirstTwoIndexesPartitioner() - Constructor for class org.apache.sysml.runtime.matrix.data.TripleIndexes.FirstTwoIndexesPartitioner
-
- float2double(GPUContext, Pointer, Pointer, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- FLOATING_POINT_PRECISION - Static variable in class org.apache.sysml.api.DMLScript
-
- floor(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs an "floor" operation on a matrix on the GPU
- FORCE_ACCELERATOR - Static variable in class org.apache.sysml.api.DMLScript
-
- forceGPU - Variable in class org.apache.sysml.api.DMLOptions
-
- forceGPU - Variable in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- Frame - Class in org.apache.sysml.api.mlcontext
-
Frame encapsulates a SystemML frame.
- Frame(FrameObject, SparkExecutionContext) - Constructor for class org.apache.sysml.api.mlcontext.Frame
-
- Frame(Dataset<Row>, FrameMetadata) - Constructor for class org.apache.sysml.api.mlcontext.Frame
-
Convert a Spark DataFrame to a SystemML binary-block representation.
- Frame(Dataset<Row>, long, long) - Constructor for class org.apache.sysml.api.mlcontext.Frame
-
Convert a Spark DataFrame to a SystemML binary-block representation,
specifying the number of rows and columns.
- Frame(Dataset<Row>) - Constructor for class org.apache.sysml.api.mlcontext.Frame
-
Convert a Spark DataFrame to a SystemML binary-block representation.
- Frame(JavaPairRDD<Long, FrameBlock>, FrameMetadata) - Constructor for class org.apache.sysml.api.mlcontext.Frame
-
Create a Frame, specifying the SystemML binary-block frame and its
metadata.
- FrameAppendMSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- FrameAppendMSPInstruction(Operator, CPOperand, CPOperand, CPOperand, CPOperand, boolean, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.FrameAppendMSPInstruction
-
- FrameAppendRSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- FrameAppendRSPInstruction(Operator, CPOperand, CPOperand, CPOperand, boolean, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.FrameAppendRSPInstruction
-
- FrameBlock - Class in org.apache.sysml.runtime.matrix.data
-
- FrameBlock() - Constructor for class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- FrameBlock(FrameBlock) - Constructor for class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Copy constructor for frame blocks, which uses a shallow copy for
the schema (column types and names) but a deep copy for meta data
and actual column data.
- FrameBlock(int, Expression.ValueType) - Constructor for class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- FrameBlock(Expression.ValueType[]) - Constructor for class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- FrameBlock(Expression.ValueType[], String[]) - Constructor for class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- FrameBlock(Expression.ValueType[], String[][]) - Constructor for class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- FrameBlock(Expression.ValueType[], String[], String[][]) - Constructor for class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- FrameBlock.ColumnMetadata - Class in org.apache.sysml.runtime.matrix.data
-
- frameBlockToFrameObject(String, FrameBlock, FrameMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a FrameBlock
to a FrameObject
.
- FrameFormat - Enum in org.apache.sysml.api.mlcontext
-
FrameFormat represents the different frame formats supported by the MLContext
API.
- FrameIndexingSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
This class implements the frame indexing functionality inside Spark.
- FrameIndexingSPInstruction(CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, AggBinaryOp.SparkAggType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.FrameIndexingSPInstruction
-
- FrameIndexingSPInstruction(CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.FrameIndexingSPInstruction
-
- FrameMetadata - Class in org.apache.sysml.api.mlcontext
-
Frame metadata, such as the number of rows, the number of columns, the number
of non-zero values, the number of rows per block, and the number of columns
per block in the frame.
- FrameMetadata() - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
- FrameMetadata(String) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on a string
representation of a frame schema.
- FrameMetadata(FrameFormat) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on frame format.
- FrameMetadata(FrameSchema) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on frame schema.
- FrameMetadata(FrameFormat, FrameSchema) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on frame format and
frame schema.
- FrameMetadata(FrameFormat, FrameSchema, Long, Long) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on frame format, frame
schema, the number of rows, and the number of columns in a frame.
- FrameMetadata(FrameFormat, FrameSchema, int, int) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on frame format, frame
schema, the number of rows, and the number of columns in a frame.
- FrameMetadata(FrameFormat, FrameSchema, Long, Long, Long, Integer, Integer) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on frame format, frame
schema, the number of rows, the number of columns, the number of non-zero
values, the number of rows per block, and the number of columns per block
in a frame.
- FrameMetadata(FrameFormat, FrameSchema, int, int, int, int, int) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on frame format, frame
schema, the number of rows, the number of columns, the number of non-zero
values, the number of rows per block, and the number of columns per block
in a frame.
- FrameMetadata(FrameFormat, Long, Long) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on frame format, the
number of rows, and the number of columns in a frame.
- FrameMetadata(FrameFormat, int, int) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on frame format, the
number of rows, and the number of columns in a frame.
- FrameMetadata(FrameFormat, Long, Long, Long) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on frame format, the
number of rows, the number of columns, and the number of non-zero values
in a frame.
- FrameMetadata(FrameFormat, int, int, int) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on frame format, the
number of rows, the number of columns, and the number of non-zero values
in a frame.
- FrameMetadata(FrameFormat, Long, Long, Long, Integer, Integer) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on frame format, the
number of rows, the number of columns, the number of non-zero values, the
number of rows per block, and the number of columns per block in a frame.
- FrameMetadata(FrameFormat, int, int, int, int, int) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on frame format, the
number of rows, the number of columns, the number of non-zero values, the
number of rows per block, and the number of columns per block in a frame.
- FrameMetadata(Long, Long) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on the number of rows
and the number of columns in a frame.
- FrameMetadata(int, int) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on the number of rows
and the number of columns in a frame.
- FrameMetadata(Long, Long, Long) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on the number of rows,
the number of columns, and the number of non-zero values in a frame.
- FrameMetadata(int, int, int) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on the number of rows,
the number of columns, and the number of non-zero values in a frame.
- FrameMetadata(Long, Long, Integer, Integer) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on the number of rows,
the number of columns, the number of rows per block, and the number of
columns per block in a frame.
- FrameMetadata(int, int, int, int) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on the number of rows,
the number of columns, the number of rows per block, and the number of
columns per block in a frame.
- FrameMetadata(Long, Long, Long, Integer, Integer) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on the number of rows,
the number of columns, the number of non-zero values, the number of rows
per block, and the number of columns per block in a frame.
- FrameMetadata(int, int, int, int, int) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on the number of rows,
the number of columns, the number of non-zero values, the number of rows
per block, and the number of columns per block in a frame.
- FrameMetadata(MatrixCharacteristics) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on a
MatrixCharacteristics object.
- FrameMetadata(FrameSchema, MatrixCharacteristics) - Constructor for class org.apache.sysml.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on the frame schema
and a MatrixCharacteristics object.
- frameObjectTo2DStringArray(FrameObject) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a two-dimensional string array.
- frameObjectToBinaryBlocks(FrameObject, SparkExecutionContext) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a JavaPairRDD<Long, FrameBlock>
.
- frameObjectToDataFrame(FrameObject, SparkExecutionContext) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a DataFrame
.
- frameObjectToJavaRDDStringCSV(FrameObject, String) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a JavaRDD<String>
in CSV format.
- frameObjectToJavaRDDStringIJV(FrameObject) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a JavaRDD<String>
in IJV format.
- frameObjectToListStringCSV(FrameObject, String) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a List<String>
in CSV format.
- frameObjectToListStringIJV(FrameObject) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a List<String>
in IJV format.
- frameObjectToRDDStringCSV(FrameObject, String) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a RDD<String>
in CSV format.
- frameObjectToRDDStringIJV(FrameObject) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a RDD<String>
in IJV format.
- FrameRDDAggregateUtils - Class in org.apache.sysml.runtime.instructions.spark.utils
-
- FrameRDDAggregateUtils() - Constructor for class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDAggregateUtils
-
- FrameRDDConverterUtils - Class in org.apache.sysml.runtime.instructions.spark.utils
-
- FrameRDDConverterUtils() - Constructor for class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- FrameRDDConverterUtils.LongFrameToLongWritableFrameFunction - Class in org.apache.sysml.runtime.instructions.spark.utils
-
- FrameRDDConverterUtils.LongWritableFrameToLongFrameFunction - Class in org.apache.sysml.runtime.instructions.spark.utils
-
- FrameRDDConverterUtils.LongWritableTextToLongTextFunction - Class in org.apache.sysml.runtime.instructions.spark.utils
-
- FrameRDDConverterUtils.LongWritableToSerFunction - Class in org.apache.sysml.runtime.instructions.spark.utils
-
- FrameSchema - Class in org.apache.sysml.api.mlcontext
-
The frame schema, stored as a list of ValueType
values.
- FrameSchema() - Constructor for class org.apache.sysml.api.mlcontext.FrameSchema
-
- FrameSchema(List<Expression.ValueType>) - Constructor for class org.apache.sysml.api.mlcontext.FrameSchema
-
Constructor that specifies the schema as a list of ValueType
values.
- FrameSchema(String) - Constructor for class org.apache.sysml.api.mlcontext.FrameSchema
-
Constructor that specifies the schema as a comma-separated string.
- free(Pointer) - Method in class org.apache.sysml.runtime.instructions.gpu.context.CudaMemoryAllocator
-
Frees memory on the device
- free(Pointer) - Method in interface org.apache.sysml.runtime.instructions.gpu.context.GPUMemoryAllocator
-
Frees memory on the device
- free(String, Pointer, boolean) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUMemoryManager
-
Deallocate the pointer
- free(Pointer) - Method in class org.apache.sysml.runtime.instructions.gpu.context.UnifiedMemoryAllocator
-
Frees memory on the device
- freeAllGPUContexts() - Static method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContextPool
-
Unreserves all GPUContexts
- fromFloatBuffer(FloatBuffer, double[]) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixNative
-
- fromIndexedFrameBlock(Pair<Long, FrameBlock>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- fromIndexedFrameBlock(List<Pair<Long, FrameBlock>>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- fromIndexedMatrixBlock(IndexedMatrixValue) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- fromIndexedMatrixBlock(List<IndexedMatrixValue>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- fromIndexedMatrixBlockToPair(IndexedMatrixValue) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- fromIndexedMatrixBlockToPair(List<IndexedMatrixValue>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- fun - Variable in class org.apache.sysml.udf.ExternalFunctionInvocationInstruction
-
- FunctionParameter - Class in org.apache.sysml.udf
-
abstract class to represent all input and output objects for package
functions.
- FunctionParameter(FunctionParameter.FunctionParameterType) - Constructor for class org.apache.sysml.udf.FunctionParameter
-
Constructor to set type
- FunctionParameter.FunctionParameterType - Enum in org.apache.sysml.udf
-
- gatherMemStats(boolean) - Method in class org.apache.sysml.api.jmlc.Connection
-
Sets a boolean flag indicating if memory profiling statistics should be
gathered.
- GatherWrapper - Class in org.apache.sysml.udf.lib
-
Wrapper class for conversions of bit vectors to condensed position vectors.
- GatherWrapper() - Constructor for class org.apache.sysml.udf.lib.GatherWrapper
-
- generateRandomMatrix(MatrixBlock, RandomMatrixGenerator, Well1024a, long) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDatagen
-
Function to generate a matrix of random numbers.
- generateRandomMatrix(MatrixBlock, RandomMatrixGenerator, Well1024a, long, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDatagen
-
Function to generate a matrix of random numbers.
- generateRuntimeProgram() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Create runtime program.
- generateSample(MatrixBlock, long, int, boolean, long) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDatagen
-
Generates a sample of size size
from a range of values [1,range].
- generateSequence(MatrixBlock, double, double, double) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDatagen
-
Method to generate a sequence according to the given parameters.
- generateUniqueSeedPath(String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDatagen
-
- genexec(double, SpoofOperator.SideInput[], double[], int, int, int, int) - Method in class org.apache.sysml.runtime.codegen.SpoofCellwise
-
- genexec(double, SpoofOperator.SideInput[], double[], int, int, long, int, int) - Method in class org.apache.sysml.runtime.codegen.SpoofCellwise
-
- genexec(double, SpoofOperator.SideInput[], double[], double[], int, int, int, int) - Method in class org.apache.sysml.runtime.codegen.SpoofMultiAggregate
-
- genexec(double, SpoofOperator.SideInput[], double[], double[], int, int, long, int, int) - Method in class org.apache.sysml.runtime.codegen.SpoofMultiAggregate
-
- genexec(double[], int, SpoofOperator.SideInput[], double[], double[], int, int, int) - Method in class org.apache.sysml.runtime.codegen.SpoofRowwise
-
- genexec(double[], int[], int, SpoofOperator.SideInput[], double[], double[], int, int, int, int) - Method in class org.apache.sysml.runtime.codegen.SpoofRowwise
-
- genexec(double[], int, SpoofOperator.SideInput[], double[], double[], int, int, long, int) - Method in class org.apache.sysml.runtime.codegen.SpoofRowwise
-
- genexec(double[], int[], int, SpoofOperator.SideInput[], double[], double[], int, int, int, long, int) - Method in class org.apache.sysml.runtime.codegen.SpoofRowwise
-
- genexecCellwise(double, double[], int, double[], int, SpoofOperator.SideInput[], double[], int, int, int, int, int) - Method in class org.apache.sysml.runtime.codegen.SpoofOuterProduct
-
- genexecDense(double, double[], int, double[], int, SpoofOperator.SideInput[], double[], double[], int, int, int, int, int, int) - Method in class org.apache.sysml.runtime.codegen.SpoofOuterProduct
-
- genOffsetBitmap(int[], int) - Static method in class org.apache.sysml.runtime.compress.BitmapEncoder
-
Encodes the bitmap in blocks of offsets.
- genRLEBitmap(int[], int) - Static method in class org.apache.sysml.runtime.compress.BitmapEncoder
-
Encodes the bitmap as a series of run lengths and offsets.
- get(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a serializable object as output
- get(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroup
-
Get the value at a global row/column position.
- get(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC
-
- get(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- get(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
- get(DblArray) - Method in class org.apache.sysml.runtime.compress.utils.DblArrayIntListHashMap
-
- get(double) - Method in class org.apache.sysml.runtime.compress.utils.DoubleIntListHashMap
-
- get(int, int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Get the value for a given row and column.
- get(int, int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- get(int, int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- get(int, int) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Gets a boxed object of the value in position (r,c).
- get(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Get value of matrix cell (r,c).
- get(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Get values of row r in the format of a sparse row.
- get(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- get(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- get(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- get(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- get(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- get(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- get(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
Gets the value of a specified column.
- get(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowScalar
-
- get(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- getActiveMLContext() - Static method in class org.apache.sysml.api.mlcontext.MLContext
-
Retrieve the currently active MLContext.
- getAggFunctions(SpoofCellwise.AggOp[]) - Static method in class org.apache.sysml.runtime.codegen.SpoofMultiAggregate
-
- getAggOp() - Method in class org.apache.sysml.runtime.codegen.SpoofCellwise
-
- getAggOps() - Method in class org.apache.sysml.runtime.codegen.SpoofMultiAggregate
-
- getAggregateOperator(SpoofCellwise.AggOp) - Static method in class org.apache.sysml.runtime.instructions.spark.SpoofSPInstruction
-
- getAlignedBlocksize(int) - Static method in class org.apache.sysml.runtime.compress.BitmapEncoder
-
- getAllPointers() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
- getArity() - Method in class org.apache.sysml.runtime.instructions.gpu.BuiltinUnaryGPUInstruction
-
- getAvailableCount() - Static method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContextPool
-
Get the number of free GPUContexts
- getAvailableMemory() - Method in class org.apache.sysml.runtime.instructions.gpu.context.CudaMemoryAllocator
-
Gets the available memory on GPU that SystemML can use.
- getAvailableMemory() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Gets the available memory on GPU that SystemML can use.
- getAvailableMemory() - Method in interface org.apache.sysml.runtime.instructions.gpu.context.GPUMemoryAllocator
-
Gets the available memory on GPU that SystemML can use.
- getAvailableMemory() - Method in class org.apache.sysml.runtime.instructions.gpu.context.UnifiedMemoryAllocator
-
Gets the available memory on GPU that SystemML can use.
- getBaseDir() - Method in class org.apache.sysml.udf.PackageFunction
-
- getBaseObject() - Method in class org.apache.sysml.runtime.matrix.data.Tagged
-
- getBasicTypeString(Object) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Obtain the SystemML scalar value type string equivalent of an accepted
basic type (Integer, Boolean, Double, String)
- getBclens() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getBeginColumn() - Method in class org.apache.sysml.runtime.instructions.Instruction
-
- getBeginLine() - Method in class org.apache.sysml.runtime.instructions.Instruction
-
- getBinaryAccessType(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixBincell
-
- getBitmapOffsets() - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- getBitmaps() - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- getBoolean(String) - Method in class org.apache.sysml.api.jmlc.ResultVariables
-
Obtain the boolean value represented by the given output variable.
- getBoolean(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a boolean
output
- getBrlens() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getCardinalityRatio() - Method in class org.apache.sysml.runtime.compress.cocode.PlanningCoCodingGroup
-
- getCellType() - Method in class org.apache.sysml.runtime.codegen.SpoofCellwise
-
- getChangeInSize() - Method in class org.apache.sysml.runtime.compress.cocode.PlanningCoCodingGroup
-
- getClass(String) - Static method in class org.apache.sysml.runtime.codegen.CodegenUtils
-
- getClass(String, byte[]) - Static method in class org.apache.sysml.runtime.codegen.CodegenUtils
-
- getClassData(String) - Static method in class org.apache.sysml.runtime.codegen.CodegenUtils
-
- getClassSync(String, byte[]) - Static method in class org.apache.sysml.runtime.codegen.CodegenUtils
-
- getClens() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getClosestK(int[], int) - Static method in class org.apache.sysml.runtime.compress.utils.LinearAlgebraUtils
-
Obtain the index of the closest element in a to the value x.
- getCM_N_COVObject() - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- getCode(int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC
-
- getCode(int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- getCode(int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- getColGroups() - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
Obtain the column groups.
- getColIndex(int) - Method in class org.apache.sysml.runtime.compress.ColGroup
-
Obtain a column index value.
- getColIndices() - Method in class org.apache.sysml.runtime.compress.cocode.PlanningCoCodingGroup
-
- getColIndices() - Method in class org.apache.sysml.runtime.compress.ColGroup
-
Obtain the offsets of the columns in the matrix block that make up the group
- getCols() - Method in class org.apache.sysml.runtime.instructions.spark.RandSPInstruction
-
- getCols() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- getColsInBlock() - Method in class org.apache.sysml.runtime.instructions.spark.RandSPInstruction
-
- getColsPerBlock() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- getColumn(int) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- getColumnData(int) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- getColumnIndex() - Method in class org.apache.sysml.runtime.matrix.data.MatrixIndexes
-
- getColumnIndex() - Method in class org.apache.sysml.runtime.matrix.data.PartialBlock
-
- getColumnMetadata() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- getColumnMetadata(int) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- getColumnName(int) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Returns the column name for the requested column.
- getColumnNameIDMap() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Creates a mapping from column names to column IDs, i.e.,
1-based column indexes
- getColumnNames() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Returns the column names of the frame block.
- getColumnNames(boolean) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Returns the column names of the frame block.
- getCompilerConfig() - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Get the compiler configuration object associated with
the prepared script instance.
- getCompressionStatistics() - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- getCompType() - Method in class org.apache.sysml.runtime.compress.ColGroup
-
Obtain the compression type.
- getCompType() - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- getCompType() - Method in class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- getCompType() - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
- getCompType() - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- getCompType() - Method in class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
- getConfig() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Obtain the SystemML configuration properties.
- getConfigForSimpleMatrixOperations(int, int) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.ExecutionConfig
-
Use this for simple vector operations and use following in the kernel
int index = blockIdx.x * blockDim.x + threadIdx.x
- getConfigForSimpleVectorOperations(int) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.ExecutionConfig
-
Use this for simple vector operations and use following in the kernel
int index = blockIdx.x * blockDim.x + threadIdx.x
- getConfiguration() - Method in class org.apache.sysml.udf.PackageFunction
-
Method to get the configuration file name
- getConstDim2() - Method in class org.apache.sysml.runtime.codegen.SpoofRowwise
-
- getConv2dBackwardDataWorkers(DnnParameters) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNConv2d
-
Factory method that returns list of callable tasks for performing conv2d backward data
- getConv2dBackwardFilterWorkers(DnnParameters) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNConv2d
-
Factory method that returns list of callable tasks for performing conv2d backward filter
- getConv2dWorkers(DnnParameters) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNConv2d
-
Factory method that returns list of callable tasks for performing conv2d
- getCounts(int[]) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- getCounts(int, int, int[]) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- getCounts(int[]) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- getCounts(int, int, int[]) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- getCounts(int[]) - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
- getCounts(int, int, int[]) - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
- getCounts(int[]) - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- getCounts(int, int, int[]) - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- getCounts() - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- getCounts(int[]) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- getCounts(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- getCounts(int, int, int[]) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- getCounts(boolean) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- getCountsAsBlock() - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- getCountsAsBlock(int[]) - Static method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- getCPType(String) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
- getCublasHandle() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Returns cublasHandle for BLAS operations on the GPU.
- getCublasHandle(GPUContext) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- getCudaKernels(GPUContext) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- getCudnnHandle() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Returns the cudnnHandle for Deep Neural Network operations on the GPU.
- getCudnnHandle(GPUContext) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNN
-
- getCurrentRowIndex() - Method in class org.apache.sysml.runtime.compress.ReaderColumnSelection
-
- getCurrentRowIndex() - Method in class org.apache.sysml.runtime.compress.ReaderColumnSelectionDenseSample
-
- getCusolverDnHandle() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Returns cusolverDnHandle for invoking solve() function on dense matrices on the GPU.
- getCusparseHandle() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Returns cusparseHandle for certain sparse BLAS operations on the GPU.
- getCusparseHandle(GPUContext) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- getData(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a Data
object.
- getData(int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC
-
Generic get value for byte-length-agnostic access
to first column.
- getData(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC
-
Generic get value for byte-length-agnostic access.
- getData(int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- getData(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- getData(int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- getData(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- getData() - Method in class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
Access for superclass
- getData() - Method in class org.apache.sysml.runtime.compress.utils.DblArray
-
- getDataFrame(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a DataFrame
.
- getDataFrame(String, boolean) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a DataFrame
of doubles or vectors with an ID
column.
- getDataFrameDoubleNoIDColumn(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a DataFrame
of doubles with no ID column.
- getDataFrameDoubleWithIDColumn(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a DataFrame
of doubles with an ID column.
- getDataFrameVectorNoIDColumn(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a DataFrame
of vectors with no ID column.
- getDataFrameVectorWithIDColumn(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a DataFrame
of vectors with an ID column.
- getDDCSize(int, int, int) - Static method in class org.apache.sysml.runtime.compress.estim.CompressedSizeEstimator
-
Estimates the number of bytes needed to encode this column group
in DDC1 or DDC2 format.
- getDDCSize() - Method in class org.apache.sysml.runtime.compress.estim.CompressedSizeInfo
-
- getDefaultCuSparseMatrixDescriptor() - Static method in class org.apache.sysml.runtime.instructions.gpu.context.CSRPointer
-
- getDenseBlock() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- getDenseBlockType(DenseBlock) - Static method in class org.apache.sysml.runtime.matrix.data.DenseBlockFactory
-
- getDenseBlockValues() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- getDenseMatrices(SpoofOperator.SideInput[]) - Static method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- getDenseMatrixOutputForGPUInstruction(ExecutionContext, String, long, long) - Method in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
Helper method to get the output block (allocated on the GPU)
Also records performance information into Statistics
- getDenseMatrixOutputForGPUInstruction(ExecutionContext, String, String, long, long) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Helper method to get the output block (allocated on the GPU)
Also records performance information into Statistics
- getDensePointer() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Pointer to dense matrix
- getDensePointer(GPUContext, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Convenience method to get jcudaDenseMatrixPtr.
- getDensePointerForCuDNN(GPUContext, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNN
-
Convenience method to get jcudaDenseMatrixPtr.
- getDensePointerForCuDNN(GPUContext, MatrixObject, String, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNN
-
Convenience method to get jcudaDenseMatrixPtr.
- getDenseRowIterator(int, int) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- getDenseVector(MatrixBlock) - Static method in class org.apache.sysml.runtime.compress.utils.ConverterUtils
-
- getDeviceCount() - Static method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContextPool
-
Number of available devices on this machine
- getDeviceNum() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Returns which device is assigned to this GPUContext instance.
- getDimsUnknownFilePrefix() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getDMLConfig() - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Get the dml configuration object associated with
the prepared script instance.
- getDmlProgram() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Obtain the program
- getDmlTranslator() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Obtain the translator
- getDouble(String) - Method in class org.apache.sysml.api.jmlc.ResultVariables
-
Obtain the double value represented by the given output variable.
- getDouble(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a double
output
- getEmptyBlockRDD(JavaSparkContext, MatrixCharacteristics) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
Creates an RDD of empty blocks according to the given matrix characteristics.
- getEndColumn() - Method in class org.apache.sysml.runtime.instructions.Instruction
-
- getEndLine() - Method in class org.apache.sysml.runtime.instructions.Instruction
-
- getEstCard() - Method in class org.apache.sysml.runtime.compress.estim.CompressedSizeInfo
-
- getEstNnz() - Method in class org.apache.sysml.runtime.compress.estim.CompressedSizeInfo
-
- getEstSize() - Method in class org.apache.sysml.runtime.compress.cocode.PlanningCoCodingGroup
-
Obtain estimated compressed size of the grouped columns.
- getExactSerializedSize() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- getExactSerializedSize() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- getExactSizeOnDisk() - Method in class org.apache.sysml.runtime.compress.ColGroup
-
Returns the exact serialized size of column group.
- getExactSizeOnDisk() - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- getExactSizeOnDisk() - Method in class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- getExactSizeOnDisk() - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- getExactSizeOnDisk() - Method in class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
- getExactSizeOnDisk() - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- getExactSizeOnDisk() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
NOTE: The used estimates must be kept consistent with the respective write functions.
- getExecType(String) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
- getExecutionContext() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Obtain the execution context
- getExecutionType() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Obtain the current execution environment.
- getExecutionType() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Obtain the current execution environment.
- getExplainType() - Method in enum org.apache.sysml.api.mlcontext.MLContext.ExplainLevel
-
- getExtendedOpcode() - Method in class org.apache.sysml.runtime.instructions.Instruction
-
- getExtraByPostition(int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixPackedCell
-
- getFilename() - Method in class org.apache.sysml.runtime.instructions.Instruction
-
- getFilePath() - Method in class org.apache.sysml.udf.Matrix
-
Method to get file path for matrix.
- getFirstIndex() - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes
-
- getFirstIndex() - Method in class org.apache.sysml.runtime.matrix.data.TripleIndexes
-
- getFormatProperties() - Method in class org.apache.sysml.runtime.instructions.spark.WriteSPInstruction
-
- getFrame(String) - Method in class org.apache.sysml.api.jmlc.ResultVariables
-
Obtain the frame represented by the given output variable.
- getFrame(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a Frame
.
- getFrameAs2DStringArray(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a two-dimensional String
array.
- getFrameBlock(String) - Method in class org.apache.sysml.api.jmlc.ResultVariables
-
Obtain the frame represented by the given output variable.
- getFrameFormat() - Method in class org.apache.sysml.api.mlcontext.FrameMetadata
-
Obtain the frame format
- getFrameMetadata() - Method in class org.apache.sysml.api.mlcontext.Frame
-
Obtain the frame metadata
- getFrameObject(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a FrameObject
- getFrameSchema() - Method in class org.apache.sysml.api.mlcontext.FrameMetadata
-
Obtain the frame schema
- getFunctionInput(int) - Method in class org.apache.sysml.udf.PackageFunction
-
Method to get a specific input to this package function.
- getFunctionOutput(int) - Method in class org.apache.sysml.udf.lib.BinningWrapper
-
- getFunctionOutput(int) - Method in class org.apache.sysml.udf.lib.CumSumProd
-
- getFunctionOutput(int) - Method in class org.apache.sysml.udf.lib.DynamicProjectMatrixCP
-
- getFunctionOutput(int) - Method in class org.apache.sysml.udf.lib.DynamicReadMatrixCP
-
- getFunctionOutput(int) - Method in class org.apache.sysml.udf.lib.DynamicReadMatrixRcCP
-
- getFunctionOutput(int) - Method in class org.apache.sysml.udf.lib.DynamicWriteMatrixCP
-
Deprecated.
- getFunctionOutput(int) - Method in class org.apache.sysml.udf.lib.EvalFunction
-
- getFunctionOutput(int) - Method in class org.apache.sysml.udf.lib.GatherWrapper
-
- getFunctionOutput(int) - Method in class org.apache.sysml.udf.lib.MultiInputCbind
-
- getFunctionOutput(int) - Method in class org.apache.sysml.udf.lib.OrderWrapper
-
Deprecated.
- getFunctionOutput(int) - Method in class org.apache.sysml.udf.lib.RemoveEmptyRows
-
Deprecated.
- getFunctionOutput(int) - Method in class org.apache.sysml.udf.lib.RowClassMeet
-
- getFunctionOutput(int) - Method in class org.apache.sysml.udf.lib.SGDNesterovUpdate
-
- getFunctionOutput(int) - Method in class org.apache.sysml.udf.lib.TimeWrapper
-
- getFunctionOutput(int) - Method in class org.apache.sysml.udf.PackageFunction
-
Method to get a specific output of this package function.
- getGPUInstructionType() - Method in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- getGPULazyCudaFreeMemoryManager() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUMemoryManager
-
- getGPUMatrixMemoryManager() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUMemoryManager
-
- getGPUProperties() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Gets the device properties for the active GPU (set with cudaSetDevice()).
- getGPUType(String) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
- getGraphString() - Method in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- getGraphString() - Method in class org.apache.sysml.runtime.instructions.Instruction
-
- getGraphString() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getGraphString() - Method in class org.apache.sysml.runtime.instructions.spark.SPInstruction
-
- getHopDAG(MLContext, Script, ArrayList<Integer>, boolean, boolean) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Get HOP DAG in dot format for a DML or PYDML Script.
- getHopDAG(MLContext, Script, ArrayList<Integer>, SparkConf, boolean, boolean) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Get HOP DAG in dot format for a DML or PYDML Script.
- getI() - Method in class org.apache.sysml.runtime.matrix.data.IJV
-
- getInitialValue(SpoofCellwise.AggOp) - Static method in class org.apache.sysml.runtime.codegen.SpoofMultiAggregate
-
- getInMemorySize() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- getInMemorySize() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- getInputInfo() - Method in class org.apache.sysml.runtime.matrix.MetaDataFormat
-
- getInputInfos() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getInputMatrices() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getInputMetadata() - Method in class org.apache.sysml.api.mlcontext.Script
-
Obtain an unmodifiable map of input matrix/frame metadata.
- getInputParameters() - Method in class org.apache.sysml.api.mlcontext.Script
-
Obtain an unmodifiable map of all input parameters ($).
- getInputs() - Method in class org.apache.sysml.api.mlcontext.Script
-
Obtain an unmodifiable map of all inputs (parameters ($) and variables).
- getInputs() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getInputVariables() - Method in class org.apache.sysml.api.mlcontext.Script
-
Obtain the input variable names as an unmodifiable set of strings.
- getInputVars() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getInstID() - Method in class org.apache.sysml.runtime.instructions.Instruction
-
Getter for instruction unique identifier
- getInstructionParts(String) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
Given an instruction string, strip-off the execution type and return
opcode and all input/output operands WITHOUT their data/value type.
- getInstructionPartsWithValueType(String) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
Given an instruction string, this function strips-off the
execution type (CP or MR) and returns the remaining parts,
which include the opcode as well as the input and output operands.
- getInternalProxy() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Used internally by MLContextProxy.
- getIterator(int, int, boolean, boolean) - Method in class org.apache.sysml.runtime.compress.ColGroup
-
Create a column group iterator for a row index range.
- getIterator(int, int, boolean, boolean) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC
-
- getIterator(int, int, boolean, boolean) - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- getIterator(int) - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- getIterator(int, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- getIterator(int) - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
- getIterator(int, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
- getIterator(int) - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- getIterator(int, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- getIterator(int, int, boolean, boolean) - Method in class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
- getIterator(int, int, boolean) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- getIterator(int, int, int, int, boolean) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- getIterator() - Method in class org.apache.sysml.runtime.matrix.data.CTableMap
-
- getIterator() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Get a non-zero iterator over the entire sparse block.
- getIterator(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Get a non-zero iterator over the partial sparse block [0,ru).
- getIterator(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Get a non-zero iterator over the subblock [rl, ru).
- getIterator() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- getIterator(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- getIterator(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- getIv_aggInstructions() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getIv_instructionsInMapper() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getIv_numReducers() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getIv_otherInstructions() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getIv_randInstructions() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getIv_recordReaderInstructions() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getIv_replication() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getIv_resultIndices() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getIv_shuffleInstructions() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getJ() - Method in class org.apache.sysml.runtime.matrix.data.IJV
-
- getJavaRDDStringCSV(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a JavaRDD<String>
in CSV format.
- getJavaRDDStringIJV(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a JavaRDD<String>
in IJV format.
- getJavaSparkContext(MLContext) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Obtain the Java Spark Context
- getJavaSparkContextFromProxy() - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Obtain the Java Spark Context from the MLContextProxy
- getJcudaSparseMatrixPtr() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Pointer to sparse matrix
- getJobType() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getKernels() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Returns utility class used to launch custom CUDA kernel, specific to the active GPU for this GPUContext.
- getKey() - Method in class org.apache.sysml.runtime.matrix.data.Pair
-
- getLeftGroup() - Method in class org.apache.sysml.runtime.compress.cocode.PlanningCoCodingGroup
-
- getLength() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- getLength() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- getLineNum() - Method in class org.apache.sysml.runtime.instructions.Instruction
-
Getter for instruction line number
- getLong(String) - Method in class org.apache.sysml.api.jmlc.ResultVariables
-
Obtain the long value represented by the given output variable.
- getLong(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a long
output
- getMatchingInputInfo(OutputInfo) - Static method in class org.apache.sysml.runtime.matrix.data.OutputInfo
-
- getMatchingOutputInfo(InputInfo) - Static method in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- getMatMultOperator(int) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
- getMatrix(String) - Method in class org.apache.sysml.api.jmlc.ResultVariables
-
Obtain the matrix represented by the given output variable.
- getMatrix(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a Matrix
.
- getMatrixAs2DDoubleArray(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a two-dimensional double
array.
- getMatrixAsDoubleArray() - Method in class org.apache.sysml.udf.Matrix
-
Method to get matrix as double array.
- getMatrixBlock(String) - Method in class org.apache.sysml.api.jmlc.ResultVariables
-
Obtain the matrix represented by the given output variable.
- getMatrixBlock() - Method in class org.apache.sysml.runtime.matrix.data.AdaptivePartialBlock
-
- getMatrixCharacteristics() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- getMatrixCharacteristics() - Method in class org.apache.sysml.runtime.matrix.MetaData
-
- getMatrixFormat() - Method in class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Obtain the matrix format
- getMatrixInputForGPUInstruction(ExecutionContext, String) - Method in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
Helper method to get the input block (allocated on the GPU)
Also records performance information into Statistics
- getMatrixMetadata() - Method in class org.apache.sysml.api.mlcontext.Matrix
-
Obtain the matrix metadata
- getMatrixObject(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a MatrixObject
- getMatrixObject() - Method in class org.apache.sysml.udf.Matrix
-
- getMaxBlocks() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Gets the maximum number of blocks supported by the active cuda device.
- getMaxColumn() - Method in class org.apache.sysml.runtime.matrix.data.CTableMap
-
- getMaxRow() - Method in class org.apache.sysml.runtime.matrix.data.CTableMap
-
- getMaxSharedMemory() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Gets the shared memory per block supported by the active cuda device.
- getMaxThreadsPerBlock() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Gets the maximum number of threads per block for "active" GPU.
- getMaxValue() - Method in class org.apache.sysml.runtime.instructions.spark.RandSPInstruction
-
- getMemoryManager() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
- getMemoryRequirements() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getMergedIndexes(int[], int[]) - Static method in class org.apache.sysml.runtime.compress.cocode.PlanningCoCodingGroup
-
- getMetaData() - Method in class org.apache.sysml.runtime.matrix.JobReturn
-
- getMetaData(int) - Method in class org.apache.sysml.runtime.matrix.JobReturn
-
- getMinSize() - Method in class org.apache.sysml.runtime.compress.estim.CompressedSizeInfo
-
- getMinValue() - Method in class org.apache.sysml.runtime.instructions.spark.RandSPInstruction
-
- getMMTSJType() - Method in class org.apache.sysml.runtime.instructions.gpu.MMTSJGPUInstruction
-
- getMRJobInstructionsLineNumbers() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
Getter for MRJobInstructionslineNumbers
- getMRString(boolean) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
Method for displaying MR instructions interspersed with source code
ONLY USED IN DEBUG MODE
- getMRType(String) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
- getMvValue() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock.ColumnMetadata
-
- getName() - Method in class org.apache.sysml.api.mlcontext.Script
-
Obtain the script name.
- getNnz(String, boolean) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Being allocated is a prerequisite for computing nnz.
- getNnz(GPUContext, String, MatrixObject, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Note: if the matrix is in dense format, it explicitly re-computes the number of nonzeros.
- getNonZeros(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- getNonZeros() - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- getNonZeros() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- getNonZeros() - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- getNonZeros() - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- getNonZeros() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- getNonZerosBound() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- getNthRow(int) - Method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNNInputRowFetcher
-
Copy the nth row and return the dense pointer
- getNumberOfZero() - Method in class org.apache.sysml.runtime.matrix.MetaDataNumItemsByEachReducer
-
- getNumBlocks() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- getNumColBlocks() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- getNumColGroups() - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- getNumCols() - Method in class org.apache.sysml.runtime.compress.ColGroup
-
Obtain the number of columns in this column group.
- getNumCols() - Method in class org.apache.sysml.udf.Matrix
-
Method to get the number of cols in the matrix.
- getNumColumns() - Method in class org.apache.sysml.api.mlcontext.Metadata
-
Obtain the number of columns
- getNumColumns() - Method in class org.apache.sysml.runtime.compress.UncompressedBitmap
-
- getNumColumns() - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- getNumColumns() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Get the number of columns of the frame block, that is
the number of columns defined in the schema.
- getNumColumns() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- getNumColumns() - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- getNumColumns() - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- getNumColumnsPerBlock() - Method in class org.apache.sysml.api.mlcontext.Metadata
-
Obtain the number of columns per block
- getNumDistinct() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock.ColumnMetadata
-
- getNumFunctionInputs() - Method in class org.apache.sysml.udf.PackageFunction
-
Method to get the number of inputs to this package function.
- getNumFunctionOutputs() - Method in class org.apache.sysml.udf.lib.BinningWrapper
-
- getNumFunctionOutputs() - Method in class org.apache.sysml.udf.lib.CumSumProd
-
- getNumFunctionOutputs() - Method in class org.apache.sysml.udf.lib.DynamicProjectMatrixCP
-
- getNumFunctionOutputs() - Method in class org.apache.sysml.udf.lib.DynamicReadMatrixCP
-
- getNumFunctionOutputs() - Method in class org.apache.sysml.udf.lib.DynamicReadMatrixRcCP
-
- getNumFunctionOutputs() - Method in class org.apache.sysml.udf.lib.DynamicWriteMatrixCP
-
Deprecated.
- getNumFunctionOutputs() - Method in class org.apache.sysml.udf.lib.EvalFunction
-
- getNumFunctionOutputs() - Method in class org.apache.sysml.udf.lib.GatherWrapper
-
- getNumFunctionOutputs() - Method in class org.apache.sysml.udf.lib.MultiInputCbind
-
- getNumFunctionOutputs() - Method in class org.apache.sysml.udf.lib.OrderWrapper
-
Deprecated.
- getNumFunctionOutputs() - Method in class org.apache.sysml.udf.lib.RemoveEmptyRows
-
Deprecated.
- getNumFunctionOutputs() - Method in class org.apache.sysml.udf.lib.RowClassMeet
-
- getNumFunctionOutputs() - Method in class org.apache.sysml.udf.lib.SGDNesterovUpdate
-
- getNumFunctionOutputs() - Method in class org.apache.sysml.udf.lib.TimeWrapper
-
- getNumFunctionOutputs() - Method in class org.apache.sysml.udf.PackageFunction
-
Method to get the number of outputs of this package function.
- getNumIntermediates() - Method in class org.apache.sysml.runtime.codegen.SpoofRowwise
-
- getNumItemsArray() - Method in class org.apache.sysml.runtime.matrix.MetaDataNumItemsByEachReducer
-
- getNumNonZeros() - Method in class org.apache.sysml.api.mlcontext.Metadata
-
Obtain the number of non-zero values
- getNumOffsets() - Method in class org.apache.sysml.runtime.compress.UncompressedBitmap
-
- getNumOffsets(int) - Method in class org.apache.sysml.runtime.compress.UncompressedBitmap
-
- getNumPointers() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
Get total number of rmvared pointers
- getNumPreferredPartitions(MatrixCharacteristics, JavaPairRDD<?, ?>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- getNumPreferredPartitions(MatrixCharacteristics) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- getNumReplicas(MatrixCharacteristics, MatrixCharacteristics, boolean) - Method in class org.apache.sysml.runtime.instructions.spark.BinarySPInstruction
-
- getNumRowBlocks() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- getNumRows() - Method in class org.apache.sysml.api.mlcontext.Metadata
-
Obtain the number of rows
- getNumRows() - Method in class org.apache.sysml.runtime.compress.ColGroup
-
- getNumRows() - Method in class org.apache.sysml.runtime.compress.estim.CompressedSizeEstimator
-
- getNumRows() - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- getNumRows() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Get the number of rows of the frame block.
- getNumRows() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- getNumRows() - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- getNumRows() - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- getNumRows() - Method in class org.apache.sysml.udf.Matrix
-
Method to get the number of rows in the matrix.
- getNumRowsPerBlock() - Method in class org.apache.sysml.api.mlcontext.Metadata
-
Obtain the number of rows per block
- getNumValues() - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
Obtain number of distinct sets of values associated with the bitmaps in this column group.
- getNumValues() - Method in class org.apache.sysml.runtime.compress.UncompressedBitmap
-
Obtain number of distinct values in the column.
- getObject() - Method in class org.apache.sysml.udf.BinaryObject
-
Method to retrieve object.
- getObjectRowIterator() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Get a row iterator over the frame where all fields are encoded
as boxed objects according to their value types.
- getObjectRowIterator(Expression.ValueType[]) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Get a row iterator over the frame where all fields are encoded
as boxed objects according to the value types of the provided
target schema.
- getObjectRowIterator(int[]) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Get a row iterator over the frame where all selected fields are
encoded as boxed objects according to their value types.
- getObjectRowIterator(int, int) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Get a row iterator over the frame where all fields are encoded
as boxed objects according to their value types.
- getObjectRowIterator(int, int, int[]) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Get a row iterator over the frame where all selected fields are
encoded as boxed objects according to their value types.
- getOffsetsList(int) - Method in class org.apache.sysml.runtime.compress.UncompressedBitmap
-
- getOLESize(int, float, int, int) - Static method in class org.apache.sysml.runtime.compress.estim.CompressedSizeEstimator
-
Estimates the number of bytes needed to encode this column group
in OLE format.
- getOLESize() - Method in class org.apache.sysml.runtime.compress.estim.CompressedSizeInfo
-
- getOpcode() - Method in class org.apache.sysml.runtime.instructions.Instruction
-
- getOpCode(String) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
- getOptChangeInSize() - Method in class org.apache.sysml.runtime.compress.cocode.PlanningMemoTable
-
- getOrCreate(PlanningCoCodingGroup, PlanningCoCodingGroup, CompressedSizeEstimator, int) - Method in class org.apache.sysml.runtime.compress.cocode.PlanningMemoTable
-
- getOtherValue() - Method in class org.apache.sysml.runtime.matrix.data.WeightedPair
-
- getOuterProdType() - Method in class org.apache.sysml.runtime.codegen.SpoofOuterProduct
-
- getOutputInfo() - Method in class org.apache.sysml.runtime.matrix.MetaDataFormat
-
- getOutputInfos() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getOutputMatrices() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getOutputs() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getOutputVariableName() - Method in class org.apache.sysml.runtime.instructions.spark.ComputationSPInstruction
-
- getOutputVariables() - Method in class org.apache.sysml.api.mlcontext.Script
-
Obtain the output variable names as an unmodifiable set of strings.
- getOutputVars() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getParams() - Method in class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction
-
- getPartialBlock() - Method in class org.apache.sysml.runtime.matrix.data.AdaptivePartialBlock
-
- getPartition(TaggedFirstSecondIndexes, Writable, int) - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes.FirstIndexPartitioner
-
- getPartition(TaggedFirstSecondIndexes, Writable, int) - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes.FirstIndexRangePartitioner
-
- getPartition(TaggedFirstSecondIndexes, MatrixValue, int) - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes.TagPartitioner
-
- getPartition(TripleIndexes, TaggedMatrixValue, int) - Method in class org.apache.sysml.runtime.matrix.data.TripleIndexes.FirstTwoIndexesPartitioner
-
- getPartitioned() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getPartitionOfZero() - Method in class org.apache.sysml.runtime.matrix.MetaDataNumItemsByEachReducer
-
- getPformats() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getPoolingBackwardWorkers(DnnParameters, boolean, LibMatrixDNN.PoolingType) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNPooling
-
Factory method that returns list of callable tasks for performing maxpooling backward operation
- getPoolingWorkers(DnnParameters, LibMatrixDNN.PoolingType) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNPooling
-
Factory method that returns list of callable tasks for performing pooling operation
- getPrefixFromSparkDebugInfo(String) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- getProjectInfo() - Static method in class org.apache.sysml.api.mlcontext.ProjectInfo
-
Return a ProjectInfo singleton instance.
- getPsizes() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getRDDStringCSV(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a RDD<String>
in CSV format.
- getRDDStringIJV(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a RDD<String>
in IJV format.
- getRecodeMap(int) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
This function will split every Recode map in the column using delimiter Lop.DATATYPE_PREFIX,
as Recode map generated earlier in the form of Code+Lop.DATATYPE_PREFIX+Token and store it in a map
which contains token and code for every unique tokens.
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.sysml.runtime.matrix.data.UnPaddedOutputFormat
-
- getReluBackwardWorkers(DnnParameters) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNRelu
-
Factory method that returns list of callable tasks for performing relu backward operation
- getResults() - Method in class org.apache.sysml.api.mlcontext.Script
-
Obtain the results of the script execution.
- getRightGroup() - Method in class org.apache.sysml.runtime.compress.cocode.PlanningCoCodingGroup
-
- getRlens() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getRLESize(int, int, int) - Static method in class org.apache.sysml.runtime.compress.estim.CompressedSizeEstimator
-
Estimates the number of bytes needed to encode this column group
in RLE encoding format.
- getRLESize() - Method in class org.apache.sysml.runtime.compress.estim.CompressedSizeInfo
-
- getRmvarPointer(String, long) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
Get any pointer of the given size from rmvar-ed pointers (applicable if eager cudaFree is set to false)
- getRmvarPointerMinSize(String, long) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
- getRowIndex() - Method in class org.apache.sysml.runtime.matrix.data.MatrixIndexes
-
- getRowIndex() - Method in class org.apache.sysml.runtime.matrix.data.PartialBlock
-
- getRowIterator(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroup
-
Create a dense row iterator for a row index range.
- getRowIterator(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC
-
- getRowIterator(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
- getRowIterator(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- getRowIterator(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
- getRows() - Method in class org.apache.sysml.runtime.instructions.spark.RandSPInstruction
-
- getRows() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
Helper function for MCSR -> {COO, CSR}
- getRows() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- getRowsInBlock() - Method in class org.apache.sysml.runtime.instructions.spark.RandSPInstruction
-
- getRowsPerBlock() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- getRowType() - Method in class org.apache.sysml.runtime.codegen.SpoofRowwise
-
- getRuntimePlatform() - Method in enum org.apache.sysml.api.mlcontext.MLContext.ExecutionType
-
- getRuntimeProgram() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Obtain the runtime program
- getScalarObject(String) - Method in class org.apache.sysml.api.jmlc.ResultVariables
-
Obtain the ScalarObject represented by the given output variable.
- getScalarObject(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a Scalar
object.
- getScalarType() - Method in class org.apache.sysml.udf.Scalar
-
Method to get type of scalar.
- getSchema() - Method in class org.apache.sysml.api.mlcontext.FrameSchema
-
Obtain the frame schema
- getSchema() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Returns the schema of the frame block.
- getSchemaAsString() - Method in class org.apache.sysml.api.mlcontext.FrameSchema
-
Obtain the schema as a comma-separated string
- getScript() - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain the Script object associated with these results.
- getScript() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Obtain the Script object associated with this ScriptExecutor
- getScriptExecutionString() - Method in class org.apache.sysml.api.mlcontext.Script
-
Generate the script execution string, which adds read/load/write/save
statements to the beginning and end of the script to execute.
- getScriptExecutor() - Method in class org.apache.sysml.api.mlcontext.Script
-
Obtain the script executor used by this Script.
- getScriptString() - Method in class org.apache.sysml.api.mlcontext.Script
-
Obtain the script string.
- getScriptType() - Method in class org.apache.sysml.api.mlcontext.Script
-
Obtain the script type.
- getSecondIndex() - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes
-
- getSecondIndex() - Method in class org.apache.sysml.runtime.matrix.data.TripleIndexes
-
- getSizeAllocatedGPUPointer(Pointer) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUMemoryManager
-
Get size of allocated GPU Pointer
- getSizeEstimator(MatrixBlock, int) - Static method in class org.apache.sysml.runtime.compress.estim.SizeEstimatorFactory
-
- getSizeOnDevice() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- getSparkContext(MLContext) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Obtain the Spark Context
- getSparkContextFromProxy() - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Obtain the Spark Context from the MLContextProxy
- getSparkSession() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Obtain the SparkSession associated with this MLContext.
- getSparkSessionFromProxy() - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Obtain the Spark Session from the MLContextProxy
- getSparseBlock() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- getSparseBlockIterator() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- getSparseBlockIterator(int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- getSparseBlockType(SparseBlock) - Static method in class org.apache.sysml.runtime.matrix.data.SparseBlockFactory
-
- getSparseMatrixCudaPointer() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Convenience method to directly examine the Sparse matrix on GPU
- getSparsePointer(GPUContext, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Convenience method to get the sparse matrix pointer from a MatrixObject
.
- getSparseRowIterator(int, int) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- getSparsity() - Method in class org.apache.sysml.runtime.instructions.spark.RandSPInstruction
-
- getSparsity() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- getSparsity() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- getSPInstructionType() - Method in class org.apache.sysml.runtime.instructions.spark.SPInstruction
-
- getSpoofType() - Method in class org.apache.sysml.runtime.codegen.SpoofCellwise
-
- getSpoofType() - Method in class org.apache.sysml.runtime.codegen.SpoofMultiAggregate
-
- getSpoofType() - Method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- getSpoofType() - Method in class org.apache.sysml.runtime.codegen.SpoofOuterProduct
-
- getSpoofType() - Method in class org.apache.sysml.runtime.codegen.SpoofRowwise
-
- getSPType(String) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
- getStartLineFromSparkDebugInfo(String) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- getStatisticsMaxHeavyHitters() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Obtain the maximum number of heavy hitters that are printed out as part
of the statistics.
- getStats() - Method in class org.apache.sysml.runtime.compress.cocode.PlanningMemoTable
-
- getString(String) - Method in class org.apache.sysml.api.jmlc.ResultVariables
-
Obtain the string value represented by the given output variable.
- getString(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a String
output
- getString(byte[]) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getStringRowIterator() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Get a row iterator over the frame where all fields are encoded
as strings independent of their value types.
- getStringRowIterator(int[]) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Get a row iterator over the frame where all selected fields are
encoded as strings independent of their value types.
- getStringRowIterator(int, int) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Get a row iterator over the frame where all fields are encoded
as strings independent of their value types.
- getStringRowIterator(int, int, int[]) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Get a row iterator over the frame where all selected fields are
encoded as strings independent of their value types.
- getSymbolTable() - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain the symbol table, which is essentially a Map<String, Data>
representing variables and their values as SystemML representations.
- getSymbolTable() - Method in class org.apache.sysml.api.mlcontext.Script
-
Obtain the symbol table, which is essentially a
HashMap<String, Data>
representing variables and their values.
- getTag() - Method in class org.apache.sysml.runtime.matrix.data.Tagged
-
- getTag() - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes
-
- getThirdIndex() - Method in class org.apache.sysml.runtime.matrix.data.TaggedTripleIndexes
-
- getThirdIndex() - Method in class org.apache.sysml.runtime.matrix.data.TripleIndexes
-
- getTotalInputNnz(ArrayList<MatrixBlock>) - Static method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- getTotalInputSize(ArrayList<MatrixBlock>) - Static method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- getTotalMemoryAllocated() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
Return the total memory in bytes used by this memory manager
- getTuple(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String, String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String, String, String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String, String, String, String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String, String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getType() - Method in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- getType() - Method in class org.apache.sysml.runtime.instructions.Instruction
-
- getType() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getType() - Method in class org.apache.sysml.runtime.instructions.spark.SPInstruction
-
- getType() - Method in class org.apache.sysml.udf.ExternalFunctionInvocationInstruction
-
- getType() - Method in class org.apache.sysml.udf.FunctionParameter
-
Method to get type
- getUncompressedColBlock(ColGroup) - Static method in class org.apache.sysml.runtime.compress.utils.ConverterUtils
-
- getUUID() - Static method in class org.apache.sysml.api.DMLScript
-
- getV() - Method in class org.apache.sysml.runtime.matrix.data.IJV
-
- getValue(double[], double) - Static method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- getValue(double[], int) - Static method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- getValue(double[], int, double, double) - Static method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- getValue(double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- getValue(double[], int[], int, int, double) - Static method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- getValue(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- getValue(SpoofOperator.SideInput, double) - Static method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- getValue(SpoofOperator.SideInput, int) - Static method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- getValue(SpoofOperator.SideInput, int, double, double) - Static method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- getValue(SpoofOperator.SideInput, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- getValue(int, int) - Method in class org.apache.sysml.runtime.codegen.SpoofOperator.SideInput
-
- getValue(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- getValue(int, int) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- getValue(int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- getValue() - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- getValue(int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- getValue(int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- getValue() - Method in class org.apache.sysml.runtime.matrix.data.Pair
-
- getValue() - Method in class org.apache.sysml.runtime.matrix.data.PartialBlock
-
- getValue() - Method in class org.apache.sysml.runtime.matrix.data.WeightedCell
-
- getValue() - Method in class org.apache.sysml.udf.Scalar
-
Method to get value for scalar.
- getValueDenseUnsafe(int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- getValues() - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- getValues() - Method in class org.apache.sysml.runtime.compress.UncompressedBitmap
-
Get all values without unnecessary allocations and copies.
- getValues(int) - Method in class org.apache.sysml.runtime.compress.UncompressedBitmap
-
Obtain tuple of column values associated with index.
- getValuesAsBlock() - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- getValuesSize() - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- getValueType() - Method in class org.apache.sysml.udf.Matrix
-
Method to get value type for this matrix.
- getVariableNames() - Method in class org.apache.sysml.api.jmlc.ResultVariables
-
Obtain the output variable names held by this ResultVariables object.
- getVector(SpoofOperator.SideInput, int, double, double) - Static method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- getVector(SpoofOperator.SideInput, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.SpoofOperator
-
- getWarpSize() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Gets the warp size supported by the active cuda device.
- getWeight() - Method in class org.apache.sysml.runtime.matrix.data.WeightedCell
-
- getWorker(MatrixBlock, MatrixBlock, DnnParameters, boolean, boolean) - Static method in interface org.apache.sysml.runtime.matrix.data.LibMatrixDNNRotate180.Rotate180Worker
-
- GMR - Class in org.apache.sysml.runtime.matrix
-
- gpu - Variable in class org.apache.sysml.api.DMLOptions
-
- gpu - Variable in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- GPU_EVICTION_POLICY - Static variable in class org.apache.sysml.api.DMLScript
-
- GPU_INST_PREFIX - Static variable in class org.apache.sysml.runtime.instructions.Instruction
-
- GPU_MEMORY_ALLOCATOR - Static variable in class org.apache.sysml.api.DMLScript
-
- GPU_MEMORY_UTILIZATION_FACTOR - Static variable in class org.apache.sysml.api.DMLScript
-
- GPUContext - Class in org.apache.sysml.runtime.instructions.gpu.context
-
Represents a context per GPU accessible through the same JVM.
- GPUContext(int) - Constructor for class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
- GPUContextPool - Class in org.apache.sysml.runtime.instructions.gpu.context
-
- GPUContextPool() - Constructor for class org.apache.sysml.runtime.instructions.gpu.context.GPUContextPool
-
- GPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- GPUInstruction(Operator, String, String) - Constructor for class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- GPUInstruction.GPUINSTRUCTION_TYPE - Enum in org.apache.sysml.runtime.instructions.gpu
-
- GPUInstructionParser - Class in org.apache.sysml.runtime.instructions
-
- GPUInstructionParser() - Constructor for class org.apache.sysml.runtime.instructions.GPUInstructionParser
-
- GPULazyCudaFreeMemoryManager - Class in org.apache.sysml.runtime.instructions.gpu.context
-
- GPULazyCudaFreeMemoryManager(GPUMemoryManager) - Constructor for class org.apache.sysml.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
- GPUMatrixMemoryManager - Class in org.apache.sysml.runtime.instructions.gpu.context
-
- GPUMatrixMemoryManager(GPUMemoryManager) - Constructor for class org.apache.sysml.runtime.instructions.gpu.context.GPUMatrixMemoryManager
-
- GPUMemoryAllocator - Interface in org.apache.sysml.runtime.instructions.gpu.context
-
- GPUMemoryManager - Class in org.apache.sysml.runtime.instructions.gpu.context
-
- All cudaFree and cudaMalloc in SystemML should go through this class to avoid OOM or incorrect results.
- GPUMemoryManager(GPUContext) - Constructor for class org.apache.sysml.runtime.instructions.gpu.context.GPUMemoryManager
-
- GPUMemoryManager.EvictionPolicyBasedComparator - Class in org.apache.sysml.runtime.instructions.gpu.context
-
Class that governs the eviction policy
- GPUObject - Class in org.apache.sysml.runtime.instructions.gpu.context
-
Handle to a matrix block on the GPU
- gridDimX - Variable in class org.apache.sysml.runtime.instructions.gpu.context.ExecutionConfig
-
- gridDimY - Variable in class org.apache.sysml.runtime.instructions.gpu.context.ExecutionConfig
-
- gridDimZ - Variable in class org.apache.sysml.runtime.instructions.gpu.context.ExecutionConfig
-
- GroupableColInfo(double, long) - Constructor for class org.apache.sysml.runtime.compress.cocode.PlanningCoCoder.GroupableColInfo
-
- GroupedAggMR - Class in org.apache.sysml.runtime.matrix
-
- groupedAggOperations(MatrixValue, MatrixValue, MatrixValue, int, Operator) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- groupedAggOperations(MatrixValue, MatrixValue, MatrixValue, int, Operator, int) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- groupedAggOperations(MatrixValue, MatrixValue, MatrixValue, int, Operator) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Invocation from CP instructions.
- groupedAggOperations(MatrixValue, MatrixValue, MatrixValue, int, Operator, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- groupedAggregate(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, int, Operator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixAgg
-
- groupedAggregate(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, int, Operator, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixAgg
-
- IdenticalConverter - Class in org.apache.sysml.runtime.matrix.data
-
- IdenticalConverter() - Constructor for class org.apache.sysml.runtime.matrix.data.IdenticalConverter
-
- iinfo - Variable in class org.apache.sysml.udf.ExternalFunctionInvocationInstruction
-
- IJV - Class in org.apache.sysml.runtime.matrix.data
-
Helper class for external key/value exchange.
- IJV() - Constructor for class org.apache.sysml.runtime.matrix.data.IJV
-
- im2col(MatrixBlock, MatrixBlock, int, DnnParameters, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNIm2Col
-
- im2col(MatrixBlock, MatrixBlock, int, int, int, int, int, int, int, int, int, int, int, int, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNIm2Col
-
- im2colDense(double[], double[], int, int, int, int, int, int, int, int, int, int, int, int, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNIm2Col
-
- im2colDenseStride1Pad0(double[], double[], int, int, int, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNIm2Col
-
- im2colSparse(MatrixBlock, MatrixBlock, int, int, int, int, int, int, int, int, int, int, int, int, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNIm2Col
-
- in(Map<String, Object>) - Method in class org.apache.sysml.api.mlcontext.Script
-
Pass a map of inputs to the script.
- in(Map<String, ?>) - Method in class org.apache.sysml.api.mlcontext.Script
-
Pass a Scala Map of inputs to the script.
- in(Seq<Object>) - Method in class org.apache.sysml.api.mlcontext.Script
-
Pass a Scala Seq of inputs to the script.
- in(String, Object) - Method in class org.apache.sysml.api.mlcontext.Script
-
Register an input (parameter ($) or variable).
- in(String, Object, Metadata) - Method in class org.apache.sysml.api.mlcontext.Script
-
Register an input (parameter ($) or variable) with optional matrix
metadata.
- incr(int, int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Increments the given value for a given row and column.
- incr(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Increments the given value for a given row and column
by delta.
- incr(int, int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- incr(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- incr(int, int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- incr(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- incrementalAggregate(AggregateOperator, MatrixValue, MatrixValue, boolean) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- incrementalAggregate(AggregateOperator, MatrixValue) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- incrementalAggregate(AggregateOperator, MatrixValue, MatrixValue, boolean) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- incrementalAggregate(AggregateOperator, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- incrementalAggregate(AggregateOperator, MatrixValue, MatrixValue, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- incrementalAggregate(AggregateOperator, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- incrementalAggregate(AggregateOperator, MatrixValue, MatrixValue, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- incrementalAggregate(AggregateOperator, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- incrementalAggregate(AggregateOperator, MatrixValue, MatrixValue, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixPackedCell
-
- incrementalAggregate(AggregateOperator, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.MatrixPackedCell
-
- incrementalAggregate(AggregateOperator, MatrixValue, MatrixValue, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- incrementalAggregate(AggregateOperator, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- incrementalAggregation(MatrixValue, MatrixValue, MatrixValue, AggregateOperator, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.OperationsOnMatrixValues
-
- incrementalAggregation(MatrixValue, MatrixValue, MatrixValue, AggregateOperator, boolean, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.OperationsOnMatrixValues
-
- incrStats(int, int, int) - Method in class org.apache.sysml.runtime.compress.cocode.PlanningMemoTable
-
- index(int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Get the block index for a given row.
- index(int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- index(int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- IndexComparator(boolean) - Constructor for class org.apache.sysml.runtime.instructions.spark.utils.RDDSortUtils.IndexComparator
-
- IndexComparator2(boolean) - Constructor for class org.apache.sysml.runtime.instructions.spark.utils.RDDSortUtils.IndexComparator2
-
- indexes(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Get the sorted array of column indexes of all non-zero entries in
row r.
- indexes(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- indexes() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
Get raw access to underlying array of column indices
For use in GPU code
- indexes() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
Get raw access to underlying array of column indices
For use in GPU code
- indexes(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- indexes(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- indexes() - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
Get the index array of non-zero entries, co-aligned
with the array of values.
- indexes() - Method in class org.apache.sysml.runtime.matrix.data.SparseRowScalar
-
- indexes() - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- indexInBlock - Variable in class org.apache.sysml.runtime.matrix.CSVReblockMR.BlockRow
-
- IndexingSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
This class implements the matrix indexing functionality inside Spark.
- IndexingSPInstruction(CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, AggBinaryOp.SparkAggType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.IndexingSPInstruction
-
- IndexingSPInstruction(CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.IndexingSPInstruction
-
- info() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Obtain information about the project such as version and build time from
the manifest in the SystemML jar file.
- info() - Method in class org.apache.sysml.api.mlcontext.Script
-
Display information about the script as a String.
- init - Variable in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- init(double[][], int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
NOTE: This method is designed only for dense representation.
- init(double[], int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
NOTE: This method is designed only for dense representation.
- init(RandomMatrixGenerator.PDF, int, int, int, int, double, double, double) - Method in class org.apache.sysml.runtime.matrix.data.RandomMatrixGenerator
-
Initializes internal data structures.
- init(RandomMatrixGenerator.PDF, int, int, int, int, double, double, double, double) - Method in class org.apache.sysml.runtime.matrix.data.RandomMatrixGenerator
-
Instantiates a Random number generator with a specific poisson mean
- INIT_CAPACITY - Static variable in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
- initHadoopExecution(DMLConfig) - Static method in class org.apache.sysml.api.DMLScript
-
- initialCapacity - Static variable in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- initialGPUMemBudget() - Static method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContextPool
-
Gets the initial GPU memory budget.
- initializeCachingAndScratchSpace() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Check security, create scratch space, cleanup working directories,
initialize caching, and reset statistics.
- initializeGPU() - Static method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContextPool
-
Static initialization of the number of devices
Also sets behaviour for J{Cuda, Cudnn, Cublas, Cusparse} in case of error
Initializes the CUDA driver
All these need be done once, and not per GPU
- initializeThread() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Sets the device for the calling thread.
- initSparse(int, int, DataInput) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
Initializes the CSR sparse block from an ordered input
stream of sparse rows (rownnz, jv-pairs*).
- initUltraSparse(int, DataInput) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
Initializes the CSR sparse block from an ordered input
stream of ultra-sparse ijv triples.
- inmemoryIndexing(JavaPairRDD<MatrixIndexes, MatrixBlock>, MatrixCharacteristics, MatrixCharacteristics, IndexRange) - Static method in class org.apache.sysml.runtime.instructions.spark.MatrixIndexingSPInstruction
-
- InnerReducer() - Constructor for class org.apache.sysml.runtime.matrix.CombineMR.InnerReducer
-
- input1 - Variable in class org.apache.sysml.runtime.instructions.spark.ComputationSPInstruction
-
- input1 - Variable in class org.apache.sysml.runtime.matrix.data.DnnParameters
-
- input2 - Variable in class org.apache.sysml.runtime.instructions.spark.ComputationSPInstruction
-
- input2 - Variable in class org.apache.sysml.runtime.matrix.data.DnnParameters
-
- input3 - Variable in class org.apache.sysml.runtime.instructions.spark.ComputationSPInstruction
-
- inputFormatClass - Variable in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- InputInfo - Class in org.apache.sysml.runtime.matrix.data
-
- InputInfo(Class<? extends InputFormat>, Class<? extends Writable>, Class<? extends Writable>) - Constructor for class org.apache.sysml.runtime.matrix.data.InputInfo
-
- InputInfoForSort - Static variable in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- InputInfoForSortOutput - Static variable in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- inputInfoToString(InputInfo) - Static method in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- inputKeyClass - Variable in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- inputs - Variable in class org.apache.sysml.udf.ExternalFunctionInvocationInstruction
-
- inputValueClass - Variable in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- instOpcode - Variable in class org.apache.sysml.runtime.instructions.Instruction
-
- Instruction - Class in org.apache.sysml.runtime.instructions
-
- Instruction() - Constructor for class org.apache.sysml.runtime.instructions.Instruction
-
- Instruction.IType - Enum in org.apache.sysml.runtime.instructions
-
- INSTRUCTION_DELIM - Static variable in class org.apache.sysml.runtime.instructions.Instruction
-
- InstructionParser - Class in org.apache.sysml.runtime.instructions
-
- InstructionParser() - Constructor for class org.apache.sysml.runtime.instructions.InstructionParser
-
- InstructionUtils - Class in org.apache.sysml.runtime.instructions
-
- InstructionUtils() - Constructor for class org.apache.sysml.runtime.instructions.InstructionUtils
-
- instString - Variable in class org.apache.sysml.runtime.instructions.Instruction
-
- IntArrayList - Class in org.apache.sysml.runtime.compress.utils
-
This class provides a memory-efficient replacement for ArrayList<Integer>
for
restricted use cases.
- IntArrayList() - Constructor for class org.apache.sysml.runtime.compress.utils.IntArrayList
-
- IntArrayList(int) - Constructor for class org.apache.sysml.runtime.compress.utils.IntArrayList
-
- intDiv(double, double) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- InternalProxy() - Constructor for class org.apache.sysml.api.mlcontext.MLContext.InternalProxy
-
- interQuartileMean() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- INVESTIGATE_ESTIMATES - Static variable in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- isActiveAM() - Static method in class org.apache.sysml.api.DMLScript
-
- isAligned(SparseBlock) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Indicates if all non-zero values are aligned with the given
second sparse block instance, which can be exploited for
more efficient operations.
- isAligned(int, SparseBlock) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Indicates if all non-zero values of row r are aligned with
the same row of the given second sparse block instance, which
can be exploited for more efficient operations.
- isAllocated() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- isAllocated() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- isAllocated(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Indicates if the underlying data structure for a given row
is already allocated.
- isAllocated(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- isAllocated(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- isAllocated(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- isAllOnes(Integer...) - Method in class org.apache.sysml.runtime.matrix.data.DnnParameters
-
- isBasicType(Object) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Is the object one of the supported basic data types? (Integer, Boolean,
Double, String)
- isBlocked() - Method in class org.apache.sysml.runtime.matrix.data.AdaptivePartialBlock
-
- isBuffered() - Method in class org.apache.sysml.runtime.instructions.gpu.context.ShadowBuffer
-
Check if the gpu object is shadow buffered
- isBuiltinFunction(String) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
- isColNameDefault(int) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- isColNamesDefault() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- isColumnAgg() - Method in enum org.apache.sysml.runtime.codegen.SpoofRowwise.RowType
-
- isColumnMetadataDefault() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- isColumnMetadataDefault(int) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- isCompareOperator(BinaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixOuterAgg
-
This will return if uaggOp is of type RowIndexMin
- isComplexType(Object) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Is the object one of the supported complex data types? (JavaRDD, RDD,
DataFrame, Matrix, double[][], MatrixBlock, URL)
- isCompressed() - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
Obtain whether this block is in compressed form or not.
- isConstDim2(long) - Method in enum org.apache.sysml.runtime.codegen.SpoofRowwise.RowType
-
- isContiguous() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Indicates if the dense block has a single
underlying block, i.e., if numBlocks==1.
- isContiguous(int, int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Indicates if the dense block has a single
underlying block for the given row range.
- isContiguous() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- isContiguous(int, int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- isContiguous() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- isContiguous(int, int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- isContiguous() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Indicates if the underlying data structures returned by values
and indexes are contiguous arrays, which can be exploited for
more efficient operations.
- isContiguous() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- isContiguous() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- isContiguous() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- isCSVLineAllNumbers(String) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
If no metadata is supplied for an RDD or JavaRDD, this method can be used
to determine whether the data appears to be matrix (or a frame)
- isDataFrameWithIDColumn(MatrixMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Return whether or not the DataFrame has an ID column.
- isDataFrameWithIDColumn(FrameMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Return whether or not the DataFrame has an ID column.
- isDenseBlockType(DenseBlock, DenseBlock.Type) - Static method in class org.apache.sysml.runtime.matrix.data.DenseBlockFactory
-
- isDensePointerNull() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Checks if the dense pointer is null
- isDirty() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Whether this block is dirty on the GPU
- isDistQuaternaryOpcode(String) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
- isDistributedCacheUsed(String) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
Evaluates if at least one instruction of the given instruction set
used the distributed cache; this call can also be used for individual
instructions.
- isDML() - Method in class org.apache.sysml.api.mlcontext.Script
-
Is the script type DML?
- isDML() - Method in enum org.apache.sysml.api.mlcontext.ScriptType
-
Is the script type DML?
- isEligibleForBuffering(boolean, boolean) - Method in class org.apache.sysml.runtime.instructions.gpu.context.ShadowBuffer
-
Checks if the GPU object is eligible for shadow buffering
- isEmpty() - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- isEmpty() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- isEmpty() - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- isEmpty() - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- isEmpty(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Get information if row r is empty, i.e., does not contain non-zero
values.
- isEmpty(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- isEmpty(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- isEmpty(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- isEmpty() - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
Indicates if the sparse row is empty, i.e., if is has
size zero.
- isEmpty() - Method in class org.apache.sysml.runtime.matrix.data.SparseRowScalar
-
- isEmpty() - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- isEmptyBlock(boolean) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- isEmptyBlock() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- isEmptyBlock(boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- isExplain() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Whether or not an explanation of the DML/PYDML program should be output
to standard output.
- isFlipOuter(int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- isForceGPU() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Whether or not the "force" GPU mode is enabled.
- isGPU() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Whether or not the GPU mode is enabled.
- isHashPartitioned(JavaPairRDD<?, ?>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
Indicates if the input RDD is hash partitioned, i.e., it has a partitioner
of type org.apache.spark.HashPartitioner
.
- isInitBeforeExecution() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Whether or not the default ScriptExecutor should be initialized before
execution.
- isInSparseFormat() - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- isInSparseFormat(GPUContext, MatrixObject) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- isInSparseFormat() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Returns the current representation (true for sparse).
- isInSparseFormat() - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- isInSparseFormat() - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- isLocked() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- isMaintainSymbolTable() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Obtain whether or not all values should be maintained in the symbol table
after execution.
- isMaintainSymbolTable() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Obtain whether or not all values should be maintained in the symbol table
after execution.
- isMapOnly() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- isMatMultMemoryBound(int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixNative
-
- isMergableMRJobInstruction(MRJobInstruction) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- isMultiBlockLookup(JavaPairRDD<?, ?>, MatrixCharacteristics, MatrixCharacteristics, IndexRange) - Static method in class org.apache.sysml.runtime.instructions.spark.MatrixIndexingSPInstruction
-
Indicates if the given index range and input matrix exhibit the following properties:
(1) existing hash partitioner, (2) out-of-core input matrix (larger than aggregated memory),
(3) aligned indexing range (which does not required aggregation), and (4) the output fits
twice in memory (in order to collect the result).
- isOutputThreadSafe() - Method in class org.apache.sysml.runtime.matrix.data.DnnParameters
-
- isPYDML() - Method in class org.apache.sysml.api.mlcontext.Script
-
Is the script type PYDML?
- isPYDML() - Method in enum org.apache.sysml.api.mlcontext.ScriptType
-
Is the script type PYDML?
- isRowIndexMax(AggregateUnaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixOuterAgg
-
This will return if uaggOp is of type RowIndexMax
- isRowIndexMin(AggregateUnaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixOuterAgg
-
This will return if uaggOp is of type RowIndexMin
- isRowTypeB1() - Method in enum org.apache.sysml.runtime.codegen.SpoofRowwise.RowType
-
- isRowTypeB1ColumnAgg() - Method in enum org.apache.sysml.runtime.codegen.SpoofRowwise.RowType
-
- isShallowSerialize() - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- isShallowSerialize(boolean) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- isShallowSerialize() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- isShallowSerialize(boolean) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- isShallowSerialize() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- isShallowSerialize(boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- isShortcutRandOperation(double, double, double, RandomMatrixGenerator.PDF) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDatagen
-
- isSingleBlockLookup(MatrixCharacteristics, IndexRange) - Static method in class org.apache.sysml.runtime.instructions.spark.MatrixIndexingSPInstruction
-
Indicates if the given index range only covers a single blocks of the inputs matrix.
- isSingleUncompressedGroup() - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- isSkinnyRightHandSide(long, long, long, long, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- isSparkVersionSupported(String, String) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Determine whether the Spark version is supported.
- isSparse - Variable in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Whether this block is in sparse format
- isSparse() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- isSparseAndEmpty() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
If this
GPUObject
is sparse and empty
Being allocated is a prerequisite to being sparse and empty.
- isSparseBlockType(SparseBlock, SparseBlock.Type) - Static method in class org.apache.sysml.runtime.matrix.data.SparseBlockFactory
-
- isSparseSafe() - Method in class org.apache.sysml.runtime.codegen.SpoofCellwise
-
- isSparseSafe() - Method in class org.apache.sysml.runtime.codegen.SpoofMultiAggregate
-
- isSparseSafeDivide(BinaryOperator, MatrixBlock) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixBincell
-
- isStatistics() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Whether or not statistics of the DML/PYDML program execution should be
output to standard output.
- isStride1Pad0() - Method in class org.apache.sysml.runtime.matrix.data.DnnParameters
-
- isSupportedMatrixMatrixOperation(String) - Static method in class org.apache.sysml.runtime.matrix.data.LibCommonsMath
-
- isSupportedMultiReturnOperation(String) - Static method in class org.apache.sysml.runtime.matrix.data.LibCommonsMath
-
- isSupportedReorgOperator(ReorgOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
- isSupportedUaggOp(AggregateUnaryOperator, BinaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixOuterAgg
-
- isSupportedUnaryAggregateOperator(AggregateUnaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixAgg
-
- isSupportedUnaryOperation(String) - Static method in class org.apache.sysml.runtime.matrix.data.LibCommonsMath
-
- isSupportedUnaryOperator(UnaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixAgg
-
- isTextIJV() - Method in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- isThreadSafe() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Indicates if concurrent modifications of disjoint rows are thread-safe.
- isThreadSafe(boolean) - Static method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Indicates if concurrent modifications of disjoint rows are thread-safe.
- isThreadSafe() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Indicates if the underlying implementation allows thread-safe row
updates if concurrent threads update disjoint rows.
- isThreadSafe() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- isThreadSafe() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- isThreadSafe() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- isUltraSparse(int, int) - Method in class org.apache.sysml.runtime.instructions.gpu.context.CSRPointer
-
Check for ultra sparsity
- isUltraSparse() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- isUltraSparse(boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- isUltraSparse() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- isUltraSparseMatrixMult(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- isUltraSparsePermutationMatrix() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- isValidDimensionsBinary(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixBincell
-
- isVector() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- isVectorBased() - Method in enum org.apache.sysml.api.mlcontext.MatrixFormat
-
Is the matrix format vector-based?
- isVectorBasedDataFrame(MatrixMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Return whether or not the DataFrame is vector-based.
- isZero(double[]) - Static method in class org.apache.sysml.runtime.compress.utils.DblArray
-
- isZero(DblArray) - Static method in class org.apache.sysml.runtime.compress.utils.DblArray
-
- ix1 - Variable in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNHelper.CellIndex3
-
- ix2 - Variable in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNHelper.CellIndex3
-
- ix3 - Variable in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNHelper.CellIndex3
-
- main(String[]) - Static method in class org.apache.sysml.api.DMLScript
-
- maintainSymbolTable - Variable in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- malloc(String, long) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUMemoryManager
-
Allocate pointer of the given size in bytes.
- map(LongWritable, Text, OutputCollector<Writable, Writable>, Reporter) - Method in class org.apache.sysml.runtime.matrix.CleanupMR.CleanupMapper
-
- MapJoinSignature1() - Constructor for class org.apache.sysml.runtime.instructions.spark.CtableSPInstruction.MapJoinSignature1
-
- MapJoinSignature2() - Constructor for class org.apache.sysml.runtime.instructions.spark.CtableSPInstruction.MapJoinSignature2
-
- MapJoinSignature3() - Constructor for class org.apache.sysml.runtime.instructions.spark.CtableSPInstruction.MapJoinSignature3
-
- MapmmChainSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MapmmSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MATERIALIZE_ZEROS - Static variable in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- matmult(ExecutionContext, GPUContext, String, MatrixObject, MatrixObject, String, boolean, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuMatMult
-
Matrix multiply on GPU Examines sparsity and shapes and routes call to
appropriate method from cuBLAS or cuSparse C = op(A) x op(B)
The user is expected to call
ec.releaseMatrixOutputForGPUInstruction(outputName);
- matMult(MatrixIndexes, MatrixBlock, MatrixIndexes, MatrixBlock, MatrixIndexes, MatrixBlock, AggregateBinaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.OperationsOnMatrixValues
-
- matMult(MatrixBlock, MatrixBlock, MatrixBlock, AggregateBinaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.OperationsOnMatrixValues
-
- matmultTSMM(ExecutionContext, GPUContext, String, MatrixObject, String, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs tsmm, A %*% A' or A' %*% A, on GPU by exploiting cublasDsyrk(...)
- Matrix - Class in org.apache.sysml.api.mlcontext
-
Matrix encapsulates a SystemML matrix.
- Matrix(MatrixObject, SparkExecutionContext) - Constructor for class org.apache.sysml.api.mlcontext.Matrix
-
- Matrix(Dataset<Row>, MatrixMetadata) - Constructor for class org.apache.sysml.api.mlcontext.Matrix
-
Convert a Spark DataFrame to a SystemML binary-block representation.
- Matrix(Dataset<Row>, long, long) - Constructor for class org.apache.sysml.api.mlcontext.Matrix
-
Convert a Spark DataFrame to a SystemML binary-block representation,
specifying the number of rows and columns.
- Matrix(JavaPairRDD<MatrixIndexes, MatrixBlock>, MatrixMetadata) - Constructor for class org.apache.sysml.api.mlcontext.Matrix
-
Create a Matrix, specifying the SystemML binary-block matrix and its
metadata.
- Matrix(Dataset<Row>) - Constructor for class org.apache.sysml.api.mlcontext.Matrix
-
Convert a Spark DataFrame to a SystemML binary-block representation.
- Matrix - Class in org.apache.sysml.udf
-
Class to represent the matrix input type
- Matrix(long, long, Matrix.ValueType) - Constructor for class org.apache.sysml.udf.Matrix
-
This constructor invokes Matrix(String path, long rows, long cols, ValueType vType)
with a default filename of ExternalFunctionProgramBlockCP and hence, should only
be used by CP external functions.
- Matrix(String, long, long, Matrix.ValueType) - Constructor for class org.apache.sysml.udf.Matrix
-
Constructor that takes matrix file path, num rows, num cols, and matrix
value type as parameters.
- Matrix(MatrixObject, Matrix.ValueType) - Constructor for class org.apache.sysml.udf.Matrix
-
- Matrix.ValueType - Enum in org.apache.sysml.udf
-
- MatrixAppendGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
Implements the cbind and rbind functions for matrices
- MatrixAppendMSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MatrixAppendMSPInstruction(Operator, CPOperand, CPOperand, CPOperand, CPOperand, boolean, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MatrixAppendMSPInstruction
-
- MatrixAppendRSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MatrixAppendRSPInstruction(Operator, CPOperand, CPOperand, CPOperand, boolean, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MatrixAppendRSPInstruction
-
- MatrixBlock - Class in org.apache.sysml.runtime.matrix.data
-
- MatrixBlock() - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- MatrixBlock(int, int, boolean) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- MatrixBlock(int, int, long) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- MatrixBlock(int, int, boolean, long) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- MatrixBlock(MatrixBlock) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- MatrixBlock(double) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- MatrixBlock(int, int, double) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- MatrixBlock(int, int, long, SparseBlock) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- MatrixBlock(MatrixBlock, SparseBlock.Type, boolean) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- MatrixBlock.BlockType - Enum in org.apache.sysml.runtime.matrix.data
-
- MatrixBlock.SparsityEstimate - Class in org.apache.sysml.runtime.matrix.data
-
- MatrixBlockDataInput - Interface in org.apache.sysml.runtime.matrix.data
-
Any data input that is intended to support fast deserialization / read
of entire blocks should implement this interface.
- MatrixBlockDataOutput - Interface in org.apache.sysml.runtime.matrix.data
-
Any data output that is intended to support fast serialization / write
of entire blocks should implement this interface.
- matrixBlockToBinaryBlock(JavaSparkContext, JavaPairRDD<MatrixIndexes, MatrixBlock>, MatrixCharacteristics) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- matrixBlockToBinaryBlockLongIndex(JavaSparkContext, JavaPairRDD<MatrixIndexes, MatrixBlock>, MatrixCharacteristics) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- matrixBlockToMatrixObject(String, MatrixBlock, MatrixMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixBlock
to a MatrixObject
.
- MatrixBuiltinGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- MatrixBuiltinGPUInstruction(Operator, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.gpu.MatrixBuiltinGPUInstruction
-
- MatrixCell - Class in org.apache.sysml.runtime.matrix.data
-
- MatrixCell() - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- MatrixCell(MatrixCell) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- MatrixCell(MatrixValue) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- MatrixCell(double) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- MatrixCharacteristics - Class in org.apache.sysml.runtime.matrix
-
- MatrixCharacteristics() - Constructor for class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- MatrixCharacteristics(long, long, long) - Constructor for class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- MatrixCharacteristics(long, long, int, int) - Constructor for class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- MatrixCharacteristics(long, long, int, int, long) - Constructor for class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- MatrixCharacteristics(MatrixCharacteristics) - Constructor for class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- matrixDescriptor - Static variable in class org.apache.sysml.runtime.instructions.gpu.context.CSRPointer
-
- MatrixFormat - Enum in org.apache.sysml.api.mlcontext
-
MatrixFormat represents the different matrix formats supported by the
MLContext API.
- MatrixIndexes - Class in org.apache.sysml.runtime.matrix.data
-
This represent the indexes to the blocks of the matrix.
- MatrixIndexes() - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixIndexes
-
- MatrixIndexes(long, long) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixIndexes
-
- MatrixIndexes(MatrixIndexes) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixIndexes
-
- MatrixIndexingGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- MatrixIndexingSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
This class implements the matrix indexing functionality inside CP.
- MatrixIndexingSPInstruction(CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, AggBinaryOp.SparkAggType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MatrixIndexingSPInstruction
-
- MatrixIndexingSPInstruction(CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, LeftIndex.LixCacheType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MatrixIndexingSPInstruction
-
- MatrixMarketInputInfo - Static variable in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- MatrixMarketOutputInfo - Static variable in class org.apache.sysml.runtime.matrix.data.OutputInfo
-
- matrixMatrixArithmetic(ExecutionContext, GPUContext, String, MatrixObject, MatrixObject, String, boolean, boolean, BinaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs elementwise arithmetic operation specified by op of two input matrices in1 and in2
- MatrixMatrixArithmeticGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- MatrixMatrixArithmeticGPUInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.gpu.MatrixMatrixArithmeticGPUInstruction
-
- MatrixMatrixAxpyGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- MatrixMatrixBuiltinGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- MatrixMatrixBuiltinGPUInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String, int) - Constructor for class org.apache.sysml.runtime.instructions.gpu.MatrixMatrixBuiltinGPUInstruction
-
- matrixMatrixOperations(MatrixBlock, MatrixBlock, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibCommonsMath
-
- matrixMatrixRelational(ExecutionContext, GPUContext, String, MatrixObject, MatrixObject, String, BinaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs elementwise operation relational specified by op of two input matrices in1 and in2
- MatrixMatrixRelationalBinaryGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- MatrixMatrixRelationalBinaryGPUInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.gpu.MatrixMatrixRelationalBinaryGPUInstruction
-
- matrixMemoryManager - Variable in class org.apache.sysml.runtime.instructions.gpu.context.GPUMemoryManager
-
- MatrixMetadata - Class in org.apache.sysml.api.mlcontext
-
Matrix metadata, such as the number of rows, the number of columns, the
number of non-zero values, the number of rows per block, and the number of
columns per block in the matrix.
- MatrixMetadata() - Constructor for class org.apache.sysml.api.mlcontext.MatrixMetadata
-
- MatrixMetadata(MatrixFormat) - Constructor for class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on matrix format.
- MatrixMetadata(MatrixFormat, Long, Long) - Constructor for class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on matrix format, the
number of rows, and the number of columns in a matrix.
- MatrixMetadata(MatrixFormat, int, int) - Constructor for class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on matrix format, the
number of rows, and the number of columns in a matrix.
- MatrixMetadata(MatrixFormat, Long, Long, Long) - Constructor for class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on matrix format, the
number of rows, the number of columns, and the number of non-zero values
in a matrix.
- MatrixMetadata(MatrixFormat, int, int, int) - Constructor for class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on matrix format, the
number of rows, the number of columns, and the number of non-zero values
in a matrix.
- MatrixMetadata(MatrixFormat, Long, Long, Long, Integer, Integer) - Constructor for class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on matrix format, the
number of rows, the number of columns, the number of non-zero values, the
number of rows per block, and the number of columns per block in a
matrix.
- MatrixMetadata(MatrixFormat, int, int, int, int, int) - Constructor for class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on matrix format, the
number of rows, the number of columns, the number of non-zero values, the
number of rows per block, and the number of columns per block in a
matrix.
- MatrixMetadata(Long, Long) - Constructor for class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on the number of rows
and the number of columns in a matrix.
- MatrixMetadata(int, int) - Constructor for class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on the number of rows
and the number of columns in a matrix.
- MatrixMetadata(Long, Long, Long) - Constructor for class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on the number of
rows, the number of columns, and the number of non-zero values in a
matrix.
- MatrixMetadata(int, int, int) - Constructor for class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on the number of
rows, the number of columns, and the number of non-zero values in a
matrix.
- MatrixMetadata(Long, Long, Integer, Integer) - Constructor for class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on the number of
rows, the number of columns, the number of rows per block, and the number
of columns per block in a matrix.
- MatrixMetadata(int, int, int, int) - Constructor for class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on the number of
rows, the number of columns, the number of rows per block, and the number
of columns per block in a matrix.
- MatrixMetadata(Long, Long, Long, Integer, Integer) - Constructor for class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on the number of
rows, the number of columns, the number of non-zero values, the number of
rows per block, and the number of columns per block in a matrix.
- MatrixMetadata(int, int, int, int, int) - Constructor for class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on the number of
rows, the number of columns, the number of non-zero values, the number of
rows per block, and the number of columns per block in a matrix.
- MatrixMetadata(MatrixCharacteristics) - Constructor for class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on a
MatrixCharacteristics object.
- matrixMult(MatrixBlock, MatrixBlock, MatrixBlock) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
Performs a matrix multiplication and stores the result in the output matrix.
- matrixMult(MatrixBlock, MatrixBlock, MatrixBlock, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
This method allows one to disabling exam sparsity.
- matrixMult(MatrixBlock, MatrixBlock, MatrixBlock, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- matrixMult(MatrixBlock, MatrixBlock, MatrixBlock, int, int, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- matrixMult(MatrixBlock, MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
Performs a multi-threaded matrix multiplication and stores the result in the output matrix.
- matrixMult(MatrixBlock, MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixNative
-
Performs matrix multiplication using native library if BLAS is available or else falls back to
Java BLAS.
- matrixMult(MatrixBlock, MatrixBlock, MatrixBlock, int, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixNative
-
- matrixMultChain(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, MapMultChain.ChainType) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
Performs a matrix multiplication chain operation of type t(X)%*%(X%*%v) or t(X)%*%(w*(X%*%v)).
- matrixMultChain(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, MapMultChain.ChainType, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
Performs a parallel matrix multiplication chain operation of type t(X)%*%(X%*%v) or t(X)%*%(w*(X%*%v)).
- matrixMultDenseDenseMM(DenseBlock, DenseBlock, DenseBlock, int, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- matrixMultPermute(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- matrixMultPermute(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- matrixMultTransposeSelf(MatrixBlock, MatrixBlock, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- matrixMultTransposeSelf(MatrixBlock, MatrixBlock, boolean, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- matrixMultWCeMM(MatrixBlock, MatrixBlock, MatrixBlock, double, MatrixBlock, WeightedCrossEntropy.WCeMMType) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- matrixMultWCeMM(MatrixBlock, MatrixBlock, MatrixBlock, double, MatrixBlock, WeightedCrossEntropy.WCeMMType, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- matrixMultWDivMM(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, WeightedDivMM.WDivMMType) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
NOTE: This operation has limited NaN support, which is acceptable because all our sparse-safe operations
have only limited NaN support.
- matrixMultWDivMM(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, WeightedDivMM.WDivMMType, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
NOTE: This operation has limited NaN support, which is acceptable because all our sparse-safe operations
have only limited NaN support.
- matrixMultWSigmoid(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, WeightedSigmoid.WSigmoidType) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- matrixMultWSigmoid(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, WeightedSigmoid.WSigmoidType, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- matrixMultWSLoss(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, WeightedSquaredLoss.WeightsType) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- matrixMultWSLoss(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, WeightedSquaredLoss.WeightsType, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- matrixMultWuMM(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, WeightedUnaryMM.WUMMType, ValueFunction) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- matrixMultWuMM(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, WeightedUnaryMM.WUMMType, ValueFunction, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- matrixObjectTo2DDoubleArray(MatrixObject) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a two-dimensional double array.
- matrixObjectToBinaryBlocks(MatrixObject, SparkExecutionContext) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a
JavaPairRDD<MatrixIndexes, MatrixBlock>
.
- matrixObjectToDataFrame(MatrixObject, SparkExecutionContext, boolean) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a DataFrame
.
- matrixObjectToJavaRDDStringCSV(MatrixObject) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a JavaRDD<String>
in CSV
format.
- matrixObjectToJavaRDDStringIJV(MatrixObject) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a JavaRDD<String>
in IJV
format.
- matrixObjectToListStringCSV(MatrixObject) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a List<String>
in CSV format.
- matrixObjectToListStringIJV(MatrixObject) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a List<String>
in IJV format.
- matrixObjectToRDDStringCSV(MatrixObject) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a RDD<String>
in CSV format.
- matrixObjectToRDDStringIJV(MatrixObject) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a RDD<String>
in IJV format.
- MatrixPackedCell - Class in org.apache.sysml.runtime.matrix.data
-
- MatrixPackedCell(MatrixPackedCell) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixPackedCell
-
- MatrixPackedCell() - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixPackedCell
-
- MatrixReshapeGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- MatrixReshapeGPUInstruction(Operator, String, String, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand) - Constructor for class org.apache.sysml.runtime.instructions.gpu.MatrixReshapeGPUInstruction
-
- MatrixReshapeSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- matrixScalarArithmetic(ExecutionContext, GPUContext, String, MatrixObject, String, boolean, ScalarOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Entry point to perform elementwise matrix-scalar arithmetic operation specified by op
- matrixScalarOp(ExecutionContext, GPUContext, String, MatrixObject, String, boolean, ScalarOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Utility to do matrix-scalar operation kernel
- matrixScalarRelational(ExecutionContext, GPUContext, String, MatrixObject, String, ScalarOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Entry point to perform elementwise matrix-scalar relational operation specified by op
- MatrixValue - Class in org.apache.sysml.runtime.matrix.data
-
- MatrixValue() - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- MatrixValue(MatrixValue) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- MatrixValue.CellIndex - Class in org.apache.sysml.runtime.matrix.data
-
- max(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
- max() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Wrapper method for reduceall-max of a matrix.
- MAX_SHALLOW_SERIALIZE_OVERHEAD - Static variable in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- MAX_SOLVE_CACHE_SIZE - Static variable in class org.apache.sysml.runtime.compress.estim.CompressedSizeEstimatorSample
-
- maxNumElementsOfCuDNNTensor - Static variable in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- mdat - Variable in class org.apache.sysml.runtime.codegen.SpoofOperator.SideInput
-
- mean() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Wrapper method for reduceall-mean of a matrix.
- median() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- memStats - Variable in class org.apache.sysml.api.DMLOptions
-
- merge(CacheBlock, boolean) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- merge(FrameBlock) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- merge(CacheBlock, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- merge(MatrixBlock, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Merge disjoint: merges all non-zero values of the given input into the current
matrix block.
- merge(MatrixBlock, boolean, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- mergeByKey(JavaPairRDD<Long, FrameBlock>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDAggregateUtils
-
- mergeByKey(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
Merges disjoint data of all blocks per key.
- mergeByKey(JavaPairRDD<MatrixIndexes, MatrixBlock>, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
Merges disjoint data of all blocks per key.
- mergeByKey(JavaPairRDD<MatrixIndexes, MatrixBlock>, int, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
Merges disjoint data of all blocks per key.
- mergeMRJobInstruction(MRJobInstruction) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- mergeRowsByKey(JavaPairRDD<MatrixIndexes, RowMatrixBlock>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
Merges disjoint data of all blocks per key.
- MergeWithShiftedBlocks(MatrixCharacteristics, MatrixCharacteristics, boolean) - Constructor for class org.apache.sysml.runtime.instructions.spark.AppendGSPInstruction.MergeWithShiftedBlocks
-
- Metadata - Class in org.apache.sysml.api.mlcontext
-
Abstract metadata class for MLContext API.
- Metadata() - Constructor for class org.apache.sysml.api.mlcontext.Metadata
-
- metadata - Variable in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- metadata - Variable in class org.apache.sysml.runtime.matrix.JobReturn
-
- MetaData - Class in org.apache.sysml.runtime.matrix
-
Class to store metadata associated with a file (e.g., a matrix) on disk.
- MetaData(MatrixCharacteristics) - Constructor for class org.apache.sysml.runtime.matrix.MetaData
-
- MetaDataFormat - Class in org.apache.sysml.runtime.matrix
-
- MetaDataFormat(MatrixCharacteristics, OutputInfo, InputInfo) - Constructor for class org.apache.sysml.runtime.matrix.MetaDataFormat
-
- MetaDataNumItemsByEachReducer - Class in org.apache.sysml.runtime.matrix
-
- MetaDataNumItemsByEachReducer(MatrixCharacteristics, long[], int, long) - Constructor for class org.apache.sysml.runtime.matrix.MetaDataNumItemsByEachReducer
-
- mightHaveEmptyBlocks() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- min() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Wrapper method for reduceall-min of a matrix.
- MIN_PAR_AGG_THRESHOLD - Static variable in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- minimumRecommendedSparkVersion() - Method in class org.apache.sysml.api.mlcontext.ProjectInfo
-
Obtain the minimum recommended Spark version from the manifest.
- minNonZero() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Utility function for computing the min non-zero value.
- minValForMaxPoolOperations - Variable in class org.apache.sysml.runtime.matrix.data.DnnParameters
-
- MISC_TIMER_ABS_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ACOS_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ACTIVATION_FORWARD_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ALLOCATE - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ALLOCATE_DENSE_OUTPUT - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ALLOCATE_SPARSE_OUTPUT - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ASIN_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ATAN_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_BIAS_ADD_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CBIND_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CEIL_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_COLUMN_TO_ROW_MAJOR - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_COMPARE_AND_SET_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CONVOLUTION_BACKWARD_DATA_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CONVOLUTION_BACKWARD_FILTER_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CONVOLUTION_FORWARD_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_COS_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_COSH_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CUDA_FREE - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CUDA_SYNC - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CUDNN_CLEANUP - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CUDNN_INIT - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DAXPY_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DAXPY_MV_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DENSE_DGEAM_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DENSE_DOT_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DENSE_IM2COL_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DENSE_MATRIX_DENSE_MATRIX_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DENSE_MATRIX_DENSE_VECTOR_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DENSE_REORG_KNPQ_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DENSE_TO_SPARSE - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DENSE_VECTOR_DENSE_MATRIX_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DEVICE_TO_DEVICE - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DEVICE_TO_HOST - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_EVICT - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_EXP_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_FILL_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_FLOOR_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_HOST_TO_DEVICE - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_LOG_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_MATRIX_MATRIX_CELLWISE_OP_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_MATRIX_SCALAR_OP_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_MAXPOOLING_BACKWARD_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_MAXPOOLING_FORWARD_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_OBJECT_CLONE - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ORMQR - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_QR - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_QR_BUFFER - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_RBIND_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_REDUCE_ALL_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_REDUCE_COL_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_REDUCE_ROW_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_RELU_BACKWARD_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_RELU_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_REUSE - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_RIX_DENSE_OP - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_RIX_SPARSE_DENSE_OP_NNZ - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_RIX_SPARSE_DENSE_OP_ROWWISE - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ROUND_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ROW_TO_COLUMN_MAJOR - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SET_ZERO - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SIGMOID_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SIGN_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SIN_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SINH_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SPARSE_ALLOCATE_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SPARSE_DGEAM_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SPARSE_IM2COL_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SPARSE_MATRIX_DENSE_MATRIX_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SPARSE_MATRIX_DENSE_VECTOR_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SPARSE_MATRIX_SPARSE_MATRIX_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SPARSE_TO_DENSE - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SQRT_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SYRK_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_TAN_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_TANH_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_TRANSPOSE_LIB - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_TRSM - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_UPPER_TO_LOWER_TRIANGLE_KERNEL - Static variable in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- MLContext - Class in org.apache.sysml.api.mlcontext
-
The MLContext API offers programmatic access to SystemML on Spark from
languages such as Scala, Java, and Python.
- MLContext(SparkSession) - Constructor for class org.apache.sysml.api.mlcontext.MLContext
-
Create an MLContext based on a SparkSession for interaction with SystemML
on Spark.
- MLContext(SparkContext) - Constructor for class org.apache.sysml.api.mlcontext.MLContext
-
Create an MLContext based on a SparkContext for interaction with SystemML
on Spark.
- MLContext(JavaSparkContext) - Constructor for class org.apache.sysml.api.mlcontext.MLContext
-
Create an MLContext based on a JavaSparkContext for interaction with
SystemML on Spark.
- MLContext.ExecutionType - Enum in org.apache.sysml.api.mlcontext
-
The different types of execution environments supported by SystemML.
- MLContext.ExplainLevel - Enum in org.apache.sysml.api.mlcontext
-
The different explain levels supported by SystemML.
- MLContext.InternalProxy - Class in org.apache.sysml.api.mlcontext
-
Used internally by MLContextProxy.
- MLContextConversionUtil - Class in org.apache.sysml.api.mlcontext
-
Utility class containing methods to perform data conversions.
- MLContextConversionUtil() - Constructor for class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
- MLContextException - Exception in org.apache.sysml.api.mlcontext
-
Uncaught exception representing SystemML exceptions that occur through the
MLContext API.
- MLContextException() - Constructor for exception org.apache.sysml.api.mlcontext.MLContextException
-
- MLContextException(String, Throwable) - Constructor for exception org.apache.sysml.api.mlcontext.MLContextException
-
- MLContextException(String) - Constructor for exception org.apache.sysml.api.mlcontext.MLContextException
-
- MLContextException(Throwable) - Constructor for exception org.apache.sysml.api.mlcontext.MLContextException
-
- MLContextException(String, boolean) - Constructor for exception org.apache.sysml.api.mlcontext.MLContextException
-
Generate an exception and optionally suppress the stacktrace.
- MLContextUtil - Class in org.apache.sysml.api.mlcontext
-
Utility class containing methods for working with the MLContext API.
- MLContextUtil() - Constructor for class org.apache.sysml.api.mlcontext.MLContextUtil
-
- MLResults - Class in org.apache.sysml.api.mlcontext
-
MLResults handles the results returned from executing a Script using the
MLContext API.
- MLResults() - Constructor for class org.apache.sysml.api.mlcontext.MLResults
-
- MLResults(LocalVariableMap) - Constructor for class org.apache.sysml.api.mlcontext.MLResults
-
- MLResults(Script) - Constructor for class org.apache.sysml.api.mlcontext.MLResults
-
- MMCJMR - Class in org.apache.sysml.runtime.matrix
-
- MMRJMR - Class in org.apache.sysml.runtime.matrix
-
- MMTSJGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- mod(double, double) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- moveFromDevice(String) - Method in class org.apache.sysml.runtime.instructions.gpu.context.ShadowBuffer
-
Move the data from GPU to shadow buffer
- moveToDevice() - Method in class org.apache.sysml.runtime.instructions.gpu.context.ShadowBuffer
-
Move the data from shadow buffer to GPU
- moveToHost() - Method in class org.apache.sysml.runtime.instructions.gpu.context.ShadowBuffer
-
Move the data from shadow buffer to Matrix object
- MRInstructionParser - Class in org.apache.sysml.runtime.instructions
-
- MRInstructionParser() - Constructor for class org.apache.sysml.runtime.instructions.MRInstructionParser
-
- MRJobInstruction - Class in org.apache.sysml.runtime.instructions
-
- MRJobInstruction(JobType) - Constructor for class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- MRJobInstruction(MRJobInstruction) - Constructor for class org.apache.sysml.runtime.instructions.MRJobInstruction
-
(deep) Copy constructor, primarily used in parfor.
- multBias(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
- MultiInputCbind - Class in org.apache.sysml.udf.lib
-
This external built-in function addresses following two common scenarios:
1.
- MultiInputCbind() - Constructor for class org.apache.sysml.udf.lib.MultiInputCbind
-
- MultipleOutputCommitter - Class in org.apache.sysml.runtime.matrix.data
-
- MultipleOutputCommitter() - Constructor for class org.apache.sysml.runtime.matrix.data.MultipleOutputCommitter
-
- multiReturnOperations(MatrixBlock, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibCommonsMath
-
- MultiReturnParameterizedBuiltinSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeBuild2Function - Class in org.apache.sysml.runtime.instructions.spark
-
- MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeBuildFunction - Class in org.apache.sysml.runtime.instructions.spark
-
This function pre-aggregates distinct values of recoded columns per partition
(part of distributed recode map construction, used for recoding, binning and
dummy coding).
- MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeGroup2Function - Class in org.apache.sysml.runtime.instructions.spark
-
- MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeGroupFunction - Class in org.apache.sysml.runtime.instructions.spark
-
This function assigns codes to globally distinct values of recoded columns
and writes the resulting column map in textcell (IJV) format to the output.
- mxxValues(int, Builtin) - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- R - Variable in class org.apache.sysml.runtime.matrix.data.DnnParameters
-
- RandomMatrixGenerator - Class in org.apache.sysml.runtime.matrix.data
-
- RandomMatrixGenerator() - Constructor for class org.apache.sysml.runtime.matrix.data.RandomMatrixGenerator
-
- RandomMatrixGenerator(RandomMatrixGenerator.PDF, int, int, int, int, double) - Constructor for class org.apache.sysml.runtime.matrix.data.RandomMatrixGenerator
-
Instantiates a Random number generator
- RandomMatrixGenerator(String, int, int, int, int, double, double, double) - Constructor for class org.apache.sysml.runtime.matrix.data.RandomMatrixGenerator
-
Instantiates a Random number generator
- RandomMatrixGenerator(RandomMatrixGenerator.PDF, int, int, int, int, double, double, double) - Constructor for class org.apache.sysml.runtime.matrix.data.RandomMatrixGenerator
-
Instantiates a Random number generator
- RandomMatrixGenerator(RandomMatrixGenerator.PDF, int, int, int, int, double, double, double, double) - Constructor for class org.apache.sysml.runtime.matrix.data.RandomMatrixGenerator
-
Instantiates a Random number generator with a specific poisson mean
- randOperations(int, int, double, double, double, String, long) - Static method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Function to generate the random matrix with specified dimensions (block sizes are not specified).
- randOperations(int, int, double, double, double, String, long, int) - Static method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Function to generate the random matrix with specified dimensions (block sizes are not specified).
- randOperations(RandomMatrixGenerator, long) - Static method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Function to generate the random matrix with specified dimensions and block dimensions.
- randOperations(RandomMatrixGenerator, long, int) - Static method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Function to generate the random matrix with specified dimensions and block dimensions.
- randOperationsInPlace(RandomMatrixGenerator, Well1024a, long) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- randOperationsInPlace(RandomMatrixGenerator, Well1024a, long, int) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- randOperationsInPlace(RandomMatrixGenerator, Well1024a, long) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Function to generate a matrix of random numbers.
- randOperationsInPlace(RandomMatrixGenerator, Well1024a, long, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Function to generate a matrix of random numbers.
- RandSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- ratio - Variable in class org.apache.sysml.runtime.compress.CompressedMatrixBlock.CompressionStatistics
-
- rbind(ExecutionContext, GPUContext, String, MatrixObject, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- rCleanupRuntimeProgram(ProgramBlock, HashSet<String>) - Static method in class org.apache.sysml.api.jmlc.JMLCUtils
-
Cleanup program blocks (called recursively).
- RDDAggregateUtils - Class in org.apache.sysml.runtime.instructions.spark.utils
-
Collection of utility methods for aggregating binary block rdds.
- RDDAggregateUtils() - Constructor for class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
- RDDBinUaggChainFunction(BinaryOperator, AggregateUnaryOperator) - Constructor for class org.apache.sysml.runtime.instructions.spark.BinUaggChainSPInstruction.RDDBinUaggChainFunction
-
- RDDConverterUtils - Class in org.apache.sysml.runtime.instructions.spark.utils
-
- RDDConverterUtils() - Constructor for class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtils
-
- RDDConverterUtils.BinaryCellToBinaryBlockFunction - Class in org.apache.sysml.runtime.instructions.spark.utils
-
- RDDConverterUtils.DataFrameExtractIDFunction - Class in org.apache.sysml.runtime.instructions.spark.utils
-
- RDDConverterUtilsExt - Class in org.apache.sysml.runtime.instructions.spark.utils
-
NOTE: These are experimental converter utils.
- RDDConverterUtilsExt() - Constructor for class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- RDDConverterUtilsExt.AddRowID - Class in org.apache.sysml.runtime.instructions.spark.utils
-
- RDDConverterUtilsExt.RDDConverterTypes - Enum in org.apache.sysml.runtime.instructions.spark.utils
-
- RDDMapGroupedAggFunction(PartitionedBroadcast<MatrixBlock>, Operator, int, int, int) - Constructor for class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDMapGroupedAggFunction
-
- RDDMapGroupedAggFunction2(PartitionedBroadcast<MatrixBlock>, Operator, int) - Constructor for class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDMapGroupedAggFunction2
-
- RDDRemoveEmptyFunction(boolean, long, long, long) - Constructor for class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDRemoveEmptyFunction
-
- RDDRemoveEmptyFunctionInMem(boolean, long, long, long, PartitionedBroadcast<MatrixBlock>) - Constructor for class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDRemoveEmptyFunctionInMem
-
- RDDReplaceFunction(double, double) - Constructor for class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDReplaceFunction
-
- RDDRExpandFunction(double, boolean, boolean, boolean, long, long) - Constructor for class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDRExpandFunction
-
- RDDSortUtils - Class in org.apache.sysml.runtime.instructions.spark.utils
-
- RDDSortUtils() - Constructor for class org.apache.sysml.runtime.instructions.spark.utils.RDDSortUtils
-
- RDDSortUtils.IndexComparator - Class in org.apache.sysml.runtime.instructions.spark.utils
-
- RDDSortUtils.IndexComparator2 - Class in org.apache.sysml.runtime.instructions.spark.utils
-
- rddStringCSVToFrameObject(RDD<String>) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a RDD<String>
in CSV format to a FrameObject
- rddStringCSVToFrameObject(RDD<String>, FrameMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a RDD<String>
in CSV format to a FrameObject
- rddStringCSVToMatrixObject(RDD<String>) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a RDD<String>
in CSV format to a MatrixObject
- rddStringCSVToMatrixObject(RDD<String>, MatrixMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a RDD<String>
in CSV format to a MatrixObject
- rddStringIJVToFrameObject(RDD<String>, FrameMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a RDD<String>
in IJV format to a FrameObject
.
- rddStringIJVToMatrixObject(RDD<String>, MatrixMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a RDD<String>
in IJV format to a MatrixObject
.
- RDDTransformApplyFunction(Broadcast<Encoder>, Broadcast<TfOffsetMap>) - Constructor for class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTransformApplyFunction
-
- RDDTransformApplyOffsetFunction(String, String[]) - Constructor for class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTransformApplyOffsetFunction
-
- RDDTransformDecodeExpandFunction(int, int) - Constructor for class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTransformDecodeExpandFunction
-
- RDDTransformDecodeFunction(Decoder, int) - Constructor for class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTransformDecodeFunction
-
- RDDUAggFunction2(AggregateUnaryOperator, int, int) - Constructor for class org.apache.sysml.runtime.instructions.spark.AggregateUnarySPInstruction.RDDUAggFunction2
-
- READ_CACHE_BLKSZ - Static variable in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- readDMLScript(boolean, String) - Static method in class org.apache.sysml.api.DMLScript
-
Reads the DML/PyDML script into a String
- readDoubleArray(int, double[]) - Method in interface org.apache.sysml.runtime.matrix.data.MatrixBlockDataInput
-
Reads the double array from the data input into the given dense block
and returns the number of non-zeros.
- readDoubleMatrix(String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Reads an input matrix in arbitrary format from HDFS into a dense double array.
- readDoubleMatrix(String, InputInfo, long, long, int, int, long) - Method in class org.apache.sysml.api.jmlc.Connection
-
Reads an input matrix in arbitrary format from HDFS into a dense double array.
- ReaderColumnSelection - Class in org.apache.sysml.runtime.compress
-
Base class for all column selection readers.
- ReaderColumnSelection(int[], int, boolean) - Constructor for class org.apache.sysml.runtime.compress.ReaderColumnSelection
-
- ReaderColumnSelectionDense - Class in org.apache.sysml.runtime.compress
-
- ReaderColumnSelectionDense(MatrixBlock, int[], boolean) - Constructor for class org.apache.sysml.runtime.compress.ReaderColumnSelectionDense
-
- ReaderColumnSelectionDenseSample - Class in org.apache.sysml.runtime.compress
-
considers only a subset of row indexes
- ReaderColumnSelectionDenseSample(MatrixBlock, int[], int[], boolean) - Constructor for class org.apache.sysml.runtime.compress.ReaderColumnSelectionDenseSample
-
- ReaderColumnSelectionSparse - Class in org.apache.sysml.runtime.compress
-
Used to extract the values at certain indexes from each row in a sparse
matrix
Keeps returning all-zeros arrays until reaching the last possible index.
- ReaderColumnSelectionSparse(MatrixBlock, int[], boolean) - Constructor for class org.apache.sysml.runtime.compress.ReaderColumnSelectionSparse
-
- readExternal(ObjectInput) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
Redirects the default java serialization via externalizable to our default
hadoop writable serialization for efficient broadcast/rdd deserialization.
- readExternal(ObjectInput) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- readExternal(ObjectInput) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Redirects the default java serialization via externalizable to our default
hadoop writable serialization for efficient broadcast/rdd deserialization.
- readExternal(ObjectInput) - Method in class org.apache.sysml.runtime.matrix.data.MatrixIndexes
-
Redirects the default java serialization via externalizable to our default
hadoop writable serialization for consistency/maintainability.
- readFields(DataInput) - Method in class org.apache.sysml.runtime.compress.ColGroup
-
Deserializes column group from data input.
- readFields(DataInput, boolean) - Method in class org.apache.sysml.runtime.compress.ColGroup
-
Deserializes column group from data input.
- readFields(DataInput) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- readFields(DataInput, boolean) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.matrix.CSVReblockMR.BlockRow
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.matrix.CSVReblockMR.OffsetCount
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.matrix.data.AdaptivePartialBlock
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.matrix.data.MatrixIndexes
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.matrix.data.MatrixPackedCell
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.matrix.data.PartialBlock
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.matrix.data.Tagged
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.matrix.data.TaggedMatrixIndexes
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.matrix.data.TaggedTripleIndexes
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.matrix.data.TripleIndexes
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.matrix.data.WeightedCell
-
- readFields(DataInput) - Method in class org.apache.sysml.runtime.matrix.data.WeightedPair
-
- readLocks - Variable in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
number of read locks on this object (this GPUObject is being used in a current instruction)
- readScript(String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Read a DML or PyDML file as a string.
- readSparseRows(int, long, SparseBlock) - Method in interface org.apache.sysml.runtime.matrix.data.MatrixBlockDataInput
-
Reads the sparse rows array from the data input into a sparse block
and returns the number of non-zeros.
- readStringFrame(String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Reads an input frame in arbitrary format from HDFS into a dense string array.
- readStringFrame(String, InputInfo, long, long) - Method in class org.apache.sysml.api.jmlc.Connection
-
Reads an input frame in arbitrary format from HDFS into a dense string array.
- readTransformMetaDataFromFile(String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Reads transform meta data from an HDFS file path and converts it into an in-memory
FrameBlock object.
- readTransformMetaDataFromFile(String, String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Reads transform meta data from an HDFS file path and converts it into an in-memory
FrameBlock object.
- readTransformMetaDataFromFile(String, String, String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Reads transform meta data from an HDFS file path and converts it into an in-memory
FrameBlock object.
- readTransformMetaDataFromPath(String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Reads transform meta data from the class path and converts it into an in-memory
FrameBlock object.
- readTransformMetaDataFromPath(String, String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Reads transform meta data from the class path and converts it into an in-memory
FrameBlock object.
- readTransformMetaDataFromPath(String, String, String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Reads transform meta data from the class path and converts it into an in-memory
FrameBlock object.
- ReblockMR - Class in org.apache.sysml.runtime.matrix
-
- ReblockSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- recodeData(HashMap<Double, Integer>) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- recomputeColumnCardinality() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- recomputeIndexes(MatrixBlock, AggregateUnaryOperator, int, int, MatrixIndexes) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixAgg
-
Recompute outputs (e.g., maxindex or minindex) according to block indexes from MR.
- recomputeNonZeros() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Recomputes and materializes the number of non-zero values
of the entire matrix block.
- recomputeNonZeros(int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- recomputeNonZeros(int, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Recomputes the number of non-zero values of a specified
range of the matrix block.
- reduce(MatrixIndexes, Iterator<TaggedMatrixValue>, OutputCollector<MatrixIndexes, WeightedPair>, Reporter) - Method in class org.apache.sysml.runtime.matrix.CombineMR.InnerReducer
-
- RelationalBinaryGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- RelationalBinaryGPUInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.gpu.RelationalBinaryGPUInstruction
-
- releaseInput() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Releases input allocated on GPU
- releaseOutput() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
releases output allocated on GPU
- releaseReadLock() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- releaseWriteLock() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- relu(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNN
-
Performs the relu operation on the GPU.
- reluBackward(GPUContext, String, MatrixObject, MatrixObject, MatrixObject) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
This method computes the backpropagation errors for previous layer of relu operation
- reluBackward(MatrixBlock, MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
This method computes the backpropagation errors for previous layer of relu operation
- ReluBackward(int, int, DnnParameters) - Constructor for class org.apache.sysml.runtime.matrix.data.LibMatrixDNNRelu.ReluBackward
-
- remove(PlanningCoCodingGroup) - Method in class org.apache.sysml.runtime.compress.cocode.PlanningMemoTable
-
- removeEmptyOperations(MatrixBlock, boolean, boolean, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- removeEmptyOperations(MatrixBlock, boolean, boolean) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- removeEmptyOperations(MatrixBlock, boolean, boolean, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- removeEmptyOperations(MatrixBlock, boolean, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- RemoveEmptyRows - Class in org.apache.sysml.udf.lib
-
Deprecated.
- RemoveEmptyRows() - Constructor for class org.apache.sysml.udf.lib.RemoveEmptyRows
-
Deprecated.
- removeGPUObject(GPUObject) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUMemoryManager
-
Removes the GPU object from the memory manager
- removeIfPresent(long, Pointer) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
Remove a specific pointer if present in the internal hashmap
- reorg(MatrixBlock, MatrixBlock, ReorgOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
- reorg(MatrixCharacteristics, ReorgOperator, MatrixCharacteristics) - Static method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- ReorgGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- reorgOperations(ReorgOperator, MatrixValue, int, int, int) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- reorgOperations(ReorgOperator, MatrixValue, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- reorgOperations(ReorgOperator, MatrixValue, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- reorgOperations(ReorgOperator, MatrixValue, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- reorgOperations(ReorgOperator, MatrixValue, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- reorgOperations(ReorgOperator, MatrixValue, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.WeightedCell
-
- ReorgSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- replaceOperations(MatrixValue, double, double) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- replaceOperations(MatrixValue, double, double) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- replaceOperations(MatrixValue, double, double) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- replaceOperations(MatrixValue, double, double) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- replaceOperations(MatrixValue, double, double) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- ReplicateRightFactorFunction(long, long) - Constructor for class org.apache.sysml.runtime.instructions.spark.SpoofSPInstruction.ReplicateRightFactorFunction
-
- requiresLabelUpdate() - Method in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- requiresLabelUpdate() - Method in class org.apache.sysml.runtime.instructions.Instruction
-
- requiresLabelUpdate() - Method in class org.apache.sysml.runtime.instructions.spark.SPInstruction
-
- reserveAllGPUContexts() - Static method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContextPool
-
Reserves and gets an initialized list of GPUContexts
- reset() - Method in class org.apache.sysml.runtime.codegen.SpoofOperator.SideInput
-
- reset() - Method in class org.apache.sysml.runtime.codegen.SpoofOperator.SideInputSparseCell
-
- reset() - Method in class org.apache.sysml.runtime.compress.ReaderColumnSelection
-
Resets the reader to the first row.
- reset() - Method in class org.apache.sysml.runtime.compress.ReaderColumnSelectionDenseSample
-
- reset() - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- reset(int, int) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- reset(int, int, boolean) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- reset(int, int, boolean, long) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- reset(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- reset() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Resets the dense block by deleting non-zero values.
- reset(int, int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Resets the dense block by deleting non-zero values.
- reset(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Resets the dense block by setting the given value.
- reset() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- reset(int, int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- reset(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- reset() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- reset(int, int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- reset(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- reset(int, boolean) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- reset() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- reset() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- reset(int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- reset(int, int, long) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- reset(int, int, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- reset(int, int, boolean, long) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- reset(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- reset() - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- reset(int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- reset(int, int, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- reset(int, int, boolean, long) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- reset(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- reset() - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- reset(int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- reset(int, int, boolean) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- reset(int, int, boolean, long) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- reset(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- reset() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Clears the sparse block by deleting non-zero values.
- reset(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Clears the sparse block by deleting non-zero values.
- reset(int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Clears row r of the sparse block by deleting non-zero values.
- reset() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- reset(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- reset(int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- reset() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- reset(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- reset(int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- reset() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- reset(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- reset(int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- reset(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
Resets the sparse row to empty, after this call size and
isEmpty are guaranteed to return 0 and true, respectively.
- reset(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowScalar
-
- reset(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- resetConfig() - Method in interface org.apache.sysml.api.ConfigurableAPI
-
Reset configuration settings to default settings.
- resetConfig() - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
- resetConfig() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
- resetFloatingPointPrecision() - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Sets the internal state based on the DMLScript.DATA_TYPE
- resetGlobalFlags() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Reset the global flags (for example: statistics, gpu, etc)
post-execution.
- resetOutputMatrix(MatrixIndexes, MatrixBlock, MatrixIndexes, MatrixBlock, AggregateUnaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixOuterAgg
-
ReSet output matrix
- resetReadWriteLock() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- resetStatistics() - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
- reshape(MatrixBlock, MatrixBlock, int, int, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
CP reshape operation (single input, single output matrix)
NOTE: In contrast to R, the rowwise parameter specifies both
the read and write order, with row-wise being the default, while
R uses always a column-wise read, rowwise specifying the write
order and column-wise being the default.
- reshape(IndexedMatrixValue, MatrixCharacteristics, MatrixCharacteristics, boolean, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
MR/SPARK reshape interface - for reshape we cannot view blocks independently, and hence,
there are different CP and MR interfaces.
- RESIZE_FACTOR1 - Static variable in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
- RESIZE_FACTOR2 - Static variable in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
- restoreInputsInSymbolTable() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Restore the input variables in the symbol table after script execution.
- results() - Method in class org.apache.sysml.api.mlcontext.Script
-
Obtain the results of the script execution.
- ResultVariables - Class in org.apache.sysml.api.jmlc
-
A ResultVariables object holds the data returned by a call
to
PreparedScript
's
executeScript
method, which executes a DML/PyDML script.
- ResultVariables() - Constructor for class org.apache.sysml.api.jmlc.ResultVariables
-
- rev(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
- rev(IndexedMatrixValue, long, int, ArrayList<IndexedMatrixValue>) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
- rewriteHops() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Apply static rewrites, perform intra-/inter-procedural analysis to
propagate size information into functions, apply dynamic rewrites, and
compute memory estimates for all HOPs.
- rewritePersistentReadsAndWrites() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Replace persistent reads and writes with transient reads and writes in
the symbol table.
- rexpand(MatrixBlock, MatrixBlock, double, boolean, boolean, boolean, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
CP rexpand operation (single input, single output)
- rexpand(IndexedMatrixValue, double, boolean, boolean, boolean, long, long, ArrayList<IndexedMatrixValue>) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
MR/Spark rexpand operation (single input, multiple outputs incl empty blocks)
- rexpandOperations(MatrixBlock, double, boolean, boolean, boolean, int) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- rexpandOperations(MatrixBlock, double, boolean, boolean, boolean, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- rightMultByVector(MatrixBlock, MatrixBlock, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroup
-
Multiply the slice of the matrix that this column group represents by a
vector on the right.
- rightMultByVector(MatrixBlock, MatrixBlock, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- rightMultByVector(ColGroupDDC1[], MatrixBlock, MatrixBlock, int, int) - Static method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- rightMultByVector(MatrixBlock, MatrixBlock, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- rightMultByVector(MatrixBlock, MatrixBlock, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
- rightMultByVector(MatrixBlock, MatrixBlock, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- rightMultByVector(MatrixBlock, MatrixBlock, int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
- rightMultByVector(MatrixBlock, MatrixBlock, int) - Method in class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
- rlen - Variable in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- rlens - Variable in class org.apache.sysml.runtime.matrix.CSVReblockMR.AssignRowIDMRReturn
-
- rmempty(MatrixBlock, MatrixBlock, boolean, boolean, MatrixBlock) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
CP rmempty operation (single input, single output matrix)
- rmempty(IndexedMatrixValue, IndexedMatrixValue, boolean, long, long, long, ArrayList<IndexedMatrixValue>) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
MR rmempty interface - for rmempty we cannot view blocks independently, and hence,
there are different CP and MR interfaces.
- RmmSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- round(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs an "round" operation on a matrix on the GPU
- row - Variable in class org.apache.sysml.runtime.matrix.data.MatrixValue.CellIndex
-
- RowClassMeet - Class in org.apache.sysml.udf.lib
-
Performs following operation:
# Computes the intersection ("meet") of equivalence classes for
# each row of A and B, excluding 0-valued cells.
- RowClassMeet() - Constructor for class org.apache.sysml.udf.lib.RowClassMeet
-
- ROWID_FILE_NAME - Static variable in class org.apache.sysml.runtime.matrix.CSVReblockMR
-
- rowIndexes() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
Get raw access to underlying array of row indices
For use in GPU code
- rowLower - Variable in class org.apache.sysml.runtime.instructions.spark.IndexingSPInstruction
-
- rowPointers() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
Get raw access to underlying array of row pointers
For use in GPU code
- rowPtr - Variable in class org.apache.sysml.runtime.instructions.gpu.context.CSRPointer
-
integer array of start of all rows and end of last row + 1
- rowsKnown() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- rowUpper - Variable in class org.apache.sysml.runtime.instructions.spark.IndexingSPInstruction
-
- rtplatform - Static variable in class org.apache.sysml.api.DMLScript
-
- runAssignRowIDMRJob(String[], InputInfo[], int[], int[], String, int, String[]) - Static method in class org.apache.sysml.runtime.matrix.CSVReblockMR
-
- runJob(DMLConfig) - Static method in class org.apache.sysml.runtime.matrix.CleanupMR
-
- runJob(MRJobInstruction, String[], InputInfo[], long[], long[], int[], int[], String, String, int, int, byte[], String[], OutputInfo[]) - Static method in class org.apache.sysml.runtime.matrix.CMCOVMR
-
- runJob(MRJobInstruction, String[], InputInfo[], long[], long[], int[], int[], String, int, int, byte[], String[], OutputInfo[]) - Static method in class org.apache.sysml.runtime.matrix.CombineMR
-
- runJob(MRJobInstruction, String[], InputInfo[], long[], long[], int[], int[], String, String, int, int, byte[], String[], OutputInfo[]) - Static method in class org.apache.sysml.runtime.matrix.CSVReblockMR
-
- runJob(MRJobInstruction, String[], String, String, String, int, int, byte[], String, String[], OutputInfo[]) - Static method in class org.apache.sysml.runtime.matrix.DataGenMR
-
Starts a Rand MapReduce job which will produce one or more random objects.
- runJob(MRJobInstruction, MatrixObject[], String, byte[], MatrixObject[], int, int) - Static method in class org.apache.sysml.runtime.matrix.DataPartitionMR
-
- runJob(MRJobInstruction, String[], InputInfo[], long[], long[], int[], int[], boolean[], ParForProgramBlock.PDataPartitionFormat[], int[], String, String, String, String, int, int, boolean, byte[], String, String[], OutputInfo[]) - Static method in class org.apache.sysml.runtime.matrix.GMR
-
Execute job.
- runJob(MRJobInstruction, String[], InputInfo[], long[], long[], int[], int[], String, String, int, int, byte[], String, String[], OutputInfo[]) - Static method in class org.apache.sysml.runtime.matrix.GroupedAggMR
-
- runJob(MRJobInstruction, String[], InputInfo[], long[], long[], int[], int[], String, String, String, int, int, String, OutputInfo) - Static method in class org.apache.sysml.runtime.matrix.MMCJMR
-
- runJob(MRJobInstruction, String[], InputInfo[], long[], long[], int[], int[], String, String, String, String, int, int, byte[], String[], OutputInfo[]) - Static method in class org.apache.sysml.runtime.matrix.MMRJMR
-
- runJob(MRJobInstruction, String[], InputInfo[], long[], long[], int[], int[], long[], String, String, String, int, int, boolean, byte[], String[], OutputInfo[]) - Static method in class org.apache.sysml.runtime.matrix.ReblockMR
-
- runJob(MRJobInstruction, String, InputInfo, long, long, int, int, String, String, int, int, String, OutputInfo, boolean) - Static method in class org.apache.sysml.runtime.matrix.SortMR
-
- runJob(MRJobInstruction, String[], InputInfo[], long[], long[], int[], int[], String, int, int, byte[], String[]) - Static method in class org.apache.sysml.runtime.matrix.WriteCSVMR
-
- runtimeProgram - Variable in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- S - Variable in class org.apache.sysml.runtime.matrix.data.DnnParameters
-
- sampleOperations(long, int, boolean, long) - Static method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- SAMPLING_RATIO - Static variable in class org.apache.sysml.runtime.compress.estim.SizeEstimatorFactory
-
- satisfiesMultiThreadingConstraints(MatrixBlock, MatrixBlock, AggregateUnaryOperator, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixAgg
-
- satisfiesMultiThreadingConstraints(MatrixBlock, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- satisfiesMultiThreadingConstraints(MatrixBlock, boolean, boolean, long, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- satisfiesMultiThreadingConstraints(MatrixBlock, MatrixBlock, boolean, boolean, long, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- sc() - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Obtain SparkContext from MLContextProxy.
- Scalar - Class in org.apache.sysml.udf
-
Class to represent a scalar input/output.
- Scalar(Scalar.ScalarValueType, String) - Constructor for class org.apache.sysml.udf.Scalar
-
Constructor to setup a scalar object.
- Scalar.ScalarValueType - Enum in org.apache.sysml.udf
-
- ScalarMatrixArithmeticGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- ScalarMatrixArithmeticGPUInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.gpu.ScalarMatrixArithmeticGPUInstruction
-
- ScalarMatrixBuiltinGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- ScalarMatrixBuiltinGPUInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String, int) - Constructor for class org.apache.sysml.runtime.instructions.gpu.ScalarMatrixBuiltinGPUInstruction
-
- ScalarMatrixRelationalBinaryGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- ScalarMatrixRelationalBinaryGPUInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.gpu.ScalarMatrixRelationalBinaryGPUInstruction
-
- scalarOperation(ScalarOperator) - Method in class org.apache.sysml.runtime.compress.ColGroup
-
Perform the specified scalar operation directly on the compressed column
group, without decompressing individual cells if possible.
- scalarOperation(ScalarOperator) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- scalarOperation(ScalarOperator) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- scalarOperation(ScalarOperator) - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
- scalarOperation(ScalarOperator) - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- scalarOperation(ScalarOperator) - Method in class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
- scalarOperations(ScalarOperator, MatrixValue) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- scalarOperations(ScalarOperator, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- scalarOperations(ScalarOperator, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- scalarOperations(ScalarOperator, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- scalarOperations(ScalarOperator, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- scalarOperations(ScalarOperator, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.WeightedCell
-
- script - Variable in class org.apache.sysml.api.DMLOptions
-
- script - Variable in class org.apache.sysml.api.mlcontext.MLResults
-
- Script - Class in org.apache.sysml.api.mlcontext
-
A Script object encapsulates a DML or PYDML script.
- Script() - Constructor for class org.apache.sysml.api.mlcontext.Script
-
Script constructor, which by default creates a DML script.
- Script(ScriptType) - Constructor for class org.apache.sysml.api.mlcontext.Script
-
Script constructor, specifying the type of script (ScriptType.DML
or ScriptType.PYDML
).
- Script(String) - Constructor for class org.apache.sysml.api.mlcontext.Script
-
Script constructor, specifying the script content.
- Script(String, ScriptType) - Constructor for class org.apache.sysml.api.mlcontext.Script
-
Script constructor, specifying the script content and the type of script
(DML or PYDML).
- script - Variable in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- SCRIPT_TYPE - Static variable in class org.apache.sysml.api.DMLScript
-
Global variable indicating the script type (DML or PYDML).
- ScriptExecutor - Class in org.apache.sysml.api.mlcontext
-
ScriptExecutor executes a DML or PYDML Script object using SystemML.
- ScriptExecutor() - Constructor for class org.apache.sysml.api.mlcontext.ScriptExecutor
-
ScriptExecutor constructor.
- ScriptExecutor(DMLConfig) - Constructor for class org.apache.sysml.api.mlcontext.ScriptExecutor
-
ScriptExecutor constructor, where the configuration properties are passed
in.
- ScriptExecutorUtils - Class in org.apache.sysml.api
-
- ScriptExecutorUtils() - Constructor for class org.apache.sysml.api.ScriptExecutorUtils
-
- ScriptFactory - Class in org.apache.sysml.api.mlcontext
-
Factory for creating DML and PYDML Script objects from strings, files, URLs,
and input streams.
- ScriptFactory() - Constructor for class org.apache.sysml.api.mlcontext.ScriptFactory
-
- scriptType - Variable in class org.apache.sysml.api.DMLOptions
-
- ScriptType - Enum in org.apache.sysml.api.mlcontext
-
ScriptType represents the type of script, DML (R-like syntax) or PYDML
(Python-like syntax).
- searchIndexesFirstGT(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- searchIndexesFirstGTE(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- searchIndexesFirstLTE(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- second - Variable in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes
-
- seqOperations(double, double, double) - Static method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Method to generate a sequence according to the given parameters.
- seqOperationsInPlace(double, double, double) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- seqOperationsInPlace(double, double, double) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- set(MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.AdaptivePartialBlock
-
- set(PartialBlock) - Method in class org.apache.sysml.runtime.matrix.data.AdaptivePartialBlock
-
- set(double) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Set the given value for the entire dense block (fill).
- set(int, int, int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Set the given value for an entire index range of the
dense block (fill).
- set(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Set the given value for a given row and column.
- set(int, double[]) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Copy the given vector into the given row.
- set(DenseBlock) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Copy the given dense block.
- set(int, int, int, int, DenseBlock) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Copy the given dense block into the specified
index range.
- set(KahanObject) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Copy the given kahan object sum and correction.
- set(int, KahanObject) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Copy the given kahan object sum and correction
into the given row.
- set(double) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- set(int, int, int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- set(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- set(DenseBlock) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- set(int, int, int, int, DenseBlock) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- set(int, double[]) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- set(double) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- set(int, int, int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- set(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- set(int, double[]) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- set(DenseBlock) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- set(int, int, int, int, DenseBlock) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- set(int, int, Object) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Sets the value in position (r,c), where the input is assumed
to be a boxed object consistent with the schema definition.
- set(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.IJV
-
- set(int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue.CellIndex
-
- set(K, V) - Method in class org.apache.sysml.runtime.matrix.data.Pair
-
- set(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.PartialBlock
-
- set(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Set the value of a matrix cell (r,c).
- set(int, SparseRow, boolean) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Set the values of row r to the given sparse row.
- set(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- set(int, SparseRow, boolean) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- set(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- set(int, SparseRow, boolean) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- set(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- set(int, SparseRow, boolean) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- set(int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
Sets the value of a specified column with awareness of
potential overwrites or deletes (set to value zero).
- set(int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowScalar
-
- set(int, double) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- set(long, long, int, int) - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- set(long, long, int, int, long) - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- set(MatrixCharacteristics) - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- setActiveAM() - Static method in class org.apache.sysml.api.DMLScript
-
- setAggregateInstructionsInReducer(String) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setAppropriateVarsForRead(Expression, String) - Method in class org.apache.sysml.api.mlcontext.MLContext.InternalProxy
-
- setBaseDir(String) - Method in class org.apache.sysml.udf.PackageFunction
-
- setBaseObject(T) - Method in class org.apache.sysml.runtime.matrix.data.Tagged
-
- setBlockSize(int, int) - Method in class org.apache.sysml.runtime.matrix.data.AddDummyWeightConverter
-
- setBlockSize(int, int) - Method in class org.apache.sysml.runtime.matrix.data.BinaryBlockToBinaryCellConverter
-
- setBlockSize(int, int) - Method in class org.apache.sysml.runtime.matrix.data.BinaryBlockToRowBlockConverter
-
- setBlockSize(int, int) - Method in class org.apache.sysml.runtime.matrix.data.BinaryBlockToTextCellConverter
-
- setBlockSize(int, int) - Method in class org.apache.sysml.runtime.matrix.data.BinaryCellToRowBlockConverter
-
- setBlockSize(int, int) - Method in class org.apache.sysml.runtime.matrix.data.BinaryCellToTextConverter
-
- setBlockSize(int, int) - Method in interface org.apache.sysml.runtime.matrix.data.Converter
-
- setBlockSize(int, int) - Method in class org.apache.sysml.runtime.matrix.data.IdenticalConverter
-
- setBlockSize(int, int) - Method in class org.apache.sysml.runtime.matrix.data.TextCellToRowBlockConverter
-
- setBlockSize(int, int) - Method in class org.apache.sysml.runtime.matrix.data.TextToBinaryCellConverter
-
- setBlockSize(int, int) - Method in class org.apache.sysml.runtime.matrix.data.WeightedCellToSortInputConverter
-
- setBlockSize(int) - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- setBlockSize(int, int) - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- setCM_N_COVObject(double, double, double) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- setCM_N_COVObject(CM_COV_Object) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- setCols(long) - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- setColsPerBlock(int) - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- setColumn(int, FrameBlock.Array) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- setColumnMetadata(FrameBlock.ColumnMetadata[]) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- setColumnMetadata(int, FrameBlock.ColumnMetadata) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- setColumnNames(String[]) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- setCompilerConfig() - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Set SystemML compiler configuration properties for MLContext
- setConfig(String) - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Set SystemML configuration based on a configuration file.
- setConfig(String) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Set SystemML configuration properties based on a configuration file.
- setConfig(DMLConfig) - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Set the SystemML configuration properties.
- setConfigProperty(String, String) - Method in interface org.apache.sysml.api.ConfigurableAPI
-
Set configuration property, such as
setConfigProperty("sysml.localtmpdir", "/tmp/systemml")
.
- setConfigProperty(String, String) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
- setConfigProperty(String, String) - Method in class org.apache.sysml.api.mlcontext.MLContext
-
- setConfiguration(String) - Method in class org.apache.sysml.udf.PackageFunction
-
Method to set the configuration file for this function.
- setData(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC
-
Generic set value for byte-length-agnostic write
of encoded value.
- setData(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- setData(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- setDefaultConfig() - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Set default SystemML configuration properties.
- setDensePointer(Pointer) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Convenience method to directly set the dense matrix pointer on GPU
- setDimension(long, long) - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- setDimsUnknownFilePrefix(String) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setExecutionScript(Script) - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Sets the script that is being executed
- setExecutionType(MLContext.ExecutionType) - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Set the execution environment.
- setExecutionType(MLContext.ExecutionType) - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Set the execution environment.
- setExplain(boolean) - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Whether or not an explanation of the DML/PYDML program should be output
to standard output.
- setExplain(boolean) - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Whether or not an explanation of the DML/PYDML program should be output
to standard output.
- setExplainLevel(MLContext.ExplainLevel) - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Set the level of program explanation that should be displayed if explain
is set to true.
- setExplainLevel(String) - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Set the level of program explanation that should be displayed if explain
is set to true.
- setExplainLevel(MLContext.ExplainLevel) - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Set the level of program explanation that should be displayed if explain
is set to true.
- setForceGPU(boolean) - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Whether or not to explicitly "force" the usage of GPU.
- setForceGPU(boolean) - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Whether or not to force GPU usage.
- setFormatProperties(FileFormatProperties) - Method in class org.apache.sysml.runtime.instructions.spark.WriteSPInstruction
-
- setFrame(String, String[][]) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a frame object to a registered input variable.
- setFrame(String, String[][], List<Expression.ValueType>) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a frame object to a registered input variable.
- setFrame(String, String[][], List<Expression.ValueType>, List<String>) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a frame object to a registered input variable.
- setFrame(String, String[][], boolean) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a frame object to a registered input variable.
- setFrame(String, String[][], List<Expression.ValueType>, boolean) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a frame object to a registered input variable.
- setFrame(String, String[][], List<Expression.ValueType>, List<String>, boolean) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a frame object to a registered input variable.
- setFrame(String, FrameBlock, boolean) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a frame object to a registered input variable.
- setFrameFormat(FrameFormat) - Method in class org.apache.sysml.api.mlcontext.FrameMetadata
-
Set the frame format
- setFrameSchema(FrameSchema) - Method in class org.apache.sysml.api.mlcontext.FrameMetadata
-
Set the frame schema
- setFunctionInputs(ArrayList<FunctionParameter>) - Method in class org.apache.sysml.udf.PackageFunction
-
- setGlobalFlags(DMLConfig) - Static method in class org.apache.sysml.api.DMLScript
-
Sets the global flags in DMLScript based on user provided configuration
- setGlobalFlags() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Set the global flags (for example: statistics, gpu, etc).
- setGMRInstructions(String[], String, String, String, String, String[], byte[], int, int) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setGPU(boolean) - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Whether or not to use (an available) GPU on the driver node.
- setGPU(boolean) - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Whether or not to enable GPU usage.
- setIfUnknown(Hop, Hop, Hop, Hop, Hop, Hop, Hop, Hop, Hop, Hop, Hop, int) - Method in class org.apache.sysml.runtime.matrix.data.DnnParameters
-
- setIndexes(long, long) - Method in class org.apache.sysml.runtime.matrix.data.MatrixIndexes
-
- setIndexes(MatrixIndexes) - Method in class org.apache.sysml.runtime.matrix.data.MatrixIndexes
-
- setIndexes(int[]) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- setIndexes(long, long) - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes
-
- setIndexes(TaggedTripleIndexes) - Method in class org.apache.sysml.runtime.matrix.data.TaggedTripleIndexes
-
- setIndexes(long, long, long) - Method in class org.apache.sysml.runtime.matrix.data.TaggedTripleIndexes
-
- setIndexes(TripleIndexes) - Method in class org.apache.sysml.runtime.matrix.data.TripleIndexes
-
- setIndexes(long, long, long) - Method in class org.apache.sysml.runtime.matrix.data.TripleIndexes
-
- setIndexRange(int, int, int, double[], int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Sets a dense array of non-zeros values into the column range [cl,cu)
in row r.
- setIndexRange(int, int, int, double[], int[], int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Sets a sparse array of non-zeros values and indexes into the column range [cl,cu)
in row r.
- setIndexRange(int, int, int, double[], int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- setIndexRange(int, int, int, double[], int[], int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- setIndexRange(int, int, int, double[], int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- setIndexRange(int, int, int, double[], int[], int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- setIndexRange(int, int, int, int, double[], int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
Inserts a sorted row-major array of non-zero values into the row and column
range [rl,ru) and [cl,cu).
- setIndexRange(int, int, int, int, SparseBlock) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
Inserts a sparse block into the row and column range [rl,ru) and [cl,cu).
- setIndexRange(int, int, int, double[], int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- setIndexRange(int, int, int, double[], int[], int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- setIndexRange(int, int, double[], int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- setIndexRange(int, int, double[], int[], int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- setInit(boolean) - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Whether or not to initialize the scratch_space, bufferpool, etc.
- setInitBeforeExecution(boolean) - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Whether or not the default ScriptExecutor should be initialized before
execution.
- setInput(FunctionParameter, int) - Method in class org.apache.sysml.udf.PackageFunction
-
Method to set a specific input for this package function
- setInputOutputLabels(String[], String[]) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
Method to set input and output labels for a MapReduce instruction.
- setInstID(long) - Method in class org.apache.sysml.runtime.instructions.Instruction
-
Setter for instruction unique identifier
- setIv_aggInstructions(String) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setIv_instructionsInMapper(String) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setIv_otherInstructions(String) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setIv_randInstructions(String) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setIv_recordReaderInstructions(String) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setIv_shuffleInstructions(String) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setKey(K) - Method in class org.apache.sysml.runtime.matrix.data.Pair
-
- setLocation(String, int, int, int, int) - Method in class org.apache.sysml.runtime.instructions.Instruction
-
- setLocation(Lop) - Method in class org.apache.sysml.runtime.instructions.Instruction
-
- setLocation(DataIdentifier) - Method in class org.apache.sysml.runtime.instructions.Instruction
-
- setLocation(Instruction) - Method in class org.apache.sysml.runtime.instructions.Instruction
-
- setMaintainSymbolTable(boolean) - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Set whether or not all values should be maintained in the symbol table
after execution.
- setMaintainSymbolTable(boolean) - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Set whether or not all values should be maintained in the symbol table
after execution.
- setMapperInstructions(String) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setMatrix(String, double[][]) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a matrix object to a registered input variable.
- setMatrix(String, double[][], boolean) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a matrix object to a registered input variable.
- setMatrix(String, MatrixBlock, boolean) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a matrix object to a registered input variable.
- setMatrixCharacteristics(MatrixCharacteristics) - Method in class org.apache.sysml.api.mlcontext.FrameMetadata
-
Set the FrameMetadata fields based on a MatrixCharacteristics object.
- setMatrixCharacteristics(MatrixCharacteristics) - Method in class org.apache.sysml.api.mlcontext.Metadata
-
Set the metadata fields based on a MatrixCharacteristics object.
- setMatrixDoubleArray(double[][]) - Method in class org.apache.sysml.udf.Matrix
-
Method to set matrix as double array.
- setMatrixDoubleArray(double[]) - Method in class org.apache.sysml.udf.Matrix
-
Method to set matrix as double array.
- setMatrixDoubleArray(MatrixBlock, OutputInfo, InputInfo) - Method in class org.apache.sysml.udf.Matrix
-
Method to set matrix as double array.
- setMatrixFormat(MatrixFormat) - Method in class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Set the matrix format
- setMatrixObject(MatrixObject) - Method in class org.apache.sysml.udf.Matrix
-
- setMaxIndexInPartition(int[], double[]) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixOuterAgg
-
This function will set maximum index in the partition to all cells in partition.
- setMemoryRequirements(double) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setMetaData(MetaData) - Method in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- setMinIndexInPartition(int[], double[]) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixOuterAgg
-
This function will set minimum index in the partition to all cells in partition.
- setMRJobInstructionsLineNumbers(ArrayList<Integer>) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
Setter for MRJobInstructionslineNumbers field
- setMvValue(String) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock.ColumnMetadata
-
- setName(String) - Method in class org.apache.sysml.api.mlcontext.Script
-
Set the script name.
- setNonZeros(long) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- setNonZeros(long) - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- setNonZerosBound(long) - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- setNumberOfReducers(int) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
Method to set the number of reducers for a MapReducer instruction.
- setNumColumns(Long) - Method in class org.apache.sysml.api.mlcontext.Metadata
-
Set the number of columns
- setNumColumns(int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- setNumColumnsPerBlock(Integer) - Method in class org.apache.sysml.api.mlcontext.Metadata
-
Set the number of columns per block
- setNumDistinct(long) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock.ColumnMetadata
-
- setNumFunctionInputs(int) - Method in class org.apache.sysml.udf.PackageFunction
-
Method to set the number of inputs for this package function
- setNumNonZeros(Long) - Method in class org.apache.sysml.api.mlcontext.Metadata
-
Set the number of non-zero values
- setNumRows(Long) - Method in class org.apache.sysml.api.mlcontext.Metadata
-
Set the number of rows
- setNumRows(int) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- setNumRows(int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
NOTE: setNumRows() and setNumColumns() are used only in ternaryInstruction (for contingency tables)
and pmm for meta corrections.
- setNumRowsPerBlock(Integer) - Method in class org.apache.sysml.api.mlcontext.Metadata
-
Set the number of rows per block
- setOtherInstructionsInReducer(String) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setOtherValue(double) - Method in class org.apache.sysml.runtime.matrix.data.WeightedPair
-
- setOuterProdType(SpoofOuterProduct.OutProdType) - Method in class org.apache.sysml.runtime.codegen.SpoofOuterProduct
-
- setOutputCharacteristicsForGroupedAgg(MatrixCharacteristics, MatrixCharacteristics, JavaPairRDD<MatrixIndexes, MatrixCell>) - Method in class org.apache.sysml.runtime.instructions.spark.ParameterizedBuiltinSPInstruction
-
- setOutputs(byte[]) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
Method to set outputs (output indices) for a MapReduce instruction.
- setPartitioned(boolean[]) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setPformats(ParForProgramBlock.PDataPartitionFormat[]) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setPsizes(int[]) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setRandInstructions(String) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setReBlockInstructions(String[], String, String, String, String[], byte[], int, int) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setRecordReaderInstructions(String) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setReplication(int) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
Method to set the replication factor for outputs produced from a MapReduce instruction.
- setResults(MLResults) - Method in class org.apache.sysml.api.mlcontext.Script
-
Set the results of the script execution.
- setRows(long) - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- setRowsPerBlock(int) - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- setScalar(String, boolean) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a scalar boolean to a registered input variable.
- setScalar(String, boolean, boolean) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a scalar boolean to a registered input variable.
- setScalar(String, long) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a scalar long to a registered input variable.
- setScalar(String, long, boolean) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a scalar long to a registered input variable.
- setScalar(String, double) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a scalar double to a registered input variable.
- setScalar(String, double, boolean) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a scalar double to a registered input variable.
- setScalar(String, String) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a scalar string to a registered input variable.
- setScalar(String, String, boolean) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a scalar string to a registered input variable.
- setScalar(String, ScalarObject, boolean) - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Binds a scalar object to a registered input variable.
- setSchema(List<Expression.ValueType>) - Method in class org.apache.sysml.api.mlcontext.FrameSchema
-
Set the frame schema
- setSchema(Expression.ValueType[]) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Sets the schema of the frame block.
- setSchemaAsString(String) - Method in class org.apache.sysml.api.mlcontext.FrameSchema
-
Set the frame schema, specifying the frame schema as a comma-separated
string
- setScriptExecutor(ScriptExecutor) - Method in class org.apache.sysml.api.mlcontext.Script
-
Set the ScriptExecutor used by this Script.
- setScriptString(String) - Method in class org.apache.sysml.api.mlcontext.Script
-
Set the script string.
- setScriptType(ScriptType) - Method in class org.apache.sysml.api.mlcontext.Script
-
Set the type of script (DML or PYDML).
- setShuffleInstructions(String) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setSize(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- setSparseBlock(SparseBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- setSparseMatrixCudaPointer(CSRPointer) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Convenience method to directly set the sparse matrix on GPU
Needed for operations like cusparseDcsrgemm(cusparseHandle, int, int, int, int, int, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer)
- setStatistics(boolean) - Method in class org.apache.sysml.api.jmlc.Connection
-
Sets a boolean flag indicating if runtime statistics should be gathered
Same behavior as in "MLContext.setStatistics()"
- setStatistics(boolean) - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Whether or not statistics of the DML/PYDML program execution should be
output to standard output.
- setStatistics(boolean) - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Whether or not statistics about the DML/PYDML program should be output to
standard output.
- setStatisticsMaxHeavyHitters(int) - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Sets the maximum number of heavy hitters that are printed out as part of
the statistics.
- setStatisticsMaxHeavyHitters(int) - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Set the maximum number of heavy hitters to display with statistics.
- setTag(byte) - Method in class org.apache.sysml.runtime.matrix.data.Tagged
-
- setTag(byte) - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes
-
- setup(Script) - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Sets the script in the ScriptExecutor, checks that the script has a type
and string, sets the ScriptExecutor in the script, sets the script string
in the Spark Monitor, globally sets the script type, sets global flags,
and resets statistics if needed.
- setupJob(JobContext) - Method in class org.apache.sysml.runtime.matrix.data.MultipleOutputCommitter
-
- setupSeedsForRand(long) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDatagen
-
A matrix of random numbers is generated by using multiple seeds, one for each
block.
- setupThreadLocalMemory(int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- setupThreadLocalMemory(int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- setupThreadLocalMemory(int) - Static method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- setupValuePRNG() - Method in class org.apache.sysml.runtime.matrix.data.RandomMatrixGenerator
-
- setUUID(String) - Static method in class org.apache.sysml.api.DMLScript
-
Used to set master UUID on all nodes (in parfor remote_mr, where DMLScript passed)
in order to simplify cleanup of scratch_space and local working dirs.
- setValue(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- setValue(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- setValue(double) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- setValue(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- setValue(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- setValue(V) - Method in class org.apache.sysml.runtime.matrix.data.Pair
-
- setValues(double[]) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- setValues(double[]) - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- setWeight(double) - Method in class org.apache.sysml.runtime.matrix.data.WeightedCell
-
- SGDNesterovUpdate - Class in org.apache.sysml.udf.lib
-
Use this class to perform an SGD update with Nesterov momentum in CP.
- SGDNesterovUpdate() - Constructor for class org.apache.sysml.udf.lib.SGDNesterovUpdate
-
- ShadowBuffer - Class in org.apache.sysml.runtime.instructions.gpu.context
-
- ShadowBuffer(GPUObject) - Constructor for class org.apache.sysml.runtime.instructions.gpu.context.ShadowBuffer
-
- SHALLOW_COPY_REORG - Static variable in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
- sharedMemBytes - Variable in class org.apache.sysml.runtime.instructions.gpu.context.ExecutionConfig
-
- shiftColIndices(int) - Method in class org.apache.sysml.runtime.compress.ColGroup
-
- ShiftColumnIndex(long, boolean) - Constructor for class org.apache.sysml.runtime.instructions.spark.AppendGAlignedSPInstruction.ShiftColumnIndex
-
- shiftLeft(int[], double[]) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixOuterAgg
-
This function will shift indices from one partition to next in left direction.
- ShiftMatrix(MatrixCharacteristics, MatrixCharacteristics, boolean) - Constructor for class org.apache.sysml.runtime.instructions.spark.AppendGSPInstruction.ShiftMatrix
-
- shiftRight(int[], double[]) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixOuterAgg
-
This function will shift indices from one partition to next in right direction.
- showExplanation() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Output a description of the program to standard output.
- SideInput(DenseBlock, MatrixBlock, int) - Constructor for class org.apache.sysml.runtime.codegen.SpoofOperator.SideInput
-
- SideInputSparseCell(SpoofOperator.SideInput) - Constructor for class org.apache.sysml.runtime.codegen.SpoofOperator.SideInputSparseCell
-
- SideInputSparseRow(SpoofOperator.SideInput) - Constructor for class org.apache.sysml.runtime.codegen.SpoofOperator.SideInputSparseRow
-
- sigmoid(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs an "sigmoid" operation on a matrix on the GPU
- sign(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs an "sign" operation on a matrix on the GPU
- sin(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs an "sin" operation on a matrix on the GPU
- SinglePrecisionCudaSupportFunctions - Class in org.apache.sysml.runtime.matrix.data
-
- SinglePrecisionCudaSupportFunctions() - Constructor for class org.apache.sysml.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- singleThreadedMatMult(MatrixBlock, MatrixBlock, MatrixBlock, boolean, boolean, DnnParameters) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNNHelper
-
- sinh(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs an "sinh" operation on a matrix on the GPU
- size() - Method in class org.apache.sysml.api.jmlc.ResultVariables
-
Obtain the number of output data held by this ResultVariables object.
- size - Variable in class org.apache.sysml.runtime.compress.cocode.PlanningCoCoder.GroupableColInfo
-
- size - Variable in class org.apache.sysml.runtime.compress.CompressedMatrixBlock.CompressionStatistics
-
- size() - Method in class org.apache.sysml.runtime.compress.utils.DblArrayIntListHashMap
-
- size() - Method in class org.apache.sysml.runtime.compress.utils.DoubleIntListHashMap
-
- size() - Method in class org.apache.sysml.runtime.compress.utils.IntArrayList
-
- size() - Method in class org.apache.sysml.runtime.matrix.data.CTableMap
-
- size() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Get the length of the dense block as the product
of row and column dimensions.
- size(int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Get the length of the given block.
- size() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- size(int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- size() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- size(int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- size() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Get the number of non-zero values in the sparse block.
- size(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Get the number of non-zero values in row r.
- size(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Get the number of non-zeros values in the row range
of [rl, ru).
- size(int, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Get the number of non-zeros values in the row and column
range of [rl/cl, ru/cu);
- size() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- size(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- size(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- size(int, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- size() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- size(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- size(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- size(int, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- size() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- size(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- size(int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- size(int, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- size() - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
Get the number of non-zero values of the sparse row.
- size() - Method in class org.apache.sysml.runtime.matrix.data.SparseRowScalar
-
- size() - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- SizeEstimationFactors(int, int, int, int, int) - Constructor for class org.apache.sysml.runtime.compress.estim.CompressedSizeEstimator.SizeEstimationFactors
-
- SizeEstimatorFactory - Class in org.apache.sysml.runtime.compress.estim
-
- SizeEstimatorFactory() - Constructor for class org.apache.sysml.runtime.compress.estim.SizeEstimatorFactory
-
- sizeInBytes - Variable in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNNConvolutionAlgorithm
-
- sizeOfDataType - Static variable in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- slice(int, int, int, int, CacheBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- slice(ArrayList<IndexedMatrixValue>, IndexRange, int, int, int, int, int, int) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- slice(ArrayList<IndexedMatrixValue>, IndexRange, int, int, int, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- slice(IndexRange, FrameBlock) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- slice(int, int, int, int, CacheBlock) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Right indexing operations to slice a subframe out of this frame block.
- slice(ArrayList<Pair<Long, FrameBlock>>, IndexRange, int) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- slice(IndexRange, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- slice(int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- slice(int, int, int, int, CacheBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- slice(int, int, int, int, boolean, CacheBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Method to perform rightIndex operation for a given lower and upper bounds in row and column dimensions.
- slice(ArrayList<IndexedMatrixValue>, IndexRange, int, int, int, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- slice(ArrayList<IndexedMatrixValue>, IndexRange, int, int, int, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- slice(ArrayList<IndexedMatrixValue>, IndexRange, int, int, int, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- sliceDenseDense(GPUContext, String, Pointer, Pointer, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Perform slice operation on dense input and output it in dense format
- sliceOperations(ExecutionContext, GPUContext, String, MatrixObject, IndexRange, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Method to perform rightIndex operation for a given lower and upper bounds in row and column dimensions.
- sliceSparseDense(GPUContext, String, CSRPointer, Pointer, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Perform slice operation on sparse input and output it in dense format
- SMALLEST_FILE_NAME_PER_INPUT - Static variable in class org.apache.sysml.runtime.matrix.CSVReblockMR
-
- softmax(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCuDNN
-
Performs an "softmax" operation on a matrix on the GPU
- solve(ExecutionContext, GPUContext, String, MatrixObject, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Implements the "solve" function for systemml Ax = B (A is of size m*n, B is of size m*1, x is of size n*1)
- sort(MatrixBlock, MatrixBlock, int[], boolean, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
- sort() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Sort all non-zero value/index pairs of the sparse block by row
and column index.
- sort(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Sort all non-zero value/index pairs of row r column index.
- sort() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- sort(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- sort() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- sort(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- sort() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- sort(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- sort() - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
In-place sort of column-index value pairs in order to allow binary search
after constant-time append was used for reading unordered sparse rows.
- sort() - Method in class org.apache.sysml.runtime.matrix.data.SparseRowScalar
-
- sort() - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- SORT_DECREASING - Static variable in class org.apache.sysml.runtime.matrix.SortMR
-
- SORT_INDEXES_OFFSETS - Static variable in class org.apache.sysml.runtime.matrix.SortMR
-
- SORT_INSTRUCTION - Static variable in class org.apache.sysml.runtime.matrix.SortMR
-
- SORT_VALUES_BY_LENGTH - Static variable in class org.apache.sysml.runtime.compress.ColGroupValue
-
- sortByVal(JavaPairRDD<MatrixIndexes, MatrixBlock>, long, int) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDSortUtils
-
- sortByVal(JavaPairRDD<MatrixIndexes, MatrixBlock>, JavaPairRDD<MatrixIndexes, MatrixBlock>, long, int) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDSortUtils
-
- sortByVals(JavaPairRDD<MatrixIndexes, MatrixBlock>, long, long, int) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDSortUtils
-
- sortDataByIx(JavaPairRDD<MatrixIndexes, MatrixBlock>, JavaPairRDD<MatrixIndexes, MatrixBlock>, long, long, int, int) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDSortUtils
-
- sortDataByVal(JavaPairRDD<MatrixIndexes, MatrixBlock>, JavaPairRDD<MatrixIndexes, MatrixBlock>, boolean, long, long, int, int) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDSortUtils
-
- sortDataByValMemSort(JavaPairRDD<MatrixIndexes, MatrixBlock>, JavaPairRDD<MatrixIndexes, MatrixBlock>, boolean, long, long, int, int, SparkExecutionContext, ReorgOperator) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDSortUtils
-
This function collects and sorts value column in memory and then broadcasts it.
- sortDataByVals(JavaPairRDD<MatrixIndexes, MatrixBlock>, JavaPairRDD<MatrixIndexes, MatrixBlock>, boolean, long, long, long, int, int) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDSortUtils
-
- sortIndexesByVal(JavaPairRDD<MatrixIndexes, MatrixBlock>, boolean, long, int) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDSortUtils
-
- sortIndexesByVals(JavaPairRDD<MatrixIndexes, MatrixBlock>, boolean, long, long, int) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDSortUtils
-
- SortMR - Class in org.apache.sysml.runtime.matrix
-
TODO fix issues sortindex mappers
- sortOperations(MatrixValue, MatrixValue) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- sortOperations(MatrixValue, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- sortSparseRows() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Sorts all existing sparse rows by column indexes.
- sortSparseRows(int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Sorts all existing sparse rows in range [rl,ru) by
column indexes.
- sortValuesByFrequency() - Method in class org.apache.sysml.runtime.compress.UncompressedBitmap
-
- SP_INST_PREFIX - Static variable in class org.apache.sysml.runtime.instructions.Instruction
-
- spark() - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Obtain SparkSession from MLContextProxy.
- sparkExecutionContext - Variable in class org.apache.sysml.api.mlcontext.MLResults
-
- SparkUtils - Class in org.apache.sysml.runtime.instructions.spark.utils
-
- SparkUtils() - Constructor for class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- sparse - Variable in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- sparse - Variable in class org.apache.sysml.runtime.matrix.data.MatrixBlock.SparsityEstimate
-
- SPARSE_OUTPUTS_IN_CSR - Static variable in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
- sparseBlock - Variable in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- SparseBlock - Class in org.apache.sysml.runtime.matrix.data
-
This SparseBlock is an abstraction for different sparse matrix formats.
- SparseBlock() - Constructor for class org.apache.sysml.runtime.matrix.data.SparseBlock
-
- SparseBlock.Type - Enum in org.apache.sysml.runtime.matrix.data
-
- SparseBlockCOO - Class in org.apache.sysml.runtime.matrix.data
-
SparseBlock implementation that realizes a traditional 'coordinate matrix'
representation, where the entire sparse block is stored as triples in three arrays:
row indexes, column indexes, and values, where row indexes and colunm indexes are
sorted in order to allow binary search.
- SparseBlockCOO(int) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- SparseBlockCOO(int, int) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- SparseBlockCOO(SparseBlock) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
Copy constructor sparse block abstraction.
- SparseBlockCOO(SparseRow[], int) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
Copy constructor old sparse row representation.
- SparseBlockCSR - Class in org.apache.sysml.runtime.matrix.data
-
SparseBlock implementation that realizes a traditional 'compressed sparse row'
representation, where the entire sparse block is stored as three arrays: ptr
of length rlen+1 to store offsets per row, and indexes/values of length nnz
to store column indexes and values of non-zero entries.
- SparseBlockCSR(int) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- SparseBlockCSR(int, int) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- SparseBlockCSR(int[], int[], double[], int) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- SparseBlockCSR(SparseBlock) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
Copy constructor sparse block abstraction.
- SparseBlockCSR(SparseRow[], int) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
Copy constructor old sparse row representation.
- SparseBlockCSR(int, int[], int[], double[]) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
Copy constructor for COO representation
- SparseBlockCSR(int, int, int[]) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
Copy constructor for given array of column indexes, which
identifies rows by position and implies values of 1.
- SparseBlockFactory - Class in org.apache.sysml.runtime.matrix.data
-
- SparseBlockFactory() - Constructor for class org.apache.sysml.runtime.matrix.data.SparseBlockFactory
-
- SparseBlockMCSR - Class in org.apache.sysml.runtime.matrix.data
-
SparseBlock implementation that realizes a 'modified compressed sparse row'
representation, where each compressed row is stored as a separate SparseRow
object which provides flexibility for unsorted row appends without the need
for global reshifting of values/indexes but it incurs additional memory
overhead per row for object/array headers per row which also slows down
memory-bound operations due to higher memory bandwidth requirements.
- SparseBlockMCSR(SparseBlock) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
Copy constructor sparse block abstraction.
- SparseBlockMCSR(SparseRow[], boolean) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
Copy constructor old sparse row representation.
- SparseBlockMCSR(int, int) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- SparseRow - Class in org.apache.sysml.runtime.matrix.data
-
Base class for sparse row implementations such as sparse
row vectors and sparse scalars (single value per row).
- SparseRow() - Constructor for class org.apache.sysml.runtime.matrix.data.SparseRow
-
- SparseRowScalar - Class in org.apache.sysml.runtime.matrix.data
-
- SparseRowScalar() - Constructor for class org.apache.sysml.runtime.matrix.data.SparseRowScalar
-
- SparseRowScalar(int, double) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseRowScalar
-
- SparseRowVector - Class in org.apache.sysml.runtime.matrix.data
-
- SparseRowVector() - Constructor for class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- SparseRowVector(int) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- SparseRowVector(int, int) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- SparseRowVector(SparseRow) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- sparseScalarOperationsInPlace(ScalarOperator) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- sparseScalarOperationsInPlace(ScalarOperator) - Method in class org.apache.sysml.runtime.matrix.data.WeightedCell
-
- sparseToColumnMajorDense() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
More efficient method to convert sparse to dense but returns dense in column major format
- sparseToDense() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Convert sparse to dense (Performs transpose, use sparseToColumnMajorDense if the kernel can deal with column major format)
- sparseToDense(String) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Convert sparse to dense (Performs transpose, use sparseToColumnMajorDense if the kernel can deal with column major format)
Also records per instruction invokation of sparseToDense.
- sparseToDense() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- sparseUnaryOperationsInPlace(UnaryOperator) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- sparseUnaryOperationsInPlace(UnaryOperator) - Method in class org.apache.sysml.runtime.matrix.data.WeightedCell
-
- SPARSITY_TURN_POINT - Static variable in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- SparsityEstimate(boolean, long) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixBlock.SparsityEstimate
-
- SparsityEstimate() - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixBlock.SparsityEstimate
-
- SPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- SPInstruction(SPInstruction.SPType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.SPInstruction
-
- SPInstruction(SPInstruction.SPType, Operator, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.SPInstruction
-
- SPInstruction.SPType - Enum in org.apache.sysml.runtime.instructions.spark
-
- SPInstructionParser - Class in org.apache.sysml.runtime.instructions
-
- SPInstructionParser() - Constructor for class org.apache.sysml.runtime.instructions.SPInstructionParser
-
- SpoofCellwise - Class in org.apache.sysml.runtime.codegen
-
- SpoofCellwise(SpoofCellwise.CellType, boolean, boolean, SpoofCellwise.AggOp) - Constructor for class org.apache.sysml.runtime.codegen.SpoofCellwise
-
- SpoofCellwise.AggOp - Enum in org.apache.sysml.runtime.codegen
-
- SpoofCellwise.CellType - Enum in org.apache.sysml.runtime.codegen
-
- SpoofMultiAggregate - Class in org.apache.sysml.runtime.codegen
-
- SpoofMultiAggregate(boolean, SpoofCellwise.AggOp...) - Constructor for class org.apache.sysml.runtime.codegen.SpoofMultiAggregate
-
- SpoofOperator - Class in org.apache.sysml.runtime.codegen
-
- SpoofOperator() - Constructor for class org.apache.sysml.runtime.codegen.SpoofOperator
-
- SpoofOperator.SideInput - Class in org.apache.sysml.runtime.codegen
-
- SpoofOperator.SideInputSparseCell - Class in org.apache.sysml.runtime.codegen
-
- SpoofOperator.SideInputSparseRow - Class in org.apache.sysml.runtime.codegen
-
- SpoofOuterProduct - Class in org.apache.sysml.runtime.codegen
-
- SpoofOuterProduct(SpoofOuterProduct.OutProdType) - Constructor for class org.apache.sysml.runtime.codegen.SpoofOuterProduct
-
- SpoofOuterProduct.OutProdType - Enum in org.apache.sysml.runtime.codegen
-
- SpoofRowwise - Class in org.apache.sysml.runtime.codegen
-
- SpoofRowwise(SpoofRowwise.RowType, long, boolean, int) - Constructor for class org.apache.sysml.runtime.codegen.SpoofRowwise
-
- SpoofRowwise.RowType - Enum in org.apache.sysml.runtime.codegen
-
- SpoofSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- SpoofSPInstruction.ReplicateRightFactorFunction - Class in org.apache.sysml.runtime.instructions.spark
-
- sqrt(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs an "sqrt" operation on a matrix on the GPU
- start_indexes_h - Variable in class org.apache.sysml.runtime.matrix.data.DnnParameters
-
- start_indexes_w - Variable in class org.apache.sysml.runtime.matrix.data.DnnParameters
-
- startAggregation(MatrixValue, MatrixValue, AggregateOperator, int, int, boolean, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.OperationsOnMatrixValues
-
- STATISTICS - Static variable in class org.apache.sysml.api.DMLScript
-
- statistics() - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Return a string containing runtime statistics.
- statistics - Variable in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- STATISTICS_COUNT - Static variable in class org.apache.sysml.api.DMLScript
-
- STATISTICS_MAX_WRAP_LEN - Static variable in class org.apache.sysml.api.DMLScript
-
- statisticsMaxHeavyHitters - Variable in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- stats - Variable in class org.apache.sysml.api.DMLOptions
-
- statsCount - Variable in class org.apache.sysml.api.DMLOptions
-
- stream - Variable in class org.apache.sysml.runtime.instructions.gpu.context.ExecutionConfig
-
- stride_h - Variable in class org.apache.sysml.runtime.matrix.data.DnnParameters
-
- stride_w - Variable in class org.apache.sysml.runtime.matrix.data.DnnParameters
-
- String2CPInstructionType - Static variable in class org.apache.sysml.runtime.instructions.CPInstructionParser
-
- String2MRInstructionType - Static variable in class org.apache.sysml.runtime.instructions.MRInstructionParser
-
- String2SPInstructionType - Static variable in class org.apache.sysml.runtime.instructions.SPInstructionParser
-
- stringDataFrameToVectorDataFrame(SparkSession, Dataset<Row>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
Convert a dataframe of comma-separated string rows to a dataframe of
ml.linalg.Vector rows.
- stringExternalToInputInfo(String) - Static method in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- stringToInputInfo(String) - Static method in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- stringToOutputInfo(String) - Static method in class org.apache.sysml.runtime.matrix.data.OutputInfo
-
- stringToSerializableText(JavaPairRDD<Long, String>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtils
-
- successful - Variable in class org.apache.sysml.runtime.matrix.JobReturn
-
- sum() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Wrapper method for reduceall-sum of a matrix.
- sumAllValues(double[], double[]) - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- sumAllValues(KahanFunction, KahanObject) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- sumAllValues(KahanFunction, KahanObject, boolean) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- sumByKeyStable(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
- sumByKeyStable(JavaPairRDD<MatrixIndexes, MatrixBlock>, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
- sumByKeyStable(JavaPairRDD<MatrixIndexes, MatrixBlock>, int, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
- sumCellsByKeyStable(JavaPairRDD<MatrixIndexes, Double>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
- sumCellsByKeyStable(JavaPairRDD<MatrixIndexes, Double>, int) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
- sumSq() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Wrapper method for reduceall-sumSq of a matrix.
- sumStable(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
- sumStable(JavaRDD<MatrixBlock>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDAggregateUtils
-
- sumValues(int) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- sumValues(int, KahanFunction) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- sumValues(int, KahanFunction, KahanObject) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- sumValues(int, double[]) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- sumWeightForQuantile() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
In a given two column matrix, the second column denotes weights.
- suppressPrint2Stdout() - Static method in class org.apache.sysml.api.DMLScript
-
- symbolTable - Variable in class org.apache.sysml.api.mlcontext.MLResults
-
- SYNCHRONIZE_GPU - Static variable in class org.apache.sysml.api.DMLScript
-
- val - Variable in class org.apache.sysml.runtime.instructions.gpu.context.CSRPointer
-
double array of non zero values
- validateScript() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Semantically validate the program's expressions, statements, and
statement blocks in a single recursive pass over the program.
- VALIDATOR_IGNORE_ISSUES - Static variable in class org.apache.sysml.api.DMLScript
-
If true, allow DMLProgram to be generated while not halting due to validation errors/warnings
- value - Variable in class org.apache.sysml.runtime.compress.utils.DblArrayIntListHashMap.DArrayIListEntry
-
- value - Variable in class org.apache.sysml.runtime.compress.utils.DoubleIntListHashMap.DIListEntry
-
- value - Variable in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- VALUE_IS_WEIGHT - Static variable in class org.apache.sysml.runtime.matrix.SortMR
-
- valueOf(String) - Static method in enum org.apache.sysml.api.DMLScript.EvictionPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.api.DMLScript.RUNTIME_PLATFORM
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.api.mlcontext.FrameFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.api.mlcontext.MatrixFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.api.mlcontext.MLContext.ExecutionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.api.mlcontext.MLContext.ExplainLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.api.mlcontext.ScriptType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.runtime.codegen.SpoofCellwise.AggOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.runtime.codegen.SpoofCellwise.CellType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.runtime.codegen.SpoofOuterProduct.OutProdType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.runtime.codegen.SpoofRowwise.RowType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.runtime.compress.cocode.PlanningCoCoder.PartitionerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.runtime.compress.ColGroup.CompressionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.runtime.instructions.gpu.GPUInstruction.GPUINSTRUCTION_TYPE
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.runtime.instructions.Instruction.IType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.runtime.instructions.spark.SPInstruction.SPType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt.RDDConverterTypes
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.runtime.matrix.data.DenseBlock.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.runtime.matrix.data.LibMatrixBincell.BinaryAccessType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.runtime.matrix.data.LibMatrixDNN.PoolingType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.runtime.matrix.data.MatrixBlock.BlockType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.runtime.matrix.data.SparseBlock.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.udf.FunctionParameter.FunctionParameterType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.udf.Matrix.ValueType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.udf.Scalar.ScalarValueType
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.sysml.api.DMLScript.EvictionPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.api.DMLScript.RUNTIME_PLATFORM
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.api.mlcontext.FrameFormat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.api.mlcontext.MatrixFormat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.api.mlcontext.MLContext.ExecutionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.api.mlcontext.MLContext.ExplainLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.api.mlcontext.ScriptType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.runtime.codegen.SpoofCellwise.AggOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.runtime.codegen.SpoofCellwise.CellType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values(int) - Method in class org.apache.sysml.runtime.codegen.SpoofOperator.SideInput
-
- values(int) - Method in class org.apache.sysml.runtime.codegen.SpoofOperator.SideInputSparseRow
-
- values() - Static method in enum org.apache.sysml.runtime.codegen.SpoofOuterProduct.OutProdType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.runtime.codegen.SpoofRowwise.RowType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.runtime.compress.cocode.PlanningCoCoder.PartitionerType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.runtime.compress.ColGroup.CompressionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.runtime.instructions.gpu.GPUInstruction.GPUINSTRUCTION_TYPE
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.runtime.instructions.Instruction.IType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.runtime.instructions.spark.SPInstruction.SPType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt.RDDConverterTypes
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.runtime.matrix.data.DenseBlock.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Get the allocated blocks.
- values(int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Get the allocated block for the given row.
- values() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- values(int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- values() - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- values(int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- values() - Static method in enum org.apache.sysml.runtime.matrix.data.LibMatrixBincell.BinaryAccessType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.runtime.matrix.data.LibMatrixDNN.PoolingType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.runtime.matrix.data.MatrixBlock.BlockType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.runtime.matrix.data.SparseBlock.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
Get the array of all non-zero entries in row r, sorted by their column
indexes.
- values(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- values() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
Get raw access to underlying array of values
For use in GPU code
- values() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
Get raw access to underlying array of values
For use in GPU code
- values(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- values(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- values() - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
Get the value array of non-zero entries, co-aligned
with the array of indexes.
- values() - Method in class org.apache.sysml.runtime.matrix.data.SparseRowScalar
-
- values() - Method in class org.apache.sysml.runtime.matrix.data.SparseRowVector
-
- values() - Static method in enum org.apache.sysml.udf.FunctionParameter.FunctionParameterType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.udf.Matrix.ValueType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysml.udf.Scalar.ScalarValueType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- valuesAt(int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlock
-
Get an allocated block.
- valuesAt(int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockDRB
-
- valuesAt(int) - Method in class org.apache.sysml.runtime.matrix.data.DenseBlockLDRB
-
- VALUETYPE_PREFIX - Static variable in class org.apache.sysml.runtime.instructions.Instruction
-
- vectAbsAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectAbsAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectAbsWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectAbsWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectAcosAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectAcosAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectAcosWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectAcosWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.compress.utils.LinearAlgebraUtils
-
- vectAdd(double, double[], char[], int, int, int) - Static method in class org.apache.sysml.runtime.compress.utils.LinearAlgebraUtils
-
- vectAdd(double, double[], int, int) - Static method in class org.apache.sysml.runtime.compress.utils.LinearAlgebraUtils
-
- vectAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- vectAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- vectAdd(double[], double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- vectAddInPlace(double, double[], int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- vectAsinAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectAsinAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectAsinWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectAsinWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectAtanAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectAtanAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectAtanWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectAtanWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectAvgpoolWrite(double[], int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectAvgpoolWrite(double[], int[], int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectBiasaddWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectBiasaddWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectBiasmultWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectBiasmultWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectBitwandWrite(double[], double, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectBitwandWrite(double, double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectBitwandWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectBitwandWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectBitwandWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectBitwandWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectBitwandWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCbindAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCbindAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCbindWrite(double, double) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCbindWrite(double[], double, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCbindWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCeilAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCeilAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCeilWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCeilWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectConv2dmmWrite(double[], double[], int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCosAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCosAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCoshAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCoshAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCoshWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCoshWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCosWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCosWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCountnnz(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCountnnz(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCummaxAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCummaxAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCummaxWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCummaxWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCumminAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCumminAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCumminWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCumminWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCumsumAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCumsumAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCumsumWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectCumsumWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectDivAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectDivAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectDivAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectDivAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectDivWrite(double[], double, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectDivWrite(double, double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectDivWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectDivWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectDivWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectDivWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectDivWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectEqualAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectEqualAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectEqualAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectEqualAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectEqualWrite(double[], double, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectEqualWrite(double, double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectEqualWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectEqualWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectEqualWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectEqualWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectEqualWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectExpAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectExpAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectExpWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectExpWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectFloorAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectFloorAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectFloorWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectFloorWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalWrite(double[], double, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalWrite(double, double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterWrite(double[], double, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterWrite(double, double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectIm2colWrite(double[], int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectIm2colWrite(double[], int[], int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalWrite(double[], double, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalWrite(double, double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessWrite(double[], double, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessWrite(double, double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLessWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLogAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLogAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLogWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectLogWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMatrixMult(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMatrixMult(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMax(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMax(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMaxAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMaxAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMaxAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMaxAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMaxpoolWrite(double[], int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMaxpoolWrite(double[], int[], int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMaxWrite(double[], double, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMaxWrite(double, double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMaxWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMaxWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMaxWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMaxWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMaxWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMean(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMean(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMin(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMin(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinusAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinusAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinusAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinusAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinusWrite(double[], double, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinusWrite(double, double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinusWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinusWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinusWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinusWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinusWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinWrite(double[], double, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinWrite(double, double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMinWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMult2Add(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMult2Add(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMult2Write(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMult2Write(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMultAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMultAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMultAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMultAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMultAdd(double[], double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMultiplyAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.compress.utils.LinearAlgebraUtils
-
- vectMultiplyAdd(double, double[], double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.compress.utils.LinearAlgebraUtils
-
- vectMultiplyAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- vectMultiplyAdd(double, double[], double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- vectMultiplyInPlace(double, double[], int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- vectMultiplyWrite(double, double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- vectMultiplyWrite(double[], double[], double[], int, int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- vectMultiplyWrite(double[], double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixMult
-
- vectMultWrite(double[], double, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMultWrite(double, double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMultWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMultWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMultWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMultWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectMultWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalWrite(double[], double, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalWrite(double, double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectOuterMultAdd(double[], double[], double[], int, int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectOuterMultAdd(double[], double[], double[], int[], int, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectOuterMultAdd(double[], double[], double[], int, int[], int, int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPlusAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPlusAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPlusAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPlusAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPlusWrite(double[], double, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPlusWrite(double, double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPlusWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPlusWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPlusWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPlusWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPlusWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPow2Add(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPow2Add(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPow2Write(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPow2Write(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPowAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPowAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPowAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPowAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPowWrite(double[], double, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPowWrite(double, double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPowWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPowWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectPowWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectRoundAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectRoundAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectRoundWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectRoundWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSigmoidAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSigmoidAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSigmoidWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSigmoidWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSignAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSignAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSignWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSignWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSinAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSinAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSinhAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSinhAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSinhWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSinhWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSinWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSinWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSpropAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSpropAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSpropWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSpropWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSqrtAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSqrtAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSqrtWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSqrtWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSum(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
Computes c = sum(A), where A is a dense vectors.
- vectSum(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSum(double[], char[], int, int, int) - Static method in class org.apache.sysml.runtime.compress.utils.LinearAlgebraUtils
-
- vectSum(double[], int, int) - Static method in class org.apache.sysml.runtime.compress.utils.LinearAlgebraUtils
-
- vectSumsq(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectSumsq(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectTanAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectTanAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectTanhAdd(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectTanhAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectTanhWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectTanhWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectTanWrite(double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectTanWrite(double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectWrite(double[], double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectWrite(boolean[], boolean[], int[]) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectWrite(boolean[], boolean[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectXorAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
Computes c = xor(A,B)
- vectXorAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectXorAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectXorAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectXorWrite(double[], double, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectXorWrite(double, double[], int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectXorWrite(double[], double[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectXorWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectXorWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectXorWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- vectXorWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysml.runtime.codegen.LibSpoofPrimitives
-
- verifySparkVersionSupported(SparkSession) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Check that the Spark version is supported.
- version() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Obtain the SystemML version number.
- version() - Method in class org.apache.sysml.api.mlcontext.ProjectInfo
-
Obtain the project version from the manifest.
- VERSION_NOT_AVAILABLE - Static variable in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Version not available message.