- base - Variable in class org.apache.sysml.runtime.matrix.data.Tagged
-
- BASIC_DATA_TYPES - Static variable in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Basic data types supported by the MLContext API
- beginCol - Variable in class org.apache.sysml.runtime.instructions.Instruction
-
- beginLine - Variable in class org.apache.sysml.runtime.instructions.Instruction
-
- bias - Variable in class org.apache.sysml.runtime.matrix.data.ConvolutionParameters
-
- biasAdd(MatrixObject, MatrixObject, MatrixObject) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs the operation corresponding to the DML script:
ones = matrix(1, rows=1, cols=Hout*Wout)
output = input + matrix(bias %*% ones, rows=1, cols=F*Hout*Wout)
This operation is often followed by conv2d and hence we have introduced bias_add(input, bias) built-in function
- biasAdd(MatrixBlock, MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
Performs the operation corresponding to the DML script:
ones = matrix(1, rows=1, cols=Hout*Wout)
output = input + matrix(bias %*% ones, rows=1, cols=F*Hout*Wout)
This operation is often followed by conv2d and hence we have introduced bias_add(input, bias) built-in function
- BIN_CAPACITY - Static variable in class org.apache.sysml.runtime.compress.cocode.ColumnGroupPartitionerBinPacking
-
- BinaryBlockFrame - Class in org.apache.sysml.api.mlcontext
-
BinaryBlockFrame stores data as a SystemML binary-block frame representation.
- BinaryBlockFrame(Dataset<Row>, FrameMetadata) - Constructor for class org.apache.sysml.api.mlcontext.BinaryBlockFrame
-
Convert a Spark DataFrame to a SystemML binary-block representation.
- BinaryBlockFrame(Dataset<Row>, long, long) - Constructor for class org.apache.sysml.api.mlcontext.BinaryBlockFrame
-
Convert a Spark DataFrame to a SystemML binary-block representation,
specifying the number of rows and columns.
- BinaryBlockFrame(Dataset<Row>) - Constructor for class org.apache.sysml.api.mlcontext.BinaryBlockFrame
-
Convert a Spark DataFrame to a SystemML binary-block representation.
- BinaryBlockFrame(JavaPairRDD<Long, FrameBlock>, MatrixCharacteristics) - Constructor for class org.apache.sysml.api.mlcontext.BinaryBlockFrame
-
Create a BinaryBlockFrame, specifying the SystemML binary-block frame and
its metadata.
- BinaryBlockFrame(JavaPairRDD<Long, FrameBlock>, FrameMetadata) - Constructor for class org.apache.sysml.api.mlcontext.BinaryBlockFrame
-
Create a BinaryBlockFrame, specifying the SystemML binary-block frame and
its metadata.
- BinaryBlockFrameInputInfo - Static variable in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- BinaryBlockFrameOutputInfo - Static variable in class org.apache.sysml.runtime.matrix.data.OutputInfo
-
- BinaryBlockInputInfo - Static variable in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- BinaryBlockMatrix - Class in org.apache.sysml.api.mlcontext
-
BinaryBlockMatrix stores data as a SystemML binary-block matrix representation.
- BinaryBlockMatrix(Dataset<Row>, MatrixMetadata) - Constructor for class org.apache.sysml.api.mlcontext.BinaryBlockMatrix
-
Convert a Spark DataFrame to a SystemML binary-block representation.
- BinaryBlockMatrix(Dataset<Row>, long, long) - Constructor for class org.apache.sysml.api.mlcontext.BinaryBlockMatrix
-
Convert a Spark DataFrame to a SystemML binary-block representation,
specifying the number of rows and columns.
- BinaryBlockMatrix(Dataset<Row>) - Constructor for class org.apache.sysml.api.mlcontext.BinaryBlockMatrix
-
Convert a Spark DataFrame to a SystemML binary-block representation.
- BinaryBlockMatrix(JavaPairRDD<MatrixIndexes, MatrixBlock>, MatrixCharacteristics) - Constructor for class org.apache.sysml.api.mlcontext.BinaryBlockMatrix
-
Create a BinaryBlockMatrix, specifying the SystemML binary-block matrix
and its metadata.
- binaryBlockMatrixToJavaRDDStringIJV(BinaryBlockMatrix) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert an BinaryBlockMatrix
to a JavaRDD<String>
in IVJ
format.
- binaryBlockMatrixToRDDStringIJV(BinaryBlockMatrix) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert an BinaryBlockMatrix
to a RDD<String>
in IVJ
format.
- BinaryBlockOutputInfo - Static variable in class org.apache.sysml.runtime.matrix.data.OutputInfo
-
- binaryBlocksToFrameObject(String, JavaPairRDD<Long, FrameBlock>) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a JavaPairRDD<Long, FrameBlock>
to a FrameObject
.
- binaryBlocksToFrameObject(String, JavaPairRDD<Long, FrameBlock>, FrameMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a JavaPairRDD<Long, FrameBlock>
to a FrameObject
.
- binaryBlocksToMatrixObject(String, JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a JavaPairRDD<MatrixIndexes, MatrixBlock>
to a
MatrixObject
.
- binaryBlocksToMatrixObject(String, JavaPairRDD<MatrixIndexes, MatrixBlock>, MatrixMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a JavaPairRDD<MatrixIndexes, MatrixBlock>
to a
MatrixObject
.
- BinaryBlockToBinaryCellConverter - Class in org.apache.sysml.runtime.matrix.data
-
- BinaryBlockToBinaryCellConverter() - Constructor for class org.apache.sysml.runtime.matrix.data.BinaryBlockToBinaryCellConverter
-
- binaryBlockToCsv(JavaPairRDD<Long, FrameBlock>, MatrixCharacteristics, CSVFileFormatProperties, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- binaryBlockToCsv(JavaPairRDD<MatrixIndexes, MatrixBlock>, MatrixCharacteristics, CSVFileFormatProperties, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtils
-
- binaryBlockToDataFrame(SparkSession, JavaPairRDD<Long, FrameBlock>, MatrixCharacteristics, Expression.ValueType[]) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- binaryBlockToDataFrame(SQLContext, JavaPairRDD<Long, FrameBlock>, MatrixCharacteristics, Expression.ValueType[]) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
Deprecated.
- binaryBlockToDataFrame(SparkSession, JavaPairRDD<MatrixIndexes, MatrixBlock>, MatrixCharacteristics, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtils
-
- binaryBlockToDataFrame(SQLContext, JavaPairRDD<MatrixIndexes, MatrixBlock>, MatrixCharacteristics, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtils
-
Deprecated.
- binaryBlockToLabeledPoints(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtils
-
Converter from binary block rdd to rdd of labeled points.
- binaryBlockToMatrixBlock(JavaPairRDD<Long, FrameBlock>, MatrixCharacteristics, MatrixCharacteristics) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- BinaryBlockToRowBlockConverter - Class in org.apache.sysml.runtime.matrix.data
-
- BinaryBlockToRowBlockConverter() - Constructor for class org.apache.sysml.runtime.matrix.data.BinaryBlockToRowBlockConverter
-
- binaryBlockToTextCell(JavaPairRDD<Long, FrameBlock>, MatrixCharacteristics) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- binaryBlockToTextCell(JavaPairRDD<MatrixIndexes, MatrixBlock>, MatrixCharacteristics) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtils
-
- BinaryBlockToTextCellConverter - Class in org.apache.sysml.runtime.matrix.data
-
- BinaryBlockToTextCellConverter() - Constructor for class org.apache.sysml.runtime.matrix.data.BinaryBlockToTextCellConverter
-
- BinaryCellInputInfo - Static variable in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- BinaryCellOutputInfo - Static variable in class org.apache.sysml.runtime.matrix.data.OutputInfo
-
- binaryCellToBinaryBlock(JavaSparkContext, JavaPairRDD<MatrixIndexes, MatrixCell>, MatrixCharacteristics, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtils
-
- BinaryCellToRowBlockConverter - Class in org.apache.sysml.runtime.matrix.data
-
- BinaryCellToRowBlockConverter() - Constructor for class org.apache.sysml.runtime.matrix.data.BinaryCellToRowBlockConverter
-
- BinaryCellToTextConverter - Class in org.apache.sysml.runtime.matrix.data
-
- BinaryCellToTextConverter() - Constructor for class org.apache.sysml.runtime.matrix.data.BinaryCellToTextConverter
-
- BinaryObject - Class in org.apache.sysml.udf
-
Class to represent an object.
- BinaryObject(Object) - Constructor for class org.apache.sysml.udf.BinaryObject
-
constructor that takes object as param
- binaryOperations(BinaryOperator, MatrixValue, MatrixValue) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- binaryOperations(BinaryOperator, MatrixValue, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- binaryOperations(BinaryOperator, MatrixValue, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- binaryOperations(BinaryOperator, MatrixValue, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- binaryOperations(BinaryOperator, MatrixValue, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- binaryOperationsInPlace(BinaryOperator, MatrixValue) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- binaryOperationsInPlace(BinaryOperator, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- binaryOperationsInPlace(BinaryOperator, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- binaryOperationsInPlace(BinaryOperator, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- binaryOperationsInPlace(BinaryOperator, MatrixValue) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- BinarySPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- BinarySPInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.BinarySPInstruction
-
- bincellOp(MatrixBlock, MatrixBlock, ScalarOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixBincell
-
matrix-scalar, scalar-matrix binary operations.
- bincellOp(MatrixBlock, MatrixBlock, MatrixBlock, BinaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixBincell
-
matrix-matrix binary operations, MM, MV
- bincellOpInPlace(MatrixBlock, MatrixBlock, BinaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixBincell
-
NOTE: operations in place always require m1 and m2 to be of equal dimensions
- BinningWrapper - Class in org.apache.sysml.udf.lib
-
Wrapper class for binning a sorted input vector
- BinningWrapper() - Constructor for class org.apache.sysml.udf.lib.BinningWrapper
-
- BinUaggChainSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- BinUaggChainSPInstruction(CPOperand, CPOperand, BinaryOperator, AggregateUnaryOperator, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.BinUaggChainSPInstruction
-
- BinUaggChainSPInstruction.RDDBinUaggChainFunction - Class in org.apache.sysml.runtime.instructions.spark
-
- BITMAP_BLOCK_SZ - Static variable in class org.apache.sysml.runtime.compress.BitmapEncoder
-
Size of the blocks used in a blocked bitmap representation.
- BitmapDecoderOLE - Class in org.apache.sysml.runtime.compress
-
General-purpose iterator to decode a compressed OLE bitmap.
- BitmapDecoderOLE(char[], int, int) - Constructor for class org.apache.sysml.runtime.compress.BitmapDecoderOLE
-
Point this object at the beginning of a particular bitmap.
- BitmapDecoderRLE - Class in org.apache.sysml.runtime.compress
-
General-purpose iterator to decode a compressed OLE bitmap.
- BitmapDecoderRLE(char[], int, int) - Constructor for class org.apache.sysml.runtime.compress.BitmapDecoderRLE
-
Point this object at the beginning of a particular bitmap.
- BitmapEncoder - Class in org.apache.sysml.runtime.compress
-
Static functions for encoding bitmaps in various ways.
- BitmapEncoder() - Constructor for class org.apache.sysml.runtime.compress.BitmapEncoder
-
- block - Variable in class org.apache.sysml.api.MLBlock
-
Deprecated.
- blockDimX - Variable in class org.apache.sysml.runtime.instructions.gpu.context.ExecutionConfig
-
- blockDimY - Variable in class org.apache.sysml.runtime.instructions.gpu.context.ExecutionConfig
-
- blockDimZ - Variable in class org.apache.sysml.runtime.instructions.gpu.context.ExecutionConfig
-
- BlockRow() - Constructor for class org.apache.sysml.runtime.matrix.CSVReblockMR.BlockRow
-
- bothSparseMatmult(MatrixObject, MatrixObject, MatrixObject, boolean, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Sparse C = Sparse op(A) * Sparse op(B)
Reroutes call to sparse matrix-vector mult if needed
- BUFFER_SIZE - Static variable in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- buildTime() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Obtain the SystemML jar file build time.
- buildTime() - Method in class org.apache.sysml.api.mlcontext.ProjectInfo
-
Object the artifact build time from the manifest.
- BuiltinBinarySPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- BuiltinBinarySPInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.BuiltinBinarySPInstruction
-
- BuiltinUnaryGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- BuiltinUnaryGPUInstruction(Operator, CPOperand, CPOperand, int, String, String) - Constructor for class org.apache.sysml.runtime.instructions.gpu.BuiltinUnaryGPUInstruction
-
- BuiltinUnarySPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- BuiltinUnarySPInstruction(Operator, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.BuiltinUnarySPInstruction
-
- bVal - Variable in class org.apache.sysml.udf.lib.RowClassMeet.ClassLabels
-
- C - Variable in class org.apache.sysml.runtime.matrix.data.ConvolutionParameters
-
- 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.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(MatrixBlock) - Method in class org.apache.sysml.runtime.instructions.spark.CompressionSPInstruction.CompressionFunction
-
- 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<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(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
-
- capacity() - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
- cardRatio - Variable in class org.apache.sysml.runtime.compress.cocode.PlanningCoCoder.GroupableColInfo
-
- CastSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- CastSPInstruction(Operator, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.CastSPInstruction
-
- CellIndex(int, int) - Constructor for class org.apache.sysml.runtime.matrix.data.MatrixValue.CellIndex
-
- CentralMomentSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- CentralMomentSPInstruction(CMOperator, CPOperand, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.CentralMomentSPInstruction
-
- 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
-
- 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
-
- 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
-
- CheckpointSPInstruction(Operator, CPOperand, CPOperand, StorageLevel, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.CheckpointSPInstruction
-
- 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
-
Basic debugging primitive to check sparse block column ordering.
- checkType(MatrixValue) - Static method in class org.apache.sysml.runtime.matrix.data.MatrixPackedCell
-
- ClassLabelComparator() - Constructor for class org.apache.sysml.udf.lib.RowClassMeet.ClassLabelComparator
-
- ClassLabels(double, double) - Constructor for class org.apache.sysml.udf.lib.RowClassMeet.ClassLabels
-
- className - Variable in class org.apache.sysml.udf.ExternalFunctionInvocationInstruction
-
- 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.
- 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.
- clearAll() - Method in class org.apache.sysml.api.mlcontext.Script
-
Clear the script string, inputs, outputs, and symbol table.
- clearData() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- 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.
- 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.
- clearSymbolTable() - Method in class org.apache.sysml.api.mlcontext.Script
-
Clear the symbol table.
- clen - Variable in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- clens - Variable in class org.apache.sysml.runtime.matrix.CSVReblockMR.AssignRowIDMRReturn
-
- clone() - Method in class org.apache.sysml.runtime.matrix.data.NumItemsByEachReducerMetaData
-
- clone() - Method in class org.apache.sysml.runtime.matrix.MatrixDimensionsMetaData
-
- clone() - Method in class org.apache.sysml.runtime.matrix.MatrixFormatMetaData
-
- clone() - Method in class org.apache.sysml.runtime.matrix.MetaData
-
- 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(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
-
- 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.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
- 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
-
- 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(ArrayList<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.JCudaObject.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
-
- colsPerBlock() - Method in class org.apache.sysml.api.MLMatrix
-
Deprecated.
- 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(cusparseHandle, int, int, Pointer) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject
-
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() - 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.
- 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(RDDSortUtils.ValueIndexPair, RDDSortUtils.ValueIndexPair) - Method in class org.apache.sysml.runtime.instructions.spark.utils.RDDSortUtils.IndexComparator
-
- compare(ConvolutionParameters) - Method in class org.apache.sysml.runtime.matrix.data.ConvolutionParameters
-
- 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
-
- compare(RowClassMeet.ClassLabels, RowClassMeet.ClassLabels) - Method in class org.apache.sysml.udf.lib.RowClassMeet.ClassLabelComparator
-
- 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
-
- 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(Operator, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.CompressionSPInstruction
-
- 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) - Constructor for class org.apache.sysml.runtime.compress.CompressedMatrixBlock.CompressionStatistics
-
- ComputationSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- ComputationSPInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.ComputationSPInstruction
-
- ComputationSPInstruction(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
-
- 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.
- computeNNZperBlock(long, long, int, int, double) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDatagen
-
- 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
-
- 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.udf.ExternalFunctionInvocationInstruction
-
- 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.
- 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
-
- conv2d(MatrixObject, MatrixObject, MatrixObject, int, int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- conv2d(MatrixBlock, MatrixBlock, MatrixBlock, ConvolutionParameters) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
- conv2dBackwardData(MatrixObject, MatrixObject, MatrixObject, int, int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
This method computes the backpropogation errors for previous layer of convolution operation
- conv2dBackwardData(MatrixBlock, MatrixBlock, MatrixBlock, ConvolutionParameters) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
This method computes the backpropogation errors for previous layer of convolution operation
- conv2dBackwardFilter(MatrixObject, MatrixObject, MatrixObject, int, int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
This method computes the backpropogation errors for filter of convolution operation
- conv2dBackwardFilter(MatrixBlock, MatrixBlock, MatrixBlock, ConvolutionParameters) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
This method computes the backpropogation errors for filter of convolution operation
- 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
-
- 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 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.
- convertToStringFrame(String, String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Converts an input string representation of a frame in textcell format
into a dense string array.
- convertToStringFrame(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 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.
- ConvolutionGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- ConvolutionGPUInstruction(CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.gpu.ConvolutionGPUInstruction
-
- ConvolutionGPUInstruction(CPOperand, CPOperand, CPOperand, String, String, ArrayList<CPOperand>, ArrayList<CPOperand>, ArrayList<CPOperand>, ArrayList<CPOperand>) - Constructor for class org.apache.sysml.runtime.instructions.gpu.ConvolutionGPUInstruction
-
- ConvolutionParameters - 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
- ConvolutionParameters(long, long, long, long, long, long, long, long, long, long, long, int) - Constructor for class org.apache.sysml.runtime.matrix.data.ConvolutionParameters
-
- ConvolutionParameters(int, int, int, int, int, int, int, int, int, int, int, int) - Constructor for class org.apache.sysml.runtime.matrix.data.ConvolutionParameters
-
- 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() - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- 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.SparseRow
-
- 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() - Method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject
-
- copyNonZerosToRowCol(MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysml.runtime.compress.utils.LinearAlgebraUtils
-
- copySparseBlock(SparseBlock.Type, SparseBlock, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.SparseBlockFactory
-
- copyToDevice(JCudaObject.CSRPointer, int, long, int[], int[], double[]) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject.CSRPointer
-
Static method to copy a CSR sparse matrix from Host to Device
- copyToHost(JCudaObject.CSRPointer, int, long, int[], int[], double[]) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject.CSRPointer
-
Static method to copy a CSR sparse matrix from Device to host
- copyUpperToLowerTriangle(MatrixBlock) - Static method in class org.apache.sysml.runtime.compress.utils.LinearAlgebraUtils
-
- count - Variable in class org.apache.sysml.runtime.matrix.CSVReblockMR.OffsetCount
-
- 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
-
- 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
-
- CovarianceSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- CovarianceSPInstruction(COVOperator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.CovarianceSPInstruction
-
- CovarianceSPInstruction(COVOperator, CPOperand, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.CovarianceSPInstruction
-
- 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).
- CpmmSPInstruction(Operator, CPOperand, CPOperand, CPOperand, AggBinaryOp.SparkAggType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.CpmmSPInstruction
-
- 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.
- createArgumentsMap(boolean, String[]) - Static method in class org.apache.sysml.api.DMLScript
-
- 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
-
- createGPUObject(MatrixObject) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
- createHistoryForScript(Script, long) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Generate a String history entry for a script.
- 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
-
- 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
-
- CSVFileFormatProperties - Class in org.apache.sysml.runtime.matrix.data
-
- CSVFileFormatProperties() - Constructor for class org.apache.sysml.runtime.matrix.data.CSVFileFormatProperties
-
- CSVFileFormatProperties(boolean, String, boolean, double, String) - Constructor for class org.apache.sysml.runtime.matrix.data.CSVFileFormatProperties
-
- CSVFileFormatProperties(boolean, String, boolean) - Constructor for class org.apache.sysml.runtime.matrix.data.CSVFileFormatProperties
-
- 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
-
- cublasHandle - Static variable in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- cudnnHandle - Static variable in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- 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
-
- CumulativeAggregateSPInstruction(AggregateUnaryOperator, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.CumulativeAggregateSPInstruction
-
- CumulativeOffsetSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- CumulativeOffsetSPInstruction(Operator, CPOperand, CPOperand, CPOperand, double, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.CumulativeOffsetSPInstruction
-
- currContext - Static variable in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
- cusparseHandle - 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(String, Dataset<Row>) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a DataFrame
to a FrameObject
.
- dataFrameToFrameObject(String, 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(String, Dataset<Row>) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a DataFrame
to a MatrixObject
.
- dataFrameToMatrixObject(String, 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
-
- 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
-
- deallocate() - Method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject.CSRPointer
-
Calls cudaFree on the allocated Pointer
instances
- DEBUG - Static variable in class org.apache.sysml.runtime.instructions.gpu.context.JCudaContext
-
enable this to print debug information before code pertaining to the GPU is executed
- debugString(Pointer, long, long) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject
-
Gets the double array from GPU memory onto host memory and returns string.
- 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, 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_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
-
- 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.SparseRow
-
- deleteRemoveVariableInstructions(Program) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Delete the 'remove variable' instructions from a runtime program.
- DeNaNWrapper - Class in org.apache.sysml.udf.lib
-
Deprecated.
- DeNaNWrapper() - Constructor for class org.apache.sysml.udf.lib.DeNaNWrapper
-
Deprecated.
- DeNegInfinityWrapper - Class in org.apache.sysml.udf.lib
-
Deprecated.
- DeNegInfinityWrapper() - Constructor for class org.apache.sysml.udf.lib.DeNegInfinityWrapper
-
Deprecated.
- denseBlock - Variable in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- denseDenseMatmult(MatrixObject, MatrixObject, MatrixObject, boolean, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Dense dense matrix multiply
C = op(A) * op(B), A and B are dense matrices
- denseDenseMatmult(Pointer, int, int, int, int, boolean, boolean, Pointer, Pointer) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Dense-dense matrix multiply
C = op(A) * op(B), A and B are dense matrices
On the host, the matrices are in row-major format; cuBLAS expects them in column-major format.
- denseScalarOperationsInPlace(ScalarOperator) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- denseScalarOperationsInPlace(ScalarOperator) - Method in class org.apache.sysml.runtime.matrix.data.WeightedCell
-
- denseSparseMatmult(MatrixObject, MatrixObject, MatrixObject, boolean, boolean, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
C = op(A) * op(B) where A is dense and B is sparse
If B is ultrasparse, A is converted to a sparse matrix and sparseSparseMatmult(MatrixObject, int, int, int, int, int, CSRPointer, CSRPointer)
is invoked
otherwise B is converted to a dense matrix and denseDenseMatmult(Pointer, int, int, int, int, boolean, boolean, Pointer, Pointer)
is invoked.
- denseToSparse() - Method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject
-
Converts this JCudaObject from dense to sparse format.
- 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.JCudaObject.CSRPointer
-
descriptor of matrix, only CUSPARSE_MATRIX_TYPE_GENERAL supported
- destroy() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
- destroy() - Method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaContext
-
- 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
- deviceCount - Static variable in class org.apache.sysml.runtime.instructions.gpu.context.JCudaContext
-
The total number of cuda devices on this machine
- 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
-
- diag - Variable in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- 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
-
- 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.
- displayScriptHistory(List<String>) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Generate a String listing of the script execution history.
- 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.
- divide(MLMatrix) - Method in class org.apache.sysml.api.MLMatrix
-
Deprecated.
- divide(Double) - Method in class org.apache.sysml.api.MLMatrix
-
Deprecated.
- 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.
- 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.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
-
- 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) - 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
-
- 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
.
- dropLastRowsOrColums(PartialAggregate.CorrectionLocationType) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- 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.
- eitherSparseMatmult(MatrixObject, MatrixObject, MatrixObject, boolean, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
One of the matrices is sparse, the other dense
C = op(A) x op(B)
- ELEMENT_DELIM - Static variable in class org.apache.sysml.udf.ExternalFunctionInvocationInstruction
-
- elementWiseMultiply(MLMatrix) - Method in class org.apache.sysml.api.MLMatrix
-
Deprecated.
- elementWiseMultiply(Double) - Method in class org.apache.sysml.api.MLMatrix
-
Deprecated.
- ENABLE_DEBUG_MODE - Static variable in class org.apache.sysml.api.DMLScript
-
- end_indexes_h - Variable in class org.apache.sysml.runtime.matrix.data.ConvolutionParameters
-
- end_indexes_w - Variable in class org.apache.sysml.runtime.matrix.data.ConvolutionParameters
-
- endCol - Variable in class org.apache.sysml.runtime.instructions.Instruction
-
- endLine - Variable in class org.apache.sysml.runtime.instructions.Instruction
-
- ensureAllocatedColumns(int) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Allocate column data structures if necessary, i.e., if schema specified
but not all column data structures created yet.
- ensureColumnCompatibility(int) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
Checks for matching column sizes in case of existing columns.
- ensureComputeCapability() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Ensures that all the CUDA cards on the current system are
of the minimum required compute capability.
- ensureComputeCapability() - Method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaContext
-
- entrySet() - Method in class org.apache.sysml.runtime.matrix.data.CTableMap
-
Deprecated.
- equals(Object) - Method in class org.apache.sysml.runtime.compress.cocode.PlanningCoCodingGroup.ColIndexes
-
- equals(Object) - Method in class org.apache.sysml.runtime.compress.cocode.PlanningCoCodingGroup
-
- equals(Object) - Method in class org.apache.sysml.runtime.compress.utils.DblArray
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.CSVReblockMR.OffsetCount
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.data.AdaptivePartialBlock
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.data.MatrixIndexes
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.data.MatrixPackedCell
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue.CellIndex
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.data.OutputInfo
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.data.PartialBlock
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.data.Tagged
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.data.TaggedMatrixIndexes
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.data.TaggedTripleIndexes
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.data.TripleIndexes
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.data.WeightedCell
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.data.WeightedPair
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.MatrixDimensionsMetaData
-
- equals(Object) - Method in class org.apache.sysml.runtime.matrix.MetaData
-
- ERROR_MSG_DELIMITER - Static variable in exception org.apache.sysml.api.DMLException
-
- estimateCompressedColGroupSize(int[]) - Method in class org.apache.sysml.runtime.compress.estim.CompressedSizeEstimator
-
- estimateCompressedColGroupSize(UncompressedBitmap) - Method in class org.apache.sysml.runtime.compress.estim.CompressedSizeEstimator
-
- estimateCompressedColGroupSize(int[]) - Method in class org.apache.sysml.runtime.compress.estim.CompressedSizeEstimatorExact
-
- estimateCompressedColGroupSize(UncompressedBitmap) - Method in class org.apache.sysml.runtime.compress.estim.CompressedSizeEstimatorExact
-
- estimateCompressedColGroupSize(int[]) - Method in class org.apache.sysml.runtime.compress.estim.CompressedSizeEstimatorSample
-
- estimateCompressedColGroupSize(UncompressedBitmap) - Method in class org.apache.sysml.runtime.compress.estim.CompressedSizeEstimatorSample
-
- estimateCompressedSizeInMemory() - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
Obtain an upper bound on the memory used to store the compressed block.
- estimatedNNzsPerRow - Variable in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- estimatedNonZeros - Variable in class org.apache.sysml.runtime.matrix.data.MatrixBlock.SparsityEstimate
-
- estimateInMemorySize() - Method in class org.apache.sysml.runtime.compress.ColGroup
-
Note: Must be overridden by child classes to account for additional data
and metadata
- estimateInMemorySize() - Method in class org.apache.sysml.runtime.compress.ColGroupDDC
-
- estimateInMemorySize() - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- estimateInMemorySize() - Method in class org.apache.sysml.runtime.compress.ColGroupDDC2
-
- estimateInMemorySize() - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- estimateInMemorySize() - Method in class org.apache.sysml.runtime.compress.ColGroupUncompressed
-
- estimateInMemorySize() - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- estimateMemory(long, long, double) - Static method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
Get the estimated in-memory size of the sparse block in COO
with the given dimensions w/o accounting for overallocation.
- estimateMemory(long, long, double) - Static method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
Get the estimated in-memory size of the sparse block in CSR
with the given dimensions w/o accounting for overallocation.
- estimateMemory(long, long, double) - Static method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
Get the estimated in-memory size of the sparse block in MCSR
with the given dimensions w/o accounting for overallocation.
- estimateSize(long, long) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject.CSRPointer
-
Estimate the size of a CSR matrix in GPU memory
Size of pointers is not needed and is not added in
- estimateSizeDenseInMemory(long, long) - Static method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- estimateSizeInMemory() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- estimateSizeInMemory(long, long, double) - Static method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- estimateSizeOnDisk() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- estimateSizeOnDisk(long, long, long) - Static method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- estimateSizeSparseInMemory(long, long, double) - Static method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- estimateSizeSparseInMemory(SparseBlock.Type, long, long, double) - Static method in class org.apache.sysml.runtime.matrix.data.SparseBlockFactory
-
- estimateSparsityOnAggBinary(MatrixBlock, MatrixBlock, AggregateBinaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- estSize - Variable in class org.apache.sysml.runtime.compress.CompressedMatrixBlock.CompressionStatistics
-
- evalSparseFormatInMemory() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Evaluates if this matrix block should be in sparse format in
memory.
- evalSparseFormatInMemory(long, long, long) - Static method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Evaluates if a matrix block with the given characteristics should be in sparse format
in memory.
- evalSparseFormatOnDisk() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Evaluates if this matrix block should be in sparse format on
disk.
- evalSparseFormatOnDisk(long, long, long) - Static method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Evaluates if a matrix block with the given characteristics should be in sparse format
on disk (or in any other serialized representation).
- evict(long) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
Cycles through the sorted list of allocated
GPUObject
instances.
- evictionPolicy - Static variable in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- examSparsity() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Evaluates if this matrix block should be in sparse format in
memory.
- execute(String, Map<String, String>, boolean, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Execute DML script by passing named arguments using specified config file.
- execute(String, Map<String, String>, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Execute DML script by passing named arguments using specified config file.
- execute(String, Map<String, String>) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Execute DML script by passing named arguments with default configuration.
- execute(String, Map<String, String>) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Execute DML script by passing named arguments.
- execute(String, Map<String, String>, boolean) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Experimental: Execute PyDML script by passing named arguments if parsePyDML=true.
- execute(String, Map<String, String>, boolean) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Experimental: Execute PyDML script by passing named arguments if parsePyDML=true.
- execute(String, String[], String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Execute DML script by passing positional arguments using specified config file
- execute(String, ArrayList<String>, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Execute DML script by passing positional arguments using specified config file
This method is implemented for compatibility with Python MLContext.
- execute(String, String[]) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Execute DML script by passing positional arguments using default configuration
- execute(String, ArrayList<String>) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Execute DML script by passing positional arguments using default configuration.
- execute(String, ArrayList<String>, boolean) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Experimental: Execute DML script by passing positional arguments if parsePyDML=true, using default configuration.
- execute(String, ArrayList<String>, boolean, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Experimental: Execute DML script by passing positional arguments if parsePyDML=true, using specified config file.
- execute(String, ArrayList<String>, ArrayList<String>, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Execute DML script by passing positional arguments using specified config file
- execute(String, ArrayList<String>, ArrayList<String>) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Execute DML script by passing positional arguments using specified config file
- execute(String, String[], boolean, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Experimental: Execute DML script by passing positional arguments if parsePyDML=true, using specified config file.
- execute(String, String[], boolean) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Experimental: Execute DML script by passing positional arguments if parsePyDML=true, using default configuration.
- execute(String, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Execute DML script without any arguments using specified config path
- execute(String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Execute DML script without any arguments using default configuration.
- execute(String, boolean, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Experimental: Execute DML script without any arguments if parsePyDML=true, using specified config path.
- execute(String, boolean) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Experimental: Execute DML script without any arguments if parsePyDML=true, using default configuration.
- execute(Script) - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Execute a DML or PYDML Script.
- execute(Script, ScriptExecutor) - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Execute a DML or PYDML Script object using a ScriptExecutor.
- execute(Script) - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Execute a DML or PYDML script.
- execute() - Method in class org.apache.sysml.udf.lib.BinningWrapper
-
- execute() - Method in class org.apache.sysml.udf.lib.CumSumProd
-
- execute() - Method in class org.apache.sysml.udf.lib.DeNaNWrapper
-
Deprecated.
- execute() - Method in class org.apache.sysml.udf.lib.DeNegInfinityWrapper
-
Deprecated.
- execute() - Method in class org.apache.sysml.udf.lib.DynamicProjectMatrixCP
-
- execute() - Method in class org.apache.sysml.udf.lib.DynamicReadMatrixCP
-
- execute() - Method in class org.apache.sysml.udf.lib.DynamicReadMatrixRcCP
-
- execute() - Method in class org.apache.sysml.udf.lib.DynamicWriteMatrixCP
-
Deprecated.
- execute() - Method in class org.apache.sysml.udf.lib.GatherWrapper
-
- execute() - Method in class org.apache.sysml.udf.lib.MultiInputCbind
-
- execute() - Method in class org.apache.sysml.udf.lib.OrderWrapper
-
Deprecated.
- execute() - Method in class org.apache.sysml.udf.lib.PermutationMatrixWrapper
-
Deprecated.
- execute() - Method in class org.apache.sysml.udf.lib.RemoveEmptyRows
-
Deprecated.
- execute() - Method in class org.apache.sysml.udf.lib.RowClassMeet
-
- execute() - Method in class org.apache.sysml.udf.lib.SGDNesterovUpdate
-
- execute() - Method in class org.apache.sysml.udf.lib.TimeWrapper
-
- execute() - Method in class org.apache.sysml.udf.PackageFunction
-
Method that will be executed to perform this function.
- executeRuntimeProgram() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Execute the runtime program.
- executeScript(Configuration, String[]) - Static method in class org.apache.sysml.api.DMLScript
-
Single entry point for all public invocation alternatives (e.g.,
main, executeScript, JaqlUdf etc)
- executeScript() - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Executes the prepared script over the bound inputs, creating the
result variables according to bound and registered outputs.
- executeScript(String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Execute a script stored in a string.
- executeScript(String, boolean) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- executeScript(String, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- executeScript(String, boolean, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- executeScript(String, ArrayList<String>, ArrayList<String>, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- executeScript(String, ArrayList<String>, ArrayList<String>) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- executeScript(String, Map<String, String>) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- executeScript(String, Map<String, String>, boolean) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- executeScript(String, Map<String, String>, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- executeScript(String, Map<String, String>, boolean, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- executeScript(String, Map<String, String>) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- executeScript(String, Map<String, String>, boolean) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- executeScript(String, Map<String, String>, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- executeScript(String, Map<String, String>, boolean, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- ExecutionConfig - Class in org.apache.sysml.runtime.instructions.gpu.context
-
Java Wrapper to specify CUDA execution configuration for launching custom kernels
- ExecutionConfig(int, int, int) - Constructor for class org.apache.sysml.runtime.instructions.gpu.context.ExecutionConfig
-
Convenience constructor for setting the number of blocks, number of threads and the
shared memory size
- ExecutionConfig(int, int) - Constructor for class org.apache.sysml.runtime.instructions.gpu.context.ExecutionConfig
-
- ExecutionConfig(int, int, int, int) - Constructor for class org.apache.sysml.runtime.instructions.gpu.context.ExecutionConfig
-
- executionContext - Variable in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- exp(MLMatrix) - Method in class org.apache.sysml.api.MLMatrix
-
Deprecated.
- EXPLAIN - Static variable in class org.apache.sysml.api.DMLScript
-
- explain() - Method in class org.apache.sysml.api.jmlc.PreparedScript
-
Explain the DML/PyDML program and view result as a string.
- explain - Variable in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- explainLevel - Variable in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- ExternalFunctionInvocationInstruction - Class in org.apache.sysml.udf
-
Class to maintain external function invocation instructions.
- ExternalFunctionInvocationInstruction(String, String, String, String) - Constructor for class org.apache.sysml.udf.ExternalFunctionInvocationInstruction
-
- EXTRACT_SAMPLE_ONCE - Static variable in class org.apache.sysml.runtime.compress.estim.SizeEstimatorFactory
-
- extractBitmap(int[], MatrixBlock) - Static method in class org.apache.sysml.runtime.compress.BitmapEncoder
-
Generate uncompressed bitmaps for a set of columns in an uncompressed
matrix block.
- extractBitmapFromSample(int[], MatrixBlock, int[]) - Static method in class org.apache.sysml.runtime.compress.BitmapEncoder
-
- extractInputMatrices(ExecutionContext) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
Extracts input variables with MATRIX data type, and stores references to
corresponding matrix objects in inputMatrices
.
- extractOutputMatrices(ExecutionContext) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
Extracts MatrixObject references to output variables, all of which will be
of MATRIX data type, and stores them in outputMatrices
.
- extractValues() - Method in class org.apache.sysml.runtime.compress.utils.DblArrayIntListHashMap
-
- extractValues() - Method in class org.apache.sysml.runtime.compress.utils.DoubleIntListHashMap
-
- extractValues() - Method in class org.apache.sysml.runtime.compress.utils.IntArrayList
-
Returns the underlying array of offsets.
- fieldIndex(String) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- FileFormatProperties - Class in org.apache.sysml.runtime.matrix.data
-
- FileFormatProperties() - Constructor for class org.apache.sysml.runtime.matrix.data.FileFormatProperties
-
- FileFormatProperties(FileFormatProperties.FileFormat) - Constructor for class org.apache.sysml.runtime.matrix.data.FileFormatProperties
-
- FileFormatProperties.FileFormat - Enum in org.apache.sysml.runtime.matrix.data
-
- filename - Variable in class org.apache.sysml.runtime.matrix.CSVReblockMR.OffsetCount
-
- fileOffset - Variable in class org.apache.sysml.runtime.matrix.CSVReblockMR.OffsetCount
-
- 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
.
- 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
-
- FORCE_ACCELERATOR - Static variable in class org.apache.sysml.api.DMLScript
-
- 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
-
- 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
-
- FrameIndexingSPInstruction(Operator, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, AggBinaryOp.SparkAggType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.FrameIndexingSPInstruction
-
- FrameIndexingSPInstruction(Operator, 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.
- frameObjectToBinaryBlockFrame(FrameObject, SparkExecutionContext) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a BinaryBlockFrame
.
- 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.
- fromIndexedFrameBlock(Pair<Long, FrameBlock>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- fromIndexedFrameBlock(ArrayList<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(ArrayList<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(ArrayList<IndexedMatrixValue>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- 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
-
- 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, long[], Well1024a, long) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDatagen
-
Function to generate a matrix of random numbers.
- generateRandomMatrix(MatrixBlock, RandomMatrixGenerator, long[], 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
-
- 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(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- 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.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
-
- getActiveMLContext() - Static method in class org.apache.sysml.api.mlcontext.MLContext
-
Retrieve the currently active MLContext.
- getActiveMLContext() - Static method in class org.apache.sysml.api.MLContextProxy
-
- getActiveMLContextForAPI() - Static method in class org.apache.sysml.api.MLContextProxy
-
- getAndAddAvailableMemory(long) - Method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaContext
-
Gets the available memory and then adds value to it
- getArity() - Method in class org.apache.sysml.runtime.instructions.gpu.BuiltinUnaryGPUInstruction
-
- getAs(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- getAs(String) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- getAvailableMemory() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Gets device memory available for SystemML operations
- getAvailableMemory() - Static method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- getAvailableMemory() - Method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaContext
-
- 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
-
- getBinaryAccessType(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixBincell
-
- getBinaryBlockedRDD(String) - Method in class org.apache.sysml.api.MLOutput
-
Deprecated.
- getBinaryBlockMatrix(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a BinaryBlockMatrix
.
- getBinaryBlocks() - Method in class org.apache.sysml.api.mlcontext.BinaryBlockFrame
-
Obtain a SystemML binary-block frame as a
JavaPairRDD<Long, FrameBlock>
- getBinaryBlocks() - Method in class org.apache.sysml.api.mlcontext.BinaryBlockMatrix
-
Obtain a SystemML binary-block matrix as a
JavaPairRDD<MatrixIndexes, MatrixBlock>
- 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(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- 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
-
- getByte(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- getCardinalityRatio() - Method in class org.apache.sysml.runtime.compress.cocode.PlanningCoCodingGroup
-
- getChangeInSize() - Method in class org.apache.sysml.runtime.compress.cocode.PlanningCoCodingGroup
-
- getClassName() - Method in class org.apache.sysml.udf.ExternalFunctionInvocationInstruction
-
- 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
-
- 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
-
- 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.
- 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
-
- getConfigFile() - Method in class org.apache.sysml.udf.ExternalFunctionInvocationInstruction
-
- getConfigForSimpleMatrixOperations(int, int) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.ExecutionConfig
-
Use this for simple matrix operations and use following in the kernel
int ix = blockIdx.x * blockDim.x + threadIdx.x;
int iy = blockIdx.y * blockDim.y + threadIdx.y;
This tries to schedule as minimum grids as possible.
- 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
This tries to schedule as minimum grids as possible.
- getConfiguration() - Method in class org.apache.sysml.udf.PackageFunction
-
Method to get the configuration file name
- getCPType(String) - Static method in class org.apache.sysml.runtime.instructions.InstructionUtils
-
- getCurrentRowIndex() - Method in class org.apache.sysml.runtime.compress.ReaderColumnSelection
-
- getCurrentRowIndex() - Method in class org.apache.sysml.runtime.compress.ReaderColumnSelectionDenseSample
-
- getData(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain an output as a Data
object.
- getData(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC
-
Generic get value for byte-length-agnostic access.
- getData(int, int) - Method in class org.apache.sysml.runtime.compress.ColGroupDDC1
-
- 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.
- getDataFrameRDD(String, JavaSparkContext) - Method in class org.apache.sysml.api.MLOutput
-
Deprecated.
- 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.
- getDate(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- 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
-
- getDecimal(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- getDecodeIterator(int) - Method in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- getDecodeIterator(int) - Method in class org.apache.sysml.runtime.compress.ColGroupOLE
-
- getDecodeIterator(int) - Method in class org.apache.sysml.runtime.compress.ColGroupRLE
-
- getDefaultCuSparseMatrixDescriptor() - Static method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject.CSRPointer
-
- getDefaultSchemaForBinaryBlock() - Static method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- getDelim() - Method in class org.apache.sysml.runtime.matrix.data.CSVFileFormatProperties
-
- getDenseBlock() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- getDenseVector(MatrixBlock) - Static method in class org.apache.sysml.runtime.compress.utils.ConverterUtils
-
- getDescription() - Method in class org.apache.sysml.runtime.matrix.data.FileFormatProperties
-
- getDF(SparkSession, String) - Method in class org.apache.sysml.api.MLOutput
-
Deprecated.
Note, the output DataFrame has an additional column ID.
- getDF(SQLContext, String) - Method in class org.apache.sysml.api.MLOutput
-
Deprecated.
Note, the output DataFrame has an additional column ID.
- getDF(SparkSession, String, boolean) - Method in class org.apache.sysml.api.MLOutput
-
Deprecated.
Obtain the DataFrame
- getDF(SQLContext, String, boolean) - Method in class org.apache.sysml.api.MLOutput
-
Deprecated.
Obtain the DataFrame
- getDF(SparkSession, String, MatrixCharacteristics) - Method in class org.apache.sysml.api.MLOutput
-
Deprecated.
This methods improves the performance of MLPipeline wrappers.
- getDF(SQLContext, String, MatrixCharacteristics) - Method in class org.apache.sysml.api.MLOutput
-
Deprecated.
This methods improves the performance of MLPipeline wrappers.
- getDimsUnknownFilePrefix() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- 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(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- 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
-
- 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.
- getExecutionContext() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Obtain the execution context
- 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
-
- getFileFormat() - Method in class org.apache.sysml.runtime.matrix.data.FileFormatProperties
-
- getFilePath() - Method in class org.apache.sysml.udf.Matrix
-
Method to get file path for matrix.
- getFillValue() - Method in class org.apache.sysml.runtime.matrix.data.CSVFileFormatProperties
-
- getFirstIndex() - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes
-
- getFirstIndex() - Method in class org.apache.sysml.runtime.matrix.data.TripleIndexes
-
- getFloat(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- 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.
- getFrameBinaryBlockedRDD(String) - Method in class org.apache.sysml.api.MLOutput
-
Deprecated.
- getFrameBlock() - Method in class org.apache.sysml.api.mlcontext.BinaryBlockFrame
-
Obtain a SystemML binary-block frame as a FrameBlock
- getFrameFormat() - Method in class org.apache.sysml.api.mlcontext.FrameMetadata
-
Obtain the frame format
- getFrameMetadata() - Method in class org.apache.sysml.api.mlcontext.BinaryBlockFrame
-
Obtain the SystemML binary-block frame metadata
- 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.DeNaNWrapper
-
Deprecated.
- getFunctionOutput(int) - Method in class org.apache.sysml.udf.lib.DeNegInfinityWrapper
-
Deprecated.
- 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.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.PermutationMatrixWrapper
-
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.
- getGPUContext() - Static method in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
Singleton Factory method for creation of
GPUContext
- getGPUInstructionType() - Method in class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- getGPUProperties() - Static method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaContext
-
Gets the device properties for the active GPU (set with cudaSetDevice())
- getGPUProperties(int) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaContext
-
Gets the device properties
- 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
-
- getI() - Method in class org.apache.sysml.runtime.matrix.data.IJV
-
- 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.MatrixFormatMetaData
-
- 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 ($).
- getInputParams() - Method in class org.apache.sysml.udf.ExternalFunctionInvocationInstruction
-
- 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.
- getInt(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- getInternalProxy() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Used internally by MLContextProxy.
- 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
-
- getJavaMap(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- 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
- getJobType() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getKey() - Method in class org.apache.sysml.runtime.matrix.data.Pair
-
- getLeftGroup() - Method in class org.apache.sysml.runtime.compress.cocode.PlanningCoCodingGroup
-
- getLineNum() - Method in class org.apache.sysml.runtime.instructions.Instruction
-
Getter for instruction line number
- getList(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- getLong(String) - Method in class org.apache.sysml.api.jmlc.ResultVariables
-
Obtain the long value represented by the given output variable.
- getLong(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- getLong(String) - Method in class org.apache.sysml.api.mlcontext.MLResults
-
Obtain a long
output
- getMap(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- 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
-
- 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() - Method in class org.apache.sysml.api.mlcontext.BinaryBlockMatrix
-
Obtain a SystemML binary-block matrix as a MatrixBlock
- getMatrixBlock(String) - Method in class org.apache.sysml.api.MLOutput
-
Deprecated.
- getMatrixBlock() - Method in class org.apache.sysml.runtime.matrix.data.AdaptivePartialBlock
-
- getMatrixCharacteristics() - Method in class org.apache.sysml.api.mlcontext.BinaryBlockFrame
-
Obtain the SystemML binary-block frame characteristics
- getMatrixCharacteristics() - Method in class org.apache.sysml.api.mlcontext.BinaryBlockMatrix
-
Obtain the SystemML binary-block matrix characteristics
- getMatrixCharacteristics(String) - Method in class org.apache.sysml.api.MLOutput
-
Deprecated.
- getMatrixCharacteristics(int) - Method in class org.apache.sysml.runtime.matrix.JobReturn
-
- getMatrixCharacteristics() - Method in class org.apache.sysml.runtime.matrix.MatrixDimensionsMetaData
-
- getMatrixFormat() - Method in class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Obtain the matrix format
- getMatrixMetadata() - Method in class org.apache.sysml.api.mlcontext.BinaryBlockMatrix
-
Obtain the SystemML binary-block matrix metadata
- 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() - Static method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaContext
-
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() - Static method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaContext
-
Gets the shared memory per block supported by the active cuda device
- getMaxThreadsPerBlock() - Static method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaContext
-
Gets the maximum number of threads per block for "active" GPU
- getMaxValue() - Method in class org.apache.sysml.runtime.instructions.spark.RandSPInstruction
-
- 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
-
- getMLMatrix(MLContext, SparkSession, String) - Method in class org.apache.sysml.api.MLOutput
-
Deprecated.
- getMLMatrix(MLContext, SQLContext, String) - Method in class org.apache.sysml.api.MLOutput
-
Deprecated.
- getMMTSJType() - Method in class org.apache.sysml.runtime.instructions.gpu.MMTSJGPUInstruction
-
returns left/right depending on the type of MMTSJ instruction
- 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.
- getNAStrings() - Method in class org.apache.sysml.runtime.matrix.data.CSVFileFormatProperties
-
- 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
-
- getNumberOfZero() - Method in class org.apache.sysml.runtime.matrix.data.NumItemsByEachReducerMetaData
-
- getNumColBlocks() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- 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.FrameMetadata
-
Obtain the number of columns
- getNumColumns() - Method in class org.apache.sysml.api.mlcontext.MatrixMetadata
-
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.FrameMetadata
-
Obtain the number of columns per block
- getNumColumnsPerBlock() - Method in class org.apache.sysml.api.mlcontext.MatrixMetadata
-
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.DeNaNWrapper
-
Deprecated.
- getNumFunctionOutputs() - Method in class org.apache.sysml.udf.lib.DeNegInfinityWrapper
-
Deprecated.
- 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.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.PermutationMatrixWrapper
-
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.
- getNumItemsArray() - Method in class org.apache.sysml.runtime.matrix.data.NumItemsByEachReducerMetaData
-
- getNumNonZeros() - Method in class org.apache.sysml.api.mlcontext.FrameMetadata
-
Obtain the number of non-zero values
- getNumNonZeros() - Method in class org.apache.sysml.api.mlcontext.MatrixMetadata
-
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
-
- getNumPreferredPartitions(MatrixCharacteristics, JavaPairRDD<?, ?>) - 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.FrameMetadata
-
Obtain the number of rows
- getNumRows() - Method in class org.apache.sysml.api.mlcontext.MatrixMetadata
-
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.FrameMetadata
-
Obtain the number of rows per block
- getNumRowsPerBlock() - Method in class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Obtain the number of rows per block
- getNumValues() - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
Obtain number of distrinct 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(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.
- 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
-
- getOutputInfo() - Method in class org.apache.sysml.runtime.matrix.MatrixFormatMetaData
-
- getOutputInfos() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getOutputMatrices() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getOutputParams() - Method in class org.apache.sysml.udf.ExternalFunctionInvocationInstruction
-
- 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.data.NumItemsByEachReducerMetaData
-
- getPformats() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- getPrefixFromSparkDebugInfo(String) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- 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
-
- 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
-
- getRowIndex() - Method in class org.apache.sysml.runtime.matrix.data.MatrixIndexes
-
- getRowIndex() - Method in class org.apache.sysml.runtime.matrix.data.PartialBlock
-
- 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
-
- 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
- getScriptByName(String) - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Obtain a script that has executed by name.
- 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.
- getScripts() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Obtain a map of the scripts that have executed.
- 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
-
- getSeq(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- getShort(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- 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.JCudaObject
-
- getSparkContext() - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- getSparkContext() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Obtain the SparkContext associated with this MLContext.
- getSparkContext(MLContext) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Obtain the Spark Context
- 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
-
- getSparseMatrixCudaPointer() - Method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject
-
Convenience method to directly examine the Sparse matrix on GPU
- getSparsity() - Method in class org.apache.sysml.runtime.instructions.spark.RandSPInstruction
-
- getSPInstructionType() - Method in class org.apache.sysml.runtime.instructions.spark.SPInstruction
-
- 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
-
- 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(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- 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
-
- getStringFrameRDD(String, String, CSVFileFormatProperties) - Method in class org.apache.sysml.api.MLOutput
-
Deprecated.
- getStringRDD(String, String) - Method in class org.apache.sysml.api.MLOutput
-
Deprecated.
- 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, 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.
- getStruct(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- 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
-
- getTimestamp(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- 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.Instruction
-
- 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(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.
- getValuesMap(Seq<String>) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- getValueSparseUnsafe(int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- 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.
- getWarpSize() - Static method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaContext
-
Gets the warp size supported by the active cuda device
- getWeight() - Method in class org.apache.sysml.runtime.matrix.data.WeightedCell
-
- globalDataFlowOptimization() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Optimize the program.
- GMR - Class in org.apache.sysml.runtime.matrix
-
- GPU_INST_PREFIX - Static variable in class org.apache.sysml.runtime.instructions.Instruction
-
- GPU_MEMORY_UTILIZATION_FACTOR - Variable in class org.apache.sysml.runtime.instructions.gpu.context.JCudaContext
-
- GPUContext - Class in org.apache.sysml.runtime.instructions.gpu.context
-
- GPUContext() - Constructor for class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
- GPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- GPUInstruction(String, String) - Constructor for class org.apache.sysml.runtime.instructions.gpu.GPUInstruction
-
- 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
-
- GPUObject - Class in org.apache.sysml.runtime.instructions.gpu.context
-
- GPUObject(MatrixObject) - Constructor for class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- GPUObject.EvictionPolicy - Enum in org.apache.sysml.runtime.instructions.gpu.context
-
- 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
-
- 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
-
- 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.
- incrementalAggregate(AggregateOperator, MatrixValue, MatrixValue) - 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) - 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) - 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) - 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) - 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) - 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
-
- incrStats(int, int, int) - Method in class org.apache.sysml.runtime.compress.cocode.PlanningMemoTable
-
- IndexComparator(boolean) - Constructor for class org.apache.sysml.runtime.instructions.spark.utils.RDDSortUtils.IndexComparator
-
- indexes - Variable in class org.apache.sysml.api.MLBlock
-
Deprecated.
- 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(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- 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.SparseBlockMCSR
-
- indexes() - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
- indexInBlock - Variable in class org.apache.sysml.runtime.matrix.CSVReblockMR.BlockRow
-
- IndexingSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- IndexingSPInstruction(Operator, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, AggBinaryOp.SparkAggType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.IndexingSPInstruction
-
- IndexingSPInstruction(Operator, 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(String, int, int, int, int, double, double, double) - Method in class org.apache.sysml.runtime.matrix.data.RandomMatrixGenerator
-
- init(String, int, int, int, int, double, double, double, double) - Method in class org.apache.sysml.runtime.matrix.data.RandomMatrixGenerator
-
- 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.SparseRow
-
- initializeCachingAndScratchSpace() - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Check security, create scratch space, cleanup working directories,
initialize caching, and reset statistics.
- 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
-
- input2 - Variable in class org.apache.sysml.runtime.instructions.spark.ComputationSPInstruction
-
- 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
-
- inputParams - 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.INSTRUCTION_TYPE - 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
-
- integerDivision(MLMatrix) - Method in class org.apache.sysml.api.MLMatrix
-
Deprecated.
- InternalProxy() - Constructor for class org.apache.sysml.api.mlcontext.MLContext.InternalProxy
-
- interQuartileMean() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- interQuartileMeanOLD() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Computes the weighted interQuartileMean.
- INVESTIGATE_ESTIMATES - Static variable in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- isActive() - Static method in class org.apache.sysml.api.MLContextProxy
-
- 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.instructions.gpu.context.JCudaObject
-
- isAllocated() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- 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
-
- 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
-
- 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, BinaryBlockMatrix, Matrix, double[][], MatrixBlock, URL)
- isCompressed() - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
Obtain whether this block is in compressed form or not.
- 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.
- isDeviceCopyModified - Variable in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- isDiag() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- 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?
- 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
-
- 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.
- isFill() - Method in class org.apache.sysml.runtime.matrix.data.CSVFileFormatProperties
-
- isGPUContextCreated - Static variable in class org.apache.sysml.runtime.instructions.gpu.context.GPUContext
-
- 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
.
- isInputMatrixBlock() - Method in class org.apache.sysml.runtime.instructions.spark.WriteSPInstruction
-
- isInSparseFormat - Variable in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- isInSparseFormat() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- isInSparseFormat() - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- isInSparseFormat(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
-
- 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
-
- 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).
- isNullAt(int) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- isOutputThreadSafe() - Method in class org.apache.sysml.runtime.matrix.data.ConvolutionParameters
-
- 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
- isShallowSerialize() - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- isShallowSerialize() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- isShortcutRandOperation(double, double, double, String) - 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
-
- isSparkVersionSupported(String) - Static method in class org.apache.sysml.api.mlcontext.MLContextUtil
-
Determine whether the Spark version is supported.
- isSparse() - Method in class org.apache.sysml.runtime.matrix.data.CSVFileFormatProperties
-
- isSparseAndEmpty() - Method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject
-
If this
JCudaObject
is sparse and empty
Being allocated is a prerequisite to being sparse and empty.
- 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.
- 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
-
- 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.JCudaObject.CSRPointer
-
Check for ultra sparsity
- isUltraSparse() - 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
-
- main(String[]) - Static method in class org.apache.sysml.api.DMLScript
-
Default DML script invocation (e.g., via 'hadoop jar SystemML.jar -f Test.dml')
- main(String[]) - Static method in class org.apache.sysml.api.mlcontext.MLContextExample
-
- main(String[]) - Static method in class org.apache.sysml.api.mlcontext.MLContextExample2
-
- maintainSymbolTable - Variable in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- map(LongWritable, Text, OutputCollector<Writable, Writable>, Reporter) - Method in class org.apache.sysml.runtime.matrix.CleanupMR.CleanupMapper
-
- MapmmChainSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MapmmChainSPInstruction(Operator, CPOperand, CPOperand, CPOperand, MapMultChain.ChainType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MapmmChainSPInstruction
-
- MapmmChainSPInstruction(Operator, CPOperand, CPOperand, CPOperand, CPOperand, MapMultChain.ChainType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MapmmChainSPInstruction
-
- MapmmSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
TODO: we need to reason about multiple broadcast variables for chains of mapmults (sum of operations until cleanup)
- MapmmSPInstruction(Operator, CPOperand, CPOperand, CPOperand, MapMult.CacheType, boolean, AggBinaryOp.SparkAggType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MapmmSPInstruction
-
- mat - Variable in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- matchar - Variable in class org.apache.sysml.runtime.matrix.MatrixDimensionsMetaData
-
- MATERIALIZE_ZEROS - Static variable in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- matmult(ExecutionContext, MatrixObject, MatrixObject, String, boolean, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Matrix multiply on GPU
Examines sparsity and shapes and routes call to appropriate method
from cuBLAS or cuSparse
C = op(A) x op(B)
- matmultTSMM(ExecutionContext, 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 - 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.ValueType - Enum in org.apache.sysml.udf
-
- 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(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
-
- MatrixBuiltinSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MatrixBuiltinSPInstruction(Operator, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MatrixBuiltinSPInstruction
-
- MatrixBVectorArithmeticSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MatrixBVectorArithmeticSPInstruction(Operator, CPOperand, CPOperand, CPOperand, BinaryM.VectorType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MatrixBVectorArithmeticSPInstruction
-
- MatrixBVectorBuiltinSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MatrixBVectorBuiltinSPInstruction(Operator, CPOperand, CPOperand, CPOperand, BinaryM.VectorType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MatrixBVectorBuiltinSPInstruction
-
- MatrixBVectorRelationalSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MatrixBVectorRelationalSPInstruction(Operator, CPOperand, CPOperand, CPOperand, BinaryM.VectorType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MatrixBVectorRelationalSPInstruction
-
- 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, 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.JCudaObject.CSRPointer
-
- MatrixDimensionsMetaData - Class in org.apache.sysml.runtime.matrix
-
- MatrixDimensionsMetaData() - Constructor for class org.apache.sysml.runtime.matrix.MatrixDimensionsMetaData
-
- MatrixDimensionsMetaData(MatrixCharacteristics) - Constructor for class org.apache.sysml.runtime.matrix.MatrixDimensionsMetaData
-
- MatrixFormat - Enum in org.apache.sysml.api.mlcontext
-
MatrixFormat represents the different matrix formats supported by the
MLContext API.
- MatrixFormatMetaData - Class in org.apache.sysml.runtime.matrix
-
- MatrixFormatMetaData(MatrixCharacteristics, OutputInfo, InputInfo) - Constructor for class org.apache.sysml.runtime.matrix.MatrixFormatMetaData
-
- 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
-
- MatrixIndexingSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
This class implements the matrix indexing functionality inside CP.
- MatrixIndexingSPInstruction(Operator, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, AggBinaryOp.SparkAggType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MatrixIndexingSPInstruction
-
- MatrixIndexingSPInstruction(Operator, 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
-
- 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
-
- MatrixMatrixArithmeticSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MatrixMatrixArithmeticSPInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MatrixMatrixArithmeticSPInstruction
-
- MatrixMatrixAxpyGPUInstruction - Class in org.apache.sysml.runtime.instructions.gpu
-
- MatrixMatrixAxpyGPUInstruction(Operator, CPOperand, CPOperand, int, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.gpu.MatrixMatrixAxpyGPUInstruction
-
- MatrixMatrixBuiltinSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MatrixMatrixBuiltinSPInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MatrixMatrixBuiltinSPInstruction
-
- matrixMatrixOperations(MatrixObject, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibCommonsMath
-
- MatrixMatrixRelationalSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MatrixMatrixRelationalSPInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MatrixMatrixRelationalSPInstruction
-
- 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.
- 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)).
- 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.
- matrixObjectToBinaryBlockMatrix(MatrixObject, SparkExecutionContext) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a BinaryBlockMatrix
.
- 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
-
- MatrixReshapeSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MatrixReshapeSPInstruction(Operator, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MatrixReshapeSPInstruction
-
- matrixScalarArithmetic(ExecutionContext, MatrixObject, String, boolean, ScalarOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Entry point to perform elementwise matrix-scalar operation specified by op
- matrixScalarArithmetic(ExecutionContext, MatrixObject, MatrixObject, String, boolean, boolean, BinaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs elementwise operation specified by op of two input matrices in1 and in2
- MatrixScalarArithmeticSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MatrixScalarArithmeticSPInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MatrixScalarArithmeticSPInstruction
-
- MatrixScalarBuiltinSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MatrixScalarBuiltinSPInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MatrixScalarBuiltinSPInstruction
-
- MatrixScalarRelationalSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MatrixScalarRelationalSPInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MatrixScalarRelationalSPInstruction
-
- 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() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Wrapper method for reduceall-max of a matrix.
- MAX_SOLVE_CACHE_SIZE - Static variable in class org.apache.sysml.runtime.compress.estim.CompressedSizeEstimatorSample
-
- maxpooling(MatrixObject, MatrixObject, int, int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
performs maxpooling on GPU by exploiting cudnnPoolingForward(...)
- maxpooling(MatrixBlock, MatrixBlock, ConvolutionParameters) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
- maxpoolingBackward(MatrixObject, MatrixObject, MatrixObject, int, int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Performs maxpoolingBackward on GPU by exploiting cudnnPoolingBackward(...)
This method computes the backpropogation errors for previous layer of maxpooling operation
- maxpoolingBackward(MatrixBlock, MatrixBlock, MatrixBlock, ConvolutionParameters) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
This method computes the backpropogation errors for previous layer of maxpooling operation
- mc - Variable in class org.apache.sysml.api.MLMatrix
-
Deprecated.
- median() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- 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.
- 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>, 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() - Constructor for class org.apache.sysml.runtime.matrix.MetaData
-
- 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
-
- minNonZero() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Utility function for computing the min non-zero value.
- minus(MLMatrix) - Method in class org.apache.sysml.api.MLMatrix
-
Deprecated.
- minus(Double) - Method in class org.apache.sysml.api.MLMatrix
-
Deprecated.
- mkString() - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- mkString(String) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- mkString(String, String, String) - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- ml - Variable in class org.apache.sysml.api.MLMatrix
-
Deprecated.
- MLBlock - Class in org.apache.sysml.api
-
- MLBlock(MatrixIndexes, MatrixBlock) - Constructor for class org.apache.sysml.api.MLBlock
-
Deprecated.
- MLContext - Class in org.apache.sysml.api
-
- MLContext(SparkContext) - Constructor for class org.apache.sysml.api.MLContext
-
Deprecated.
Create an associated MLContext for given spark session.
- MLContext(JavaSparkContext) - Constructor for class org.apache.sysml.api.MLContext
-
Deprecated.
Create an associated MLContext for given spark session.
- 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(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(SparkContext, boolean) - Constructor for class org.apache.sysml.api.mlcontext.MLContext
-
Create an MLContext based on a SparkContext for interaction with SystemML
on Spark, optionally monitor performance.
- 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
-
- MLContextExample - Class in org.apache.sysml.api.mlcontext
-
- MLContextExample() - Constructor for class org.apache.sysml.api.mlcontext.MLContextExample
-
- MLContextExample2 - Class in org.apache.sysml.api.mlcontext
-
- MLContextExample2() - Constructor for class org.apache.sysml.api.mlcontext.MLContextExample2
-
- 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.
- MLContextProxy - Class in org.apache.sysml.api
-
The purpose of this proxy is to shield systemml internals from direct access to MLContext
which would try to load spark libraries and hence fail if these are not available.
- MLContextProxy() - Constructor for class org.apache.sysml.api.MLContextProxy
-
- 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
-
- MLMatrix - Class in org.apache.sysml.api
-
- MLMatrix(SparkSession, LogicalPlan, MLContext) - Constructor for class org.apache.sysml.api.MLMatrix
-
Deprecated.
- MLMatrix(SQLContext, LogicalPlan, MLContext) - Constructor for class org.apache.sysml.api.MLMatrix
-
Deprecated.
- MLMatrix(SparkSession, QueryExecution, MLContext) - Constructor for class org.apache.sysml.api.MLMatrix
-
Deprecated.
- MLMatrix(SQLContext, QueryExecution, MLContext) - Constructor for class org.apache.sysml.api.MLMatrix
-
Deprecated.
- MLMatrix(Dataset<Row>, MatrixCharacteristics, MLContext) - Constructor for class org.apache.sysml.api.MLMatrix
-
Deprecated.
- MLOutput - Class in org.apache.sysml.api
-
- MLOutput(Map<String, JavaPairRDD<?, ?>>, Map<String, MatrixCharacteristics>) - Constructor for class org.apache.sysml.api.MLOutput
-
Deprecated.
- 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
-
- MMTSJGPUInstruction(Operator, CPOperand, MMTSJ.MMTSJType, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.gpu.MMTSJGPUInstruction
-
MMTSJGPUInstruction constructor.
- modulus(MLMatrix) - Method in class org.apache.sysml.api.MLMatrix
-
Deprecated.
- 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.
- 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
-
- multiply(MLMatrix) - Method in class org.apache.sysml.api.MLMatrix
-
Deprecated.
- multiReturnOperations(MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibCommonsMath
-
- MultiReturnParameterizedBuiltinSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- MultiReturnParameterizedBuiltinSPInstruction(Operator, CPOperand, CPOperand, ArrayList<CPOperand>, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction
-
- 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.ConvolutionParameters
-
- RAND_PDF_NORMAL - Static variable in class org.apache.sysml.runtime.matrix.data.LibMatrixDatagen
-
- RAND_PDF_POISSON - Static variable in class org.apache.sysml.runtime.matrix.data.LibMatrixDatagen
-
- RAND_PDF_UNIFORM - Static variable in class org.apache.sysml.runtime.matrix.data.LibMatrixDatagen
-
- RandomMatrixGenerator - Class in org.apache.sysml.runtime.matrix.data
-
- RandomMatrixGenerator() - Constructor for class org.apache.sysml.runtime.matrix.data.RandomMatrixGenerator
-
- RandomMatrixGenerator(String, int, int, int, int, double) - Constructor for class org.apache.sysml.runtime.matrix.data.RandomMatrixGenerator
-
- RandomMatrixGenerator(String, int, int, int, int, double, double, double) - Constructor for class org.apache.sysml.runtime.matrix.data.RandomMatrixGenerator
-
- RandomMatrixGenerator(String, int, int, int, int, double, double, double, double) - Constructor for class org.apache.sysml.runtime.matrix.data.RandomMatrixGenerator
-
- 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, long[], Well1024a, long) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- randOperationsInPlace(RandomMatrixGenerator, long[], Well1024a, long, int) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- randOperationsInPlace(RandomMatrixGenerator, long[], Well1024a, long) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Function to generate a matrix of random numbers.
- randOperationsInPlace(RandomMatrixGenerator, long[], 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
-
- RandSPInstruction(Operator, Hop.DataGenMethod, CPOperand, CPOperand, long, long, int, int, double, double, double, long, String, String, String, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.RandSPInstruction
-
- RandSPInstruction(Operator, Hop.DataGenMethod, CPOperand, CPOperand, long, long, int, int, double, double, double, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.RandSPInstruction
-
- RandSPInstruction(Operator, Hop.DataGenMethod, CPOperand, CPOperand, long, long, int, int, double, boolean, long, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.RandSPInstruction
-
- ratio - Variable in class org.apache.sysml.runtime.compress.CompressedMatrixBlock.CompressionStatistics
-
- rCleanupRuntimeProgram(ProgramBlock, 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.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
-
- rddStringCSVToFrameObject(String, RDD<String>) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a RDD<String>
in CSV format to a FrameObject
- rddStringCSVToFrameObject(String, RDD<String>, FrameMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a RDD<String>
in CSV format to a FrameObject
- rddStringCSVToMatrixObject(String, RDD<String>) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a RDD<String>
in CSV format to a MatrixObject
- rddStringCSVToMatrixObject(String, RDD<String>, MatrixMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a RDD<String>
in CSV format to a MatrixObject
- rddStringIJVToFrameObject(String, RDD<String>, FrameMetadata) - Static method in class org.apache.sysml.api.mlcontext.MLContextConversionUtil
-
Convert a RDD<String>
in IJV format to a FrameObject
.
- rddStringIJVToMatrixObject(String, 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
-
- read(SparkSession, String, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Experimental API: Might be discontinued in future release
- read(SQLContext, String, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Experimental API: Might be discontinued in future release
- READ_CACHE_BLKSZ - Static variable in class org.apache.sysml.runtime.compress.ColGroupOffset
-
- readDMLScript(String, String) - Static method in class org.apache.sysml.api.DMLScript
-
- 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) - 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
-
- readScript(String) - Method in class org.apache.sysml.api.jmlc.Connection
-
Read a DML or PyDML file as a string.
- readSparseRows(int, 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
-
- ReblockSPInstruction(Operator, CPOperand, CPOperand, int, int, boolean, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.ReblockSPInstruction
-
- recap(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
- 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, 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
-
- REFRESH_AVAILABLE_MEMORY_EVERY_TIME - Variable in class org.apache.sysml.runtime.instructions.gpu.context.JCudaContext
-
- registerFrameInput(String, Dataset<Row>) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register DataFrame as input.
- registerFrameInput(String, Dataset<Row>, boolean) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register DataFrame as input.
- registerInput(String, Dataset<Row>) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register DataFrame as input.
- registerInput(String, Dataset<Row>, boolean) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register DataFrame as input.
- registerInput(String, MLMatrix) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Experimental API.
- registerInput(String, JavaRDD<String>, String, boolean, String, boolean, double) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register CSV/Text as inputs: Method for supplying csv file format properties, but without dimensions or nnz
- registerInput(String, RDD<String>, String, boolean, String, boolean, double) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register CSV/Text as inputs: Method for supplying csv file format properties, but without dimensions or nnz
- registerInput(String, RDD<String>, String, boolean, String, boolean, double, long, long, long) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register CSV/Text as inputs: Method for supplying csv file format properties along with dimensions or nnz
- registerInput(String, JavaRDD<String>, String, boolean, String, boolean, double, long, long, long) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register CSV/Text as inputs: Method for supplying csv file format properties along with dimensions or nnz
- registerInput(String, RDD<String>, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register CSV/Text as inputs: Convenience method without dimensions and nnz.
- registerInput(String, JavaRDD<String>, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register CSV/Text as inputs: Convenience method without dimensions and nnz.
- registerInput(String, JavaRDD<String>, String, long, long) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register CSV/Text as inputs: Convenience method with dimensions and but no nnz.
- registerInput(String, RDD<String>, String, long, long) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register CSV/Text as inputs: Convenience method with dimensions and but no nnz.
- registerInput(String, JavaRDD<String>, String, long, long, long) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register CSV/Text as inputs: with dimensions and nnz.
- registerInput(String, RDD<String>, String, long, long, long) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register CSV/Text as inputs: with dimensions and nnz.
- registerInput(String, JavaRDD<String>, String, long, long, FileFormatProperties, List<Expression.ValueType>) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register Frame with CSV/Text as inputs: with dimensions.
- registerInput(String, JavaPairRDD<MatrixIndexes, MatrixBlock>, long, long) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register binary blocked RDD with given dimensions, default block sizes and no nnz
- registerInput(String, JavaPairRDD<MatrixIndexes, MatrixBlock>, long, long, int, int) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register binary blocked RDD with given dimensions, given block sizes and no nnz
- registerInput(String, JavaPairRDD<MatrixIndexes, MatrixBlock>, long, long, int, int, long) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Register binary blocked RDD with given dimensions, given block sizes and given nnz (preferred).
- registerInput(String, JavaPairRDD<MatrixIndexes, MatrixBlock>, MatrixCharacteristics) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- registerInput(String, MatrixBlock) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- registerInput(String, MatrixBlock, MatrixCharacteristics) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- registerOutput(String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Marks the variable in the DML script as output variable.
- RelationalBinarySPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- RelationalBinarySPInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.RelationalBinarySPInstruction
-
- releaseInput() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- releaseInput() - Method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject
-
releases input allocated on GPU
- releaseOutput() - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
- releaseOutput() - Method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject
-
releases output allocated on GPU
- relu(ExecutionContext, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
- reluBackward(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
- remove() - Method in class org.apache.sysml.runtime.compress.BitmapDecoderOLE
-
- remove() - Method in class org.apache.sysml.runtime.compress.BitmapDecoderRLE
-
- remove(PlanningCoCodingGroup) - Method in class org.apache.sysml.runtime.compress.cocode.PlanningMemoTable
-
- removeEmptyOperations(MatrixBlock, boolean, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- removeEmptyOperations(MatrixBlock, boolean) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- removeEmptyOperations(MatrixBlock, boolean, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- removeEmptyOperations(MatrixBlock, 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.
- 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
-
- ReorgGPUInstruction(Operator, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.gpu.ReorgGPUInstruction
-
for opcodes r'
- 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
-
- ReorgSPInstruction(Operator, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.ReorgSPInstruction
-
- ReorgSPInstruction(Operator, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, String, boolean, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.ReorgSPInstruction
-
- 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
-
- 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
-
- reset() - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Call this method if you want to clear any RDDs set via registerInput, registerOutput.
- reset(boolean) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
- 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(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
-
- resetConfig() - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Reset configuration settings to default settings.
- resetOutputMatix(MatrixIndexes, MatrixBlock, MatrixIndexes, MatrixBlock, AggregateUnaryOperator) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixOuterAgg
-
ReSet output matrix
- 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)
- reshape(IndexedMatrixValue, long, long, int, int, ArrayList<IndexedMatrixValue>, long, long, int, int, boolean) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
MR 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) - 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) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- rexpandOperations(MatrixBlock, double, boolean, boolean, boolean) - 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, 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
-
- RmmSPInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.RmmSPInstruction
-
- 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
-
- RowClassMeet.ClassLabelComparator - Class in org.apache.sysml.udf.lib
-
- RowClassMeet.ClassLabels - Class in org.apache.sysml.udf.lib
-
- 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.JCudaObject.CSRPointer
-
integer array of start of all rows and end of last row + 1
- rowsKnown() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- rowsPerBlock() - Method in class org.apache.sysml.api.MLMatrix
-
Deprecated.
- 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
-
- runAssignRowIDMRJob(String[], InputInfo[], int[], int[], String, int, String[], boolean, String, 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.ConvolutionParameters
-
- 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
-
- 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
-
- 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
-
- schema() - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- 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.
- 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 - 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.SparseRow
-
- searchIndexesFirstGTE(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
- searchIndexesFirstLTE(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
- 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(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
-
- 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
-
- setActive(boolean) - Static method in class org.apache.sysml.api.MLContextProxy
-
- 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
-
- setAppropriateVarsForRead(Expression, String) - Static method in class org.apache.sysml.api.MLContextProxy
-
- setBaseDir(String) - Method in class org.apache.sysml.udf.PackageFunction
-
- setBaseObject(T) - Method in class org.apache.sysml.runtime.matrix.data.Tagged
-
- setBinaryBlocks(JavaPairRDD<Long, FrameBlock>) - Method in class org.apache.sysml.api.mlcontext.BinaryBlockFrame
-
Set the SystemML binary-block frame as a
JavaPairRDD<Long, FrameBlock>
- setBinaryBlocks(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysml.api.mlcontext.BinaryBlockMatrix
-
Set the SystemML binary-block matrix as a
JavaPairRDD<MatrixIndexes, MatrixBlock>
- 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.instructions.spark.RandSPInstruction
-
- setColsInBlock(int) - Method in class org.apache.sysml.runtime.instructions.spark.RandSPInstruction
-
- setColsPerBlock(int) - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- 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.
- setConfig(String, String) - Method in class org.apache.sysml.api.MLContext
-
Deprecated.
Allow users to provide custom named-value configuration.
- setConfigProperty(String, String) - Method in class org.apache.sysml.api.mlcontext.MLContext
-
Set configuration property, such as
setConfigProperty("localtmpdir", "/tmp/systemml")
.
- 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.
- setDelim(String) - Method in class org.apache.sysml.runtime.matrix.data.CSVFileFormatProperties
-
- setDenseMatrixCudaPointer(Pointer) - Method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject
-
Convenience method to directly set the dense matrix pointer on GPU
Make sure to call
JCudaObject.setDeviceModify(long)
after this to set appropriate state, if you are not sure what you are doing.
- setDescription(String) - Method in class org.apache.sysml.runtime.matrix.data.FileFormatProperties
-
- setDeviceModify(long) - Method in class org.apache.sysml.runtime.instructions.gpu.context.GPUObject
-
If memory on GPU has been allocated from elsewhere, this method
updates the internal bookkeeping
- setDeviceModify(long) - Method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject
-
- setDiag() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- setDimension(long, long) - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- setDimsUnknownFilePrefix(String) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- 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.
- setFileFormat(FileFormatProperties.FileFormat) - Method in class org.apache.sysml.runtime.matrix.data.FileFormatProperties
-
- setFill(boolean) - Method in class org.apache.sysml.runtime.matrix.data.CSVFileFormatProperties
-
- setFillValue(double) - Method in class org.apache.sysml.runtime.matrix.data.CSVFileFormatProperties
-
- 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
- setFrameMetadata(FrameMetadata) - Method in class org.apache.sysml.api.mlcontext.BinaryBlockFrame
-
Set the SystemML binary-block frame metadata
- setFrameSchema(FrameSchema) - Method in class org.apache.sysml.api.mlcontext.FrameMetadata
-
Set the frame schema
- setGMRInstructions(String[], String, String, String, String, String[], byte[], int, int) - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- setHeader(boolean) - Method in class org.apache.sysml.runtime.matrix.data.CSVFileFormatProperties
-
- 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.SparseRow
-
- 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 sorted array of non-zeros values 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) - 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, double[], int, int) - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
Inserts a dense vector into a column range; calling this methods helps to
avoid repeated shifting of remaining values/indexes for every set value.
- setInit(boolean) - Method in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
Whether or not to initialize the scratch_space, bufferpool, etc.
- setInput(FunctionParameter, int) - Method in class org.apache.sysml.udf.PackageFunction
-
Method to set a specific input for this package function
- setInputMatrixBlock(boolean) - Method in class org.apache.sysml.runtime.instructions.spark.WriteSPInstruction
-
- 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(int, int, int, int) - Method in class org.apache.sysml.runtime.instructions.Instruction
-
Setter for instruction line/column number
- 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.MatrixMetadata
-
Set the MatrixMetadata fields based on a MatrixCharacteristics object.
- setMatrixCharacteristics(MatrixCharacteristics) - Method in class org.apache.sysml.runtime.matrix.MatrixDimensionsMetaData
-
- 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
- setMatrixMetadata(MatrixMetadata) - Method in class org.apache.sysml.api.mlcontext.BinaryBlockMatrix
-
Set the SystemML binary-block matrix metadata
- 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.
- setMaxValue(double) - Method in class org.apache.sysml.runtime.instructions.spark.RandSPInstruction
-
- 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.
- setMinValue(double) - Method in class org.apache.sysml.runtime.instructions.spark.RandSPInstruction
-
- 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
-
- 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.FrameMetadata
-
Set the number of columns
- setNumColumns(Long) - Method in class org.apache.sysml.api.mlcontext.MatrixMetadata
-
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.FrameMetadata
-
Set the number of columns per block
- setNumColumnsPerBlock(Integer) - Method in class org.apache.sysml.api.mlcontext.MatrixMetadata
-
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.FrameMetadata
-
Set the number of non-zero values
- setNumNonZeros(Long) - Method in class org.apache.sysml.api.mlcontext.MatrixMetadata
-
Set the number of non-zero values
- setNumRows(Long) - Method in class org.apache.sysml.api.mlcontext.FrameMetadata
-
Set the number of rows
- setNumRows(Long) - Method in class org.apache.sysml.api.mlcontext.MatrixMetadata
-
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 tertiaryInstruction (for contingency tables)
and pmm for meta corrections.
- setNumRowsPerBlock(Integer) - Method in class org.apache.sysml.api.mlcontext.FrameMetadata
-
Set the number of rows per block
- setNumRowsPerBlock(Integer) - Method in class org.apache.sysml.api.mlcontext.MatrixMetadata
-
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
-
- 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.instructions.spark.RandSPInstruction
-
- setRowsInBlock(int) - Method in class org.apache.sysml.runtime.instructions.spark.RandSPInstruction
-
- 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.SparseRow
-
- setSparse(boolean) - Method in class org.apache.sysml.runtime.matrix.data.CSVFileFormatProperties
-
- setSparseMatrixCudaPointer(JCudaObject.CSRPointer) - Method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject
-
Convenience method to directly set the sparse matrix on GPU
Make sure to call
JCudaObject.setDeviceModify(long)
after this to set appropriate state, if you are not sure what you are doing.
- setSparsity(double) - Method in class org.apache.sysml.runtime.instructions.spark.RandSPInstruction
-
- 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
-
- setTag(byte) - Method in class org.apache.sysml.runtime.matrix.data.Tagged
-
- setTag(byte) - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes
-
- setType(Instruction.INSTRUCTION_TYPE) - Method in class org.apache.sysml.runtime.instructions.Instruction
-
- 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, and globally sets the script type.
- 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.
- 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
-
- setValueDenseUnsafe(int, int, double) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
This can be only called when you know you have properly allocated spaces for a dense representation
and r and c are in the the range of the dimension
Note: this function won't keep track of the nozeros
- setValues(double[]) - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
- 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
-
- SHALLOW_DENSE_ROWWISE_RESHAPE - Static variable in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
- SHALLOW_DENSE_VECTOR_TRANSPOSE - 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.
- shutdown() - Method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaKernels
-
Performs cleanup actions such as unloading the module
- size() - Method in class org.apache.sysml.api.jmlc.ResultVariables
-
Obtain the number of output data held by this ResultVariables object.
- size() - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- 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.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
-
- 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
-
- sliceOperations(int, int, int, int, CacheBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- sliceOperations(ArrayList<IndexedMatrixValue>, IndexRange, int, int, int, int, int, int) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- sliceOperations(ArrayList<IndexedMatrixValue>, IndexRange, int, int, int, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- sliceOperations(IndexRange, FrameBlock) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- sliceOperations(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.
- sliceOperations(ArrayList<Pair<Long, FrameBlock>>, IndexRange, int) - Method in class org.apache.sysml.runtime.matrix.data.FrameBlock
-
- sliceOperations(IndexRange, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- sliceOperations(int, int, int, int, CacheBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
Method to perform rangeReIndex operation for a given lower and upper bounds in row and column dimensions.
- sliceOperations(ArrayList<IndexedMatrixValue>, IndexRange, int, int, int, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- sliceOperations(ArrayList<IndexedMatrixValue>, IndexRange, int, int, int, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- sliceOperations(ArrayList<IndexedMatrixValue>, IndexRange, int, int, int, int, int, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- SMALLEST_FILE_NAME_PER_INPUT - Static variable in class org.apache.sysml.runtime.matrix.CSVReblockMR
-
- 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_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
-
- 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.
- sortIndexesByVal(JavaPairRDD<MatrixIndexes, MatrixBlock>, boolean, 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
-
- 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
-
- 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
- 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
-
- sparseDenseMatmult(MatrixObject, MatrixObject, MatrixObject, boolean, boolean, int, int, int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
* C = op(A) * op(B) where A is sparse and B is dense
If A is ultrasparse, B is converted to a sparse matrix and sparseSparseMatmult(MatrixObject, int, int, int, int, int, CSRPointer, CSRPointer)
is invoked
otherwise A is converted to a dense matrix and denseDenseMatmult(Pointer, int, int, int, int, boolean, boolean, Pointer, Pointer)
is invoked.
- sparseMatrixDenseVectorMult(MatrixObject, JCudaObject.CSRPointer, Pointer, int, int, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
C = op(A) x B
A is a sparse matrix, B is a dense vector
- sparseMatrixVectorMult(MatrixObject, int, int, int, int, JCudaObject.CSRPointer, JCudaObject.CSRPointer) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Does a sparse matrix-vector multiply.
- SparseRow - Class in org.apache.sysml.runtime.matrix.data
-
- SparseRow() - Constructor for class org.apache.sysml.runtime.matrix.data.SparseRow
-
- SparseRow(int) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseRow
-
- SparseRow(int, int) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseRow
-
- SparseRow(SparseRow) - Constructor for class org.apache.sysml.runtime.matrix.data.SparseRow
-
- sparseScalarOperationsInPlace(ScalarOperator) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- sparseScalarOperationsInPlace(ScalarOperator) - Method in class org.apache.sysml.runtime.matrix.data.WeightedCell
-
- sparseSparseMatmult(MatrixObject, int, int, int, int, int, JCudaObject.CSRPointer, JCudaObject.CSRPointer) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Does a sparse-sparse Matrix multiply
C = op(A) x op(B), A, B are sparse matrices
- sparseToColumnMajorDense() - Method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject
-
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.JCudaObject
-
Convert sparse to dense (Performs transpose, use sparseToColumnMajorDense if the kernel can deal with column major format)
- 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(String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.SPInstruction
-
- SPInstruction(Operator, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.SPInstruction
-
- SPInstruction.SPINSTRUCTION_TYPE - 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
-
- start_indexes_h - Variable in class org.apache.sysml.runtime.matrix.data.ConvolutionParameters
-
- start_indexes_w - Variable in class org.apache.sysml.runtime.matrix.data.ConvolutionParameters
-
- 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 - Variable in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- STATISTICS_COUNT - Static variable in class org.apache.sysml.api.DMLScript
-
- statisticsMaxHeavyHitters - Variable in class org.apache.sysml.api.mlcontext.ScriptExecutor
-
- stream - Variable in class org.apache.sysml.runtime.instructions.gpu.context.ExecutionConfig
-
- stride_h - Variable in class org.apache.sysml.runtime.matrix.data.ConvolutionParameters
-
- stride_w - Variable in class org.apache.sysml.runtime.matrix.data.ConvolutionParameters
-
- String2CPFileInstructionType - Static variable in class org.apache.sysml.runtime.instructions.CPInstructionParser
-
- String2CPInstructionType - Static variable in class org.apache.sysml.runtime.instructions.CPInstructionParser
-
- String2GPUInstructionType - Static variable in class org.apache.sysml.runtime.instructions.GPUInstructionParser
-
- String2MRInstructionType - Static variable in class org.apache.sysml.runtime.instructions.MRInstructionParser
-
- String2SPInstructionType - Static variable in class org.apache.sysml.runtime.instructions.SPInstructionParser
-
- stringDataFrameToVectorDataFrame(SQLContext, Dataset<Row>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- 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
-
- sumByKeyStable(JavaPairRDD<MatrixIndexes, MatrixBlock>) - 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
-
- 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, KahanObject) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- sumValues(int, double[]) - Method in class org.apache.sysml.runtime.compress.ColGroupValue
-
- SUPPORTS_SPARSE_OUTPUTS - Static variable in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
- suppressPrint2Stdout() - Static method in class org.apache.sysml.api.DMLScript
-
- symbolTable - Variable in class org.apache.sysml.api.mlcontext.MLResults
-
- SYSTEMML_MINIMUM_SPARK_VERSION - Static variable in class org.apache.sysml.api.mlcontext.MLContext
-
Minimum Spark version supported by SystemML.
- tag - Variable in class org.apache.sysml.runtime.matrix.data.Tagged
-
- tag - Variable in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes
-
- Tagged<T extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.sysml.runtime.matrix.data
-
- Tagged(T, byte) - Constructor for class org.apache.sysml.runtime.matrix.data.Tagged
-
- Tagged() - Constructor for class org.apache.sysml.runtime.matrix.data.Tagged
-
- TaggedAdaptivePartialBlock - Class in org.apache.sysml.runtime.matrix.data
-
- TaggedAdaptivePartialBlock(AdaptivePartialBlock, byte) - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedAdaptivePartialBlock
-
- TaggedAdaptivePartialBlock() - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedAdaptivePartialBlock
-
- TaggedFirstSecondIndexes - Class in org.apache.sysml.runtime.matrix.data
-
- TaggedFirstSecondIndexes() - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes
-
- TaggedFirstSecondIndexes(long, byte, long) - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes
-
- TaggedFirstSecondIndexes(TaggedFirstSecondIndexes) - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes
-
- TaggedFirstSecondIndexes.Comparator - Class in org.apache.sysml.runtime.matrix.data
-
A Comparator optimized for TaggedFirstSecondIndexes.
- TaggedFirstSecondIndexes.FirstIndexPartitioner - Class in org.apache.sysml.runtime.matrix.data
-
Partition based on the first index.
- TaggedFirstSecondIndexes.FirstIndexRangePartitioner - Class in org.apache.sysml.runtime.matrix.data
-
Partition based on the first index.
- TaggedFirstSecondIndexes.TagPartitioner - Class in org.apache.sysml.runtime.matrix.data
-
Partition based on the first index.
- TaggedMatrixBlock - Class in org.apache.sysml.runtime.matrix.data
-
- TaggedMatrixBlock(MatrixBlock, byte) - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedMatrixBlock
-
- TaggedMatrixBlock() - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedMatrixBlock
-
- TaggedMatrixBlock(TaggedMatrixBlock) - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedMatrixBlock
-
- TaggedMatrixCell - Class in org.apache.sysml.runtime.matrix.data
-
- TaggedMatrixCell(MatrixCell, byte) - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedMatrixCell
-
- TaggedMatrixCell() - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedMatrixCell
-
- TaggedMatrixCell(TaggedMatrixCell) - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedMatrixCell
-
- TaggedMatrixIndexes - Class in org.apache.sysml.runtime.matrix.data
-
- TaggedMatrixIndexes() - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedMatrixIndexes
-
- TaggedMatrixIndexes(MatrixIndexes, byte) - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedMatrixIndexes
-
- TaggedMatrixIndexes(TaggedMatrixIndexes) - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedMatrixIndexes
-
- TaggedMatrixPackedCell - Class in org.apache.sysml.runtime.matrix.data
-
- TaggedMatrixPackedCell(MatrixPackedCell, byte) - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedMatrixPackedCell
-
- TaggedMatrixPackedCell() - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedMatrixPackedCell
-
- TaggedMatrixPackedCell(TaggedMatrixPackedCell) - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedMatrixPackedCell
-
- TaggedMatrixValue - Class in org.apache.sysml.runtime.matrix.data
-
- TaggedMatrixValue(MatrixValue, byte) - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedMatrixValue
-
- TaggedMatrixValue() - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedMatrixValue
-
- TaggedTripleIndexes - Class in org.apache.sysml.runtime.matrix.data
-
- TaggedTripleIndexes() - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedTripleIndexes
-
- TaggedTripleIndexes(long, long, long, byte) - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedTripleIndexes
-
- TaggedTripleIndexes(TaggedTripleIndexes) - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedTripleIndexes
-
- TagPartitioner() - Constructor for class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes.TagPartitioner
-
- ternaryOperations(Operator, double, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- ternaryOperations(Operator, double, double, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- ternaryOperations(Operator, MatrixIndexes, double, boolean, int, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- ternaryOperations(Operator, MatrixValue, double, boolean, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- ternaryOperations(Operator, MatrixValue, double, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- ternaryOperations(Operator, MatrixValue, MatrixValue, CTableMap) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- ternaryOperations(Operator, MatrixValue, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- ternaryOperations(Operator, MatrixValue, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- ternaryOperations(Operator, MatrixValue, double, boolean, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- ternaryOperations(Operator, double, double, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- ternaryOperations(Operator, MatrixIndexes, double, boolean, int, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- ternaryOperations(Operator, double, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- ternaryOperations(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)
- ternaryOperations(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)
- ternaryOperations(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.
- ternaryOperations(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.
- ternaryOperations(Operator, 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)
- ternaryOperations(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)
- ternaryOperations(Operator, MatrixValue, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- ternaryOperations(Operator, MatrixValue, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- ternaryOperations(Operator, MatrixValue, double, boolean, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- ternaryOperations(Operator, double, double, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- ternaryOperations(Operator, MatrixIndexes, double, boolean, int, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- ternaryOperations(Operator, double, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixCell
-
- ternaryOperations(Operator, MatrixValue, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- ternaryOperations(Operator, MatrixValue, double, boolean, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- ternaryOperations(Operator, double, double, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- ternaryOperations(Operator, MatrixIndexes, double, boolean, int, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- ternaryOperations(Operator, double, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue
-
- TernarySPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- TernarySPInstruction(Operator, CPOperand, CPOperand, CPOperand, CPOperand, String, boolean, String, boolean, boolean, boolean, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.TernarySPInstruction
-
- TEST_SPARSE_FILTER - Static variable in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
- TEST_SPARSE_INPUT - Static variable in class org.apache.sysml.runtime.matrix.data.LibMatrixDNN
-
- TextCellInputInfo - Static variable in class org.apache.sysml.runtime.matrix.data.InputInfo
-
- TextCellOutputInfo - Static variable in class org.apache.sysml.runtime.matrix.data.OutputInfo
-
- textCellToBinaryBlock(JavaSparkContext, JavaPairRDD<LongWritable, Text>, MatrixCharacteristics, Expression.ValueType[]) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- textCellToBinaryBlock(JavaSparkContext, JavaPairRDD<LongWritable, Text>, MatrixCharacteristics, boolean) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtils
-
- textCellToBinaryBlockLongIndex(JavaSparkContext, JavaPairRDD<Long, Text>, MatrixCharacteristics, Expression.ValueType[]) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- TextCellToRowBlockConverter - Class in org.apache.sysml.runtime.matrix.data
-
- TextCellToRowBlockConverter() - Constructor for class org.apache.sysml.runtime.matrix.data.TextCellToRowBlockConverter
-
- TextToBinaryCellConverter - Class in org.apache.sysml.runtime.matrix.data
-
- TextToBinaryCellConverter() - Constructor for class org.apache.sysml.runtime.matrix.data.TextToBinaryCellConverter
-
- timePhase1 - Variable in class org.apache.sysml.runtime.compress.CompressedMatrixBlock.CompressionStatistics
-
- timePhase2 - Variable in class org.apache.sysml.runtime.compress.CompressedMatrixBlock.CompressionStatistics
-
- timePhase3 - Variable in class org.apache.sysml.runtime.compress.CompressedMatrixBlock.CompressionStatistics
-
- timePhase4 - Variable in class org.apache.sysml.runtime.compress.CompressedMatrixBlock.CompressionStatistics
-
- TimeWrapper - Class in org.apache.sysml.udf.lib
-
Wrapper class for time invocation
time = externalFunction(Integer i) return (Double B) implemented in
(classname="org.apache.sysml.udf.lib.TimeWrapper",exectype="mem");
t = time (1);
print( "Time in millsecs= " + t);
- TimeWrapper() - Constructor for class org.apache.sysml.udf.lib.TimeWrapper
-
- to2DDoubleArray() - Method in class org.apache.sysml.api.mlcontext.Matrix
-
Obtain the matrix as a two-dimensional double array
- to2DStringArray() - Method in class org.apache.sysml.api.mlcontext.Frame
-
Obtain the frame as a two-dimensional String array
- toBinaryBlockFrame() - Method in class org.apache.sysml.api.mlcontext.Frame
-
Obtain the matrix as a BinaryBlockFrame
- toBinaryBlockMatrix() - Method in class org.apache.sysml.api.mlcontext.Matrix
-
Obtain the matrix as a BinaryBlockMatrix
- toColumnMajorDenseMatrix(cusparseHandle, cublasHandle, int, int) - Method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject.CSRPointer
-
Copies this CSR matrix on the GPU to a dense column-major matrix
on the GPU.
- toDF() - Method in class org.apache.sysml.api.mlcontext.Frame
-
Obtain the frame as a DataFrame
- toDF() - Method in class org.apache.sysml.api.mlcontext.Matrix
-
Obtain the matrix as a DataFrame
of doubles with an ID column
- toDFDoubleNoIDColumn() - Method in class org.apache.sysml.api.mlcontext.Matrix
-
Obtain the matrix as a DataFrame
of doubles with no ID column
- toDFDoubleWithIDColumn() - Method in class org.apache.sysml.api.mlcontext.Matrix
-
Obtain the matrix as a DataFrame
of doubles with an ID column
- toDFVectorNoIDColumn() - Method in class org.apache.sysml.api.mlcontext.Matrix
-
Obtain the matrix as a DataFrame
of vectors with no ID column
- toDFVectorWithIDColumn() - Method in class org.apache.sysml.api.mlcontext.Matrix
-
Obtain the matrix as a DataFrame
of vectors with an ID column
- toFrameObject() - Method in class org.apache.sysml.api.mlcontext.Frame
-
Obtain the frame as a SystemML FrameObject.
- toIndexedFrameBlock(Tuple2<Long, FrameBlock>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- toIndexedLong(List<Tuple2<Long, Long>>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- toIndexedMatrixBlock(Tuple2<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- toIndexedMatrixBlock(MatrixIndexes, MatrixBlock) - Static method in class org.apache.sysml.runtime.instructions.spark.utils.SparkUtils
-
- toIntExact(long) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject
-
- toJavaRDDStringCSV() - Method in class org.apache.sysml.api.mlcontext.Frame
-
Obtain the frame as a JavaRDD<String>
in CSV format
- toJavaRDDStringCSV() - Method in class org.apache.sysml.api.mlcontext.Matrix
-
Obtain the matrix as a JavaRDD<String>
in CSV format
- toJavaRDDStringIJV() - Method in class org.apache.sysml.api.mlcontext.Frame
-
Obtain the frame as a JavaRDD<String>
in IJV format
- toJavaRDDStringIJV() - Method in class org.apache.sysml.api.mlcontext.Matrix
-
Obtain the matrix as a JavaRDD<String>
in IJV format
- toMatrixBlock(int, int) - Method in class org.apache.sysml.runtime.matrix.data.CTableMap
-
- toMatrixObject() - Method in class org.apache.sysml.api.mlcontext.Matrix
-
Obtain the matrix as a SystemML MatrixObject.
- toRDDStringCSV() - Method in class org.apache.sysml.api.mlcontext.Frame
-
Obtain the frame as a RDD<String>
in CSV format
- toRDDStringCSV() - Method in class org.apache.sysml.api.mlcontext.Matrix
-
Obtain the matrix as a RDD<String>
in CSV format
- toRDDStringIJV() - Method in class org.apache.sysml.api.mlcontext.Frame
-
Obtain the frame as a RDD<String>
in IJV format
- toRDDStringIJV() - Method in class org.apache.sysml.api.mlcontext.Matrix
-
Obtain the matrix as a RDD<String>
in IJV format
- toSeq() - Method in class org.apache.sysml.api.MLBlock
-
Deprecated.
- toString() - Method in class org.apache.sysml.api.mlcontext.BinaryBlockFrame
-
- toString() - Method in class org.apache.sysml.api.mlcontext.BinaryBlockMatrix
-
- toString() - Method in class org.apache.sysml.api.mlcontext.Frame
-
- toString() - Method in class org.apache.sysml.api.mlcontext.FrameMetadata
-
- toString() - Method in class org.apache.sysml.api.mlcontext.Matrix
-
- toString() - Method in class org.apache.sysml.api.mlcontext.MatrixMetadata
-
- toString() - Method in exception org.apache.sysml.api.mlcontext.MLContextException
-
- toString() - Method in class org.apache.sysml.api.mlcontext.MLResults
-
- toString() - Method in class org.apache.sysml.api.mlcontext.ProjectInfo
-
- toString() - Method in class org.apache.sysml.api.mlcontext.Script
-
- toString() - Method in class org.apache.sysml.runtime.compress.cocode.PlanningCoCodingGroup
-
- toString() - Method in class org.apache.sysml.runtime.compress.utils.DblArray
-
- toString() - Method in class org.apache.sysml.runtime.instructions.Instruction
-
- toString() - Method in class org.apache.sysml.runtime.instructions.MRJobInstruction
-
- toString() - Method in class org.apache.sysml.runtime.matrix.CSVReblockMR.AssignRowIDMRReturn
-
- toString() - Method in class org.apache.sysml.runtime.matrix.CSVReblockMR.OffsetCount
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.AdaptivePartialBlock
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.CM_N_COVCell
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.ConvolutionParameters
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.IJV
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.MatrixIndexes
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.MatrixPackedCell
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.MatrixValue.CellIndex
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.PartialBlock
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlock
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCOO
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockMCSR
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.Tagged
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.TaggedFirstSecondIndexes
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.TaggedMatrixIndexes
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.TaggedTripleIndexes
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.TripleIndexes
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.WeightedCell
-
- toString() - Method in class org.apache.sysml.runtime.matrix.data.WeightedPair
-
- toString() - Method in class org.apache.sysml.runtime.matrix.MatrixCharacteristics
-
- toString() - Method in class org.apache.sysml.runtime.matrix.MatrixDimensionsMetaData
-
- toString() - Method in class org.apache.sysml.runtime.matrix.MetaData
-
- toString() - Method in class org.apache.sysml.udf.ExternalFunctionInvocationInstruction
-
- TransformEncodeBuild2Function(MVImputeAgent) - Constructor for class org.apache.sysml.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeBuild2Function
-
- TransformEncodeBuildFunction(Encoder) - Constructor for class org.apache.sysml.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeBuildFunction
-
- TransformEncodeGroup2Function(MVImputeAgent) - Constructor for class org.apache.sysml.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeGroup2Function
-
- TransformEncodeGroupFunction(MultiReturnParameterizedBuiltinSPInstruction.MaxLongAccumulator) - Constructor for class org.apache.sysml.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeGroupFunction
-
- transpose() - Method in class org.apache.sysml.api.MLMatrix
-
Deprecated.
- transpose(Pointer, int, int, int, int) - Static method in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject
-
Transposes a dense matrix on the GPU by calling the cublasDgeam operation
- transpose(ExecutionContext, MatrixObject, String) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixCUDA
-
Transposes the input matrix using cublasDgeam
- transpose(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
- transpose(MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysml.runtime.matrix.data.LibMatrixReorg
-
- TRANSPOSE_INPUT - Static variable in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- transposeSelfMatrixMultOperations(MatrixBlock, MMTSJ.MMTSJType) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- transposeSelfMatrixMultOperations(MatrixBlock, MMTSJ.MMTSJType, int) - Method in class org.apache.sysml.runtime.compress.CompressedMatrixBlock
-
- transposeSelfMatrixMultOperations(MatrixBlock, MMTSJ.MMTSJType) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- transposeSelfMatrixMultOperations(MatrixBlock, MMTSJ.MMTSJType, int) - Method in class org.apache.sysml.runtime.matrix.data.MatrixBlock
-
- TripleIndexes - Class in org.apache.sysml.runtime.matrix.data
-
- TripleIndexes() - Constructor for class org.apache.sysml.runtime.matrix.data.TripleIndexes
-
- TripleIndexes(long, long, long) - Constructor for class org.apache.sysml.runtime.matrix.data.TripleIndexes
-
- TripleIndexes(TripleIndexes) - Constructor for class org.apache.sysml.runtime.matrix.data.TripleIndexes
-
- TripleIndexes.Comparator - Class in org.apache.sysml.runtime.matrix.data
-
- TripleIndexes.FirstTwoIndexesPartitioner - Class in org.apache.sysml.runtime.matrix.data
-
Partition based on the first and second index.
- Tsmm2SPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- Tsmm2SPInstruction(Operator, CPOperand, CPOperand, MMTSJ.MMTSJType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.Tsmm2SPInstruction
-
- TsmmSPInstruction - Class in org.apache.sysml.runtime.instructions.spark
-
- TsmmSPInstruction(Operator, CPOperand, CPOperand, MMTSJ.MMTSJType, String, String) - Constructor for class org.apache.sysml.runtime.instructions.spark.TsmmSPInstruction
-
- type - Variable in class org.apache.sysml.runtime.instructions.Instruction
-
- val - Variable in class org.apache.sysml.runtime.instructions.gpu.context.JCudaObject.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.
- 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.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.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.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.context.GPUObject.EvictionPolicy
-
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.INSTRUCTION_TYPE
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysml.runtime.instructions.spark.SPInstruction.SPINSTRUCTION_TYPE
-
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.FileFormatProperties.FileFormat
-
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.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.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.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.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.context.GPUObject.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.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.INSTRUCTION_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.spark.SPInstruction.SPINSTRUCTION_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.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.FileFormatProperties.FileFormat
-
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.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.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(int) - Method in class org.apache.sysml.runtime.matrix.data.SparseBlockCSR
-
- 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.SparseBlockMCSR
-
- values() - Method in class org.apache.sysml.runtime.matrix.data.SparseRow
-
- 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.
- VALUETYPE_PREFIX - Static variable in class org.apache.sysml.runtime.instructions.Instruction
-
- 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
-
- 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.compress.utils.LinearAlgebraUtils
-
- 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
-
- verifySparkVersionSupported(SparkContext) - 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.