- ABitmap - Class in org.apache.sysds.runtime.compress.utils
-
- ABitmap(int, IntArrayList[], int) - Constructor for class org.apache.sysds.runtime.compress.utils.ABitmap
-
- ABitmap.BitmapType - Enum in org.apache.sysds.runtime.compress.utils
-
- abs(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs an "abs" operation on a matrix on the GPU
- AbstractCompressedMatrixBlock - Class in org.apache.sysds.runtime.compress
-
- AbstractCompressedMatrixBlock() - Constructor for class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
Constructor for building an empty Compressed Matrix block object.
- AbstractCompressedMatrixBlock(int, int, boolean) - Constructor for class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
Main constructor for building a block from scratch.
- AbstractCompressedMatrixBlock(MatrixBlock) - Constructor for class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
"Copy" constructor to populate this compressed block with the uncompressed contents of a conventional block.
- accept(Class) - Method in class org.apache.sysds.runtime.io.BinaryBlockSerialization
-
- accPSAggregationTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- accPSBatchIndexingTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- accPSGradientComputeTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- accPSLocalModelUpdateTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- accPSModelBroadcastTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- accPSRpcRequestTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- accPSSetupTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- accrueGradients(ListObject, ListObject, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
Accumulate the given gradients into the accrued gradients
- accrueGradients(ListObject, ListObject, boolean, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
Accumulate the given gradients into the accrued gradients
- accSparkBroadCastTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- accSparkCollectTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- accSparkParallelizeTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- AccumulatorAssignmentStatementContext(DmlParser.StatementContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.AccumulatorAssignmentStatementContext
-
- acos(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs an "acos" operation on a matrix on the GPU
- acquireDeviceModifyDense() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
- acquireDeviceModifySparse() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
- acquireDeviceRead(String) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
- acquireHostRead(String) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
if the data is allocated on the GPU and is dirty, it is copied back to the host memory
- acquireModify(T) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
Acquires the exclusive "write" lock for a thread that wants to throw away the
old cache block data and link up with new cache block data.
- acquireRead() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
Acquires a shared "read-only" lock, produces the reference to the cache block,
restores the cache block to main memory, reads from HDFS if needed.
- acquireReadAndRelease() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- add(Hop, TemplateBase.TemplateType) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- add(Hop, TemplateBase.TemplateType, long) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- add(Hop, TemplateBase.TemplateType, long, long) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- add(Hop, TemplateBase.TemplateType, long, long, long) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- add(Hop, CPlanMemoTable.MemoTableEntry) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- add(int, int, double) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Add a value to a matrix cell (r,c).
- add(int, int, double) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- add(int, int, double) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- add(int, int, double) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- add(int, double) - Method in class org.apache.sysds.runtime.data.SparseRow
-
Add a value to a specified column with awareness of
potential insertions.
- add(int, double) - Method in class org.apache.sysds.runtime.data.SparseRowScalar
-
- add(int, double) - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- add(Data, LineageItem) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- add(String, Data, LineageItem) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- add(long, Pointer) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
Add a pointer to the rmvar-ed list
- add(String, String) - Method in class org.apache.sysds.runtime.lineage.LineageTokenizer
-
- add(String) - Method in class org.apache.sysds.runtime.lineage.LineageTokenizer
-
- add(int) - Method in class org.apache.sysds.runtime.util.IndexRange
-
- ADD_PRIME1 - Static variable in class org.apache.sysds.runtime.util.UtilFunctions
-
- addAll(Hop, CPlanMemoTable.MemoTableEntrySet) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- addAll(Collection<T>, T[]) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
-
- addAllDataLineage(ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
-
- addAllInputs(ArrayList<Hop>) - Method in class org.apache.sysds.hops.Hop
-
- addBias(double[], double[], double, int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNN
-
- addBinaryBlockSerializationFramework(Configuration) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- addBroadcastSize(long) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- addCell(int, int, double) - Method in class org.apache.sysds.runtime.io.ReaderTextCellParallel.CellBuffer
-
- addCheckedConstraints(Map<PrivacyConstraint.PrivacyLevel, LongAdder>) - Static method in class org.apache.sysds.runtime.privacy.CheckedConstraintsLog
-
Adds checkedConstraints to the checked constraints total.
- addChild(OptNode) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- addChildReference(Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- addChildReference(Hop, Hop, int) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- addChilds(ArrayList<OptNode>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- addCPMemObject(int, double) - Static method in class org.apache.sysds.utils.Statistics
-
- addDimsPreservingFunction(String) - Method in class org.apache.sysds.hops.ipa.FunctionCallSizeInfo
-
Adds a function to the set of dimension-preserving
functions.
- addExprParam(String, Expression, boolean) - Method in class org.apache.sysds.parser.OutputStatement
-
- addFederatedExprParam(String, Expression) - Method in class org.apache.sysds.parser.DataExpression
-
- addFunction(String, T) - Method in class org.apache.sysds.parser.FunctionDictionary
-
- addFunction(String, T, boolean) - Method in class org.apache.sysds.parser.FunctionDictionary
-
- addFunctionProgramBlock(String, String, FunctionProgramBlock) - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- addFunctionProgramBlock(String, String, FunctionProgramBlock, boolean) - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- addFunctionStatementBlock(String, FunctionStatementBlock) - Method in class org.apache.sysds.parser.DMLProgram
-
- addFunctionStatementBlock(String, String, FunctionStatementBlock) - Method in class org.apache.sysds.parser.DMLProgram
-
- addHeaderToCSV(String, String, long, long) - Method in class org.apache.sysds.runtime.io.WriterTextCSV
-
- addHop(Hop) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- addIDToDataFrame(Dataset<Row>, SparkSession, String) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
Add element indices as new column to DataFrame
- addInput(CNode) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
-
- addInput(Hop) - Method in class org.apache.sysds.hops.Hop
-
- addInput(Lop) - Method in class org.apache.sysds.lops.Lop
-
Method to add input to Lop
- addInput(CPOperand) - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- addInstruction(Instruction) - Method in class org.apache.sysds.runtime.controlprogram.BasicProgramBlock
-
- addInstructions(ArrayList<Instruction>) - Method in class org.apache.sysds.runtime.controlprogram.BasicProgramBlock
-
- addIteration(IntObject) - Method in class org.apache.sysds.runtime.controlprogram.parfor.Task
-
- addLineage(String, String, boolean) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- addLineageBroadcast(String, String) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
Adds a child broadcast object to the lineage of a parent rdd.
- addLineageChild(LineageObject) - Method in class org.apache.sysds.runtime.instructions.spark.data.LineageObject
-
- addLineageRDD(String, String) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
Adds a child rdd object to the lineage of a parent rdd.
- addLoadedConstraint(PrivacyConstraint.PrivacyLevel) - Static method in class org.apache.sysds.runtime.privacy.CheckedConstraintsLog
-
Add an occurence of the given privacy level to the loaded constraints log total.
- addMatrixExprParam(String, Expression) - Method in class org.apache.sysds.parser.DataExpression
-
- addNode(Lop) - Method in class org.apache.sysds.lops.compile.Dag
-
Method to add a node to the DAG.
- addOutput(Lop) - Method in class org.apache.sysds.lops.Lop
-
Method to add output to Lop
- addParam(OptNode.ParamType, String) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- addProgramBlock(ProgramBlock) - Method in class org.apache.sysds.runtime.controlprogram.ForProgramBlock
-
- addProgramBlock(ProgramBlock) - Method in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
-
- addProgramBlock(ProgramBlock) - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- addProgramBlock(ProgramBlock) - Method in class org.apache.sysds.runtime.controlprogram.WhileProgramBlock
-
- addProgramBlockElseBody(ProgramBlock) - Method in class org.apache.sysds.runtime.controlprogram.IfProgramBlock
-
- addProgramBlockIfBody(ProgramBlock) - Method in class org.apache.sysds.runtime.controlprogram.IfProgramBlock
-
- addRandExprParam(String, Expression) - Method in class org.apache.sysds.parser.DataExpression
-
- addReadLock() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
- AddRowID() - Constructor for class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtilsExt.AddRowID
-
- addSqlExprParam(String, Expression) - Method in class org.apache.sysds.parser.DataExpression
-
- addStatement(Statement) - Method in class org.apache.sysds.parser.StatementBlock
-
- addStatementBlock(StatementBlock) - Method in class org.apache.sysds.parser.DMLProgram
-
- addStatementBlock(StatementBlock) - Method in class org.apache.sysds.parser.ForStatement
-
- addStatementBlock(StatementBlock) - Method in class org.apache.sysds.parser.StatementBlock
-
- addStatementBlock(StatementBlock) - Method in class org.apache.sysds.parser.WhileStatement
-
- addStatementBlockElseBody(StatementBlock) - Method in class org.apache.sysds.parser.IfStatement
-
- addStatementBlockIfBody(StatementBlock) - Method in class org.apache.sysds.parser.IfStatement
-
- AddSubExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.AddSubExpressionContext
-
- addTensorExprParam(String, Expression) - Method in class org.apache.sysds.parser.DataExpression
-
- addToDag(Dag<Lop>) - Method in class org.apache.sysds.lops.Lop
-
Method to recursively add LOPS to a DAG
- addValidCompression(ColGroup.CompressionType) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
-
Add a single valid compression type to the EnumSet of valid compressions.
- addValue(long, long, double) - Method in class org.apache.sysds.runtime.util.LongLongDoubleHashMap
-
- addVariable(String, DataIdentifier) - Method in class org.apache.sysds.parser.VariableSet
-
- addVariables(VariableSet) - Method in class org.apache.sysds.parser.VariableSet
-
- addVarParam(String, Expression) - Method in class org.apache.sysds.parser.DataExpression
-
- addVarParam(String, Expression) - Method in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- addWriteLock() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
- ADictionary - Class in org.apache.sysds.runtime.compress.colgroup
-
This dictionary class aims to encapsulate the storage and operations over unique floating point values of a column
group.
- ADictionary() - Constructor for class org.apache.sysds.runtime.compress.colgroup.ADictionary
-
- adjustRowIndicesMax(int[], double[], BinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixOuterAgg
-
This function adjusts indices to be leveraged in uarimaxXX functions.
- adjustRowIndicesMin(int[], double[], BinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixOuterAgg
-
This function adjusts indices to be leveraged in uariminXX functions.
- ADoubleEntry(double) - Constructor for class org.apache.sysds.runtime.util.LongLongDoubleHashMap.ADoubleEntry
-
- aggAdd(Future<FederatedResponse>[]) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
-
- AggBinaryOp - Class in org.apache.sysds.hops
-
- AggBinaryOp(String, Types.DataType, Types.ValueType, Types.OpOp2, Types.AggOp, Hop, Hop) - Constructor for class org.apache.sysds.hops.AggBinaryOp
-
- AggBinaryOp.MMultMethod - Enum in org.apache.sysds.hops
-
- AggBinaryOp.SparkAggType - Enum in org.apache.sysds.hops
-
- aggByKeyStable(JavaPairRDD<MatrixIndexes, MatrixBlock>, AggregateOperator) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
- aggByKeyStable(JavaPairRDD<MatrixIndexes, MatrixBlock>, AggregateOperator, boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
- aggByKeyStable(JavaPairRDD<MatrixIndexes, MatrixBlock>, AggregateOperator, int, boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
- aggMatrix(AggregateUnaryOperator, Future<FederatedResponse>[], FederationMap) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
-
- aggMean(Future<FederatedResponse>[], FederationMap) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
-
- aggMinMax(Future<FederatedResponse>[], boolean, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
-
- aggOp - Variable in class org.apache.sysds.runtime.matrix.operators.AggregateBinaryOperator
-
- aggOp - Variable in class org.apache.sysds.runtime.matrix.operators.AggregateTernaryOperator
-
- aggOp - Variable in class org.apache.sysds.runtime.matrix.operators.AggregateUnaryOperator
-
- aggOpType - Variable in class org.apache.sysds.runtime.matrix.operators.CMOperator
-
- aggregate(double, Builtin) - Method in class org.apache.sysds.runtime.compress.colgroup.ADictionary
-
Aggregate all the contained values, useful in value only computations where the operation is iterating through
all values contained in the dictionary.
- aggregate(double, Builtin) - Method in class org.apache.sysds.runtime.compress.colgroup.Dictionary
-
- aggregate(double, Builtin) - Method in class org.apache.sysds.runtime.compress.colgroup.QDictionary
-
- aggregate(long, long, double) - Method in class org.apache.sysds.runtime.matrix.data.CTableMap
-
- aggregateBinary(DataCharacteristics, DataCharacteristics, AggregateBinaryOperator, DataCharacteristics) - Static method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- AggregateBinaryCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- AggregateBinaryFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
-
- AggregateBinaryFEDInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysds.runtime.instructions.fed.AggregateBinaryFEDInstruction
-
- AggregateBinaryGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
- aggregateBinaryMatrix(MatrixBlock, MatrixBlock, MatrixBlock, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
-
Core incremental matrix aggregate (ak+) as used in mapmult, tsmm,
cpmm, etc.
- aggregateBinaryMatrix(MatrixBlock, MatrixBlock, AggregateOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
-
Core incremental matrix aggregate (ak+) as used for uack+ and acrk+.
- aggregateBinaryOperations(MatrixIndexes, MatrixBlock, MatrixIndexes, MatrixBlock, MatrixBlock, AggregateBinaryOperator) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- aggregateBinaryOperations(MatrixBlock, MatrixBlock, MatrixBlock, AggregateBinaryOperator) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- aggregateBinaryOperations(MatrixIndexes, MatrixBlock, MatrixIndexes, MatrixBlock, MatrixBlock, AggregateBinaryOperator) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- aggregateBinaryOperations(MatrixBlock, MatrixBlock, MatrixBlock, AggregateBinaryOperator) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- AggregateBinaryOperator - Class in org.apache.sysds.runtime.matrix.operators
-
- AggregateBinaryOperator(ValueFunction, AggregateOperator) - Constructor for class org.apache.sysds.runtime.matrix.operators.AggregateBinaryOperator
-
- AggregateBinaryOperator(ValueFunction, AggregateOperator, int) - Constructor for class org.apache.sysds.runtime.matrix.operators.AggregateBinaryOperator
-
- aggregateBinaryTensor(BasicTensorBlock, BasicTensorBlock, AggregateOperator) - Static method in class org.apache.sysds.runtime.data.LibTensorAgg
-
Core incremental tensor aggregate (ak+) as used for uack+ and acrk+.
- aggregateCols(double[], Builtin, int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ADictionary
-
Aggregates the columns into the target double array provided.
- AggregateDropCorrectionFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- AggregateDropCorrectionFunction(AggregateOperator) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.AggregateDropCorrectionFunction
-
- aggregateMatrix(MatrixBlock, MatrixBlock, double[], int[], BinaryOperator, AggregateUnaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixOuterAgg
-
- AggregateOperator - Class in org.apache.sysds.runtime.matrix.operators
-
- AggregateOperator(double, ValueFunction) - Constructor for class org.apache.sysds.runtime.matrix.operators.AggregateOperator
-
- AggregateOperator(double, ValueFunction, Types.CorrectionLocationType) - Constructor for class org.apache.sysds.runtime.matrix.operators.AggregateOperator
-
- aggregatePartialResults(SpoofCellwise.AggOp[], MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.codegen.SpoofMultiAggregate
-
- aggregateTernary(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, AggregateTernaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
-
- aggregateTernary(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, AggregateTernaryOperator, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
-
- AggregateTernaryCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- aggregateTernaryOperations(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, AggregateTernaryOperator, boolean) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- aggregateTernaryOperations(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, AggregateTernaryOperator, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- AggregateTernaryOperator - Class in org.apache.sysds.runtime.matrix.operators
-
- AggregateTernaryOperator(ValueFunction, AggregateOperator, IndexFunction) - Constructor for class org.apache.sysds.runtime.matrix.operators.AggregateTernaryOperator
-
- AggregateTernaryOperator(ValueFunction, AggregateOperator, IndexFunction, int) - Constructor for class org.apache.sysds.runtime.matrix.operators.AggregateTernaryOperator
-
- AggregateTernarySPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- aggregateUnary(DataCharacteristics, AggregateUnaryOperator, DataCharacteristics) - Static method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- AggregateUnaryCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- AggregateUnaryCPInstruction.AUType - Enum in org.apache.sysds.runtime.instructions.cp
-
- AggregateUnaryFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
-
- AggregateUnaryGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
Implements aggregate unary instructions for CUDA
- aggregateUnaryMatrix(MatrixBlock, MatrixBlock, AggregateUnaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
-
- aggregateUnaryMatrix(MatrixBlock, MatrixBlock, AggregateUnaryOperator, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, MatrixIndexes, boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, MatrixIndexes) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- aggregateUnaryOperations(AggregateUnaryOperator, BasicTensorBlock) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
Aggregate a unary operation on this tensor.
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, MatrixIndexes) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, MatrixIndexes, boolean) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, MatrixIndexes) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, MatrixIndexes, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, MatrixIndexes) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, MatrixIndexes, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, MatrixIndexes) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, MatrixIndexes, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, MatrixIndexes) - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
-
- AggregateUnaryOperator - Class in org.apache.sysds.runtime.matrix.operators
-
- AggregateUnaryOperator(AggregateOperator, IndexFunction) - Constructor for class org.apache.sysds.runtime.matrix.operators.AggregateUnaryOperator
-
- AggregateUnaryOperator(AggregateOperator, IndexFunction, int) - Constructor for class org.apache.sysds.runtime.matrix.operators.AggregateUnaryOperator
-
- AggregateUnarySPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- AggregateUnarySPInstruction.RDDUAggFunction2 - Class in org.apache.sysds.runtime.instructions.spark
-
Similar to RDDUAggFunction but single output block.
- AggregateUnarySPInstruction.RDDUTensorAggFunction2 - Class in org.apache.sysds.runtime.instructions.spark
-
Similar to RDDUAggFunction but single output block.
- aggregateUnaryTensor(BasicTensorBlock, BasicTensorBlock, AggregateUnaryOperator) - Static method in class org.apache.sysds.runtime.data.LibTensorAgg
-
Aggregate a tensor-block with the given unary operator.
- aggScalar(AggregateUnaryOperator, Future<FederatedResponse>[]) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
-
- aggStable(JavaPairRDD<MatrixIndexes, MatrixBlock>, AggregateOperator) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
Single block aggregation over pair rdds with corrections for numerical stability.
- aggStable(JavaRDD<MatrixBlock>, AggregateOperator) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
Single block aggregation over rdds with corrections for numerical stability.
- aggStableTensor(JavaPairRDD<TensorIndexes, TensorBlock>, AggregateOperator) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
Single block aggregation over pair rdds with corrections for numerical stability.
- aggStableTensor(JavaRDD<TensorBlock>, AggregateOperator) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
Single block aggregation over rdds with corrections for numerical stability.
- AggUnaryOp - Class in org.apache.sysds.hops
-
- AggUnaryOp(String, Types.DataType, Types.ValueType, Types.AggOp, Types.Direction, Hop) - Constructor for class org.apache.sysds.hops.AggUnaryOp
-
- algo - Variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNConvolutionAlgorithm
-
- ALL_SUPPORTED_DATA_TYPES - Static variable in class org.apache.sysds.api.mlcontext.MLContextUtil
-
All data types supported by the MLContext API.
- allocate(int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Allocate the underlying data structure holding non-zero values
of row r if necessary.
- allocate(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Allocate the underlying data structure holding non-zero values
of row r if necessary, w/ given size.
- allocate(int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Allocate the underlying data structure holding non-zero values
of row r w/ the specified estimated nnz and max nnz.
- allocate(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- allocate(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- allocate(int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- allocate(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- allocate(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- allocate(int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- allocate(int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- allocate(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- allocate(int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- allocate(Pointer, long) - Method in class org.apache.sysds.runtime.instructions.gpu.context.CudaMemoryAllocator
-
Allocate memory on the device.
- allocate(String, long) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Invokes memory manager's malloc method
- allocate(Pointer, long) - Method in interface org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryAllocator
-
Allocate memory on the device.
- allocate(Pointer, long) - Method in class org.apache.sysds.runtime.instructions.gpu.context.UnifiedMemoryAllocator
-
Allocate memory on the device.
- allocateAndFillDense(double) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Allocates a dense matrix of size obtained from the attached matrix metadata
and fills it up with a single value
- allocateAndResetSparseBlock(boolean, SparseBlock.Type) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- allocateBlock() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- allocateBlock() - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- allocateBlock() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
If data is not yet allocated, allocate.
- allocateBlock() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- allocateBlockAsync() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- allocateColGroupList(List<ColGroup>) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- allocateDenseBlock() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- allocateDenseBlock(boolean) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- allocateDenseBlock() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- allocateDenseBlock(boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- allocateDenseBlockUnsafe(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
This should be called only in the read and write functions for CP
This function should be called before calling any setValueDenseUnsafe()
- allocateDenseOrSparse(int, int, boolean) - Static method in class org.apache.sysds.runtime.util.Py4jConverterUtils
-
- allocateDenseOrSparse(long, long, boolean) - Static method in class org.apache.sysds.runtime.util.Py4jConverterUtils
-
- allocateDoubleArrTime - Static variable in class org.apache.sysds.utils.Statistics
-
- allocateEmpty(GPUContext, long, long) - Static method in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
Factory method to allocate an empty CSR Sparse matrix on the GPU
- allocateForDgeam(GPUContext, cusparseHandle, CSRPointer, CSRPointer, int, int) - Static method in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
Estimates the number of non zero elements from the results of a sparse cusparseDgeam operation
C = a op(A) + b op(B)
- allocateForMatrixMultiply(GPUContext, cusparseHandle, CSRPointer, int, CSRPointer, int, int, int, int) - Static method in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
Estimates the number of non-zero elements from the result of a sparse matrix multiplication C = A * B
and returns the
CSRPointer
to C with the appropriate GPU memory.
- allocateGPUMatrixObject(String, long, long) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
Allocates the
GPUObject
for a given LOPS Variable (eg.
- allocateSparseAndEmpty() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Allocates a sparse and empty
GPUObject
This is the result of operations that are both non zero matrices.
- allocateSparseBlock() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- allocateSparseBlock(boolean) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- allocateSparseRowsBlock() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- allocateSparseRowsBlock(boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- allocVector(int, boolean) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- ALLOW_ALGEBRAIC_SIMPLIFICATION - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
- ALLOW_AUTO_VECTORIZATION - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
- ALLOW_BRANCH_REMOVAL - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Enables if-else branch removal for constant predicates (original literals or
results of constant folding).
- ALLOW_BROADCAST_INPUTS - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- ALLOW_CODE_MOTION - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Enables a specific rewrite for code motion, i.e., hoisting loop invariant code
out of while, for, and parfor loops.
- ALLOW_COMBINE_FILE_INPUT_FORMAT - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Enables the use of CombineSequenceFileInputFormat with splitsize = 2x hdfs blocksize,
if sort buffer size large enough and parallelism not hurt.
- ALLOW_COMMON_SUBEXPRESSION_ELIMINATION - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Enables common subexpression elimination in dags.
- ALLOW_CONSTANT_FOLDING - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Enables constant folding in dags.
- ALLOW_COPY_CELLFILES - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeLocalFile
-
- ALLOW_CTABLE_SEQUENCE_REWRITES - Static variable in class org.apache.sysds.hops.TernaryOp
-
- ALLOW_DATA_COLOCATION - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- ALLOW_INTER_PROCEDURAL_ANALYSIS - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Enables interprocedural analysis between main script and functions as well as functions
and other functions.
- ALLOW_LOOP_UPDATE_IN_PLACE - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Enables a specific rewrite that enables update in place for loop variables that are
only read/updated via cp leftindexing.
- ALLOW_NESTED_PARALLELISM - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- ALLOW_OPERATOR_FUSION - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
- ALLOW_RAND_JOB_RECOMPILE - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
- ALLOW_REMOTE_NESTED_PARALLELISM - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerRuleBased
-
- ALLOW_REUSE_PARTITION_VARS - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- ALLOW_RUNTIME_PIGGYBACKING - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Enables parfor runtime piggybacking of MR jobs into the packed jobs for
scan sharing.
- ALLOW_SIZE_EXPRESSION_EVALUATION - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Enables simple expression evaluation for datagen parameters 'rows', 'cols'.
- ALLOW_SPLIT_HOP_DAGS - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Enables a specific hop dag rewrite that splits hop dags after csv persistent reads with
unknown size in order to allow for recompile.
- ALLOW_SUM_PRODUCT_REWRITES - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Enables sum product rewrites such as mapmultchains.
- ALLOW_WORSTCASE_SIZE_EXPRESSION_EVALUATION - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Enables simple expression evaluation for datagen parameters 'rows', 'cols'.
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.AggBinaryOp
-
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.AggUnaryOp
-
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.BinaryOp
-
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.codegen.SpoofFusedOp
-
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.DataGenOp
-
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.DataOp
-
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.DnnOp
-
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.FunctionOp
-
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.Hop
-
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.IndexingOp
-
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.LeftIndexingOp
-
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.LiteralOp
-
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.NaryOp
-
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.QuaternaryOp
-
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.ReorgOp
-
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.TernaryOp
-
- allowsAllExecTypes() - Method in class org.apache.sysds.hops.UnaryOp
-
- allowsBinaryCellPartitions(MatrixObject, ParForProgramBlock.PartitionFormat) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerRuleBased
-
- allowSharedDictionary - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
-
Share DDC Dictionaries between ColGroups.
- allowsShortCircuitCollect() - Method in class org.apache.sysds.runtime.instructions.spark.data.RDDObject
-
- allowsShortCircuitRead() - Method in class org.apache.sysds.runtime.instructions.spark.data.RDDObject
-
Indicates if rdd is an hdfs file or a checkpoint over an hdfs file;
in both cases, we can directly read the file instead of collecting
the given rdd.
- allowsToFilterEmptyBlockOutputs(Hop) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- allowWorkerStatistics - Static variable in class org.apache.sysds.utils.Statistics
-
- ALPHABET - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- ALPHABET - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- alwaysRequiresReblock(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- analyze(VariableSet) - Method in class org.apache.sysds.parser.ForStatementBlock
-
- analyze(VariableSet) - Method in class org.apache.sysds.parser.FunctionStatementBlock
-
- analyze(VariableSet, VariableSet) - Method in class org.apache.sysds.parser.FunctionStatementBlock
-
- analyze(VariableSet) - Method in class org.apache.sysds.parser.IfStatementBlock
-
- analyze(VariableSet) - Method in class org.apache.sysds.parser.LiveVariableAnalysis
-
- analyze(VariableSet) - Method in class org.apache.sysds.parser.StatementBlock
-
- analyze(VariableSet) - Method in class org.apache.sysds.parser.WhileStatementBlock
-
- analyzePlanPartitions(CPlanMemoTable, ArrayList<Hop>, boolean) - Static method in class org.apache.sysds.hops.codegen.opt.PlanAnalyzer
-
- analyzeProgram() - Method in class org.apache.sysds.hops.ipa.InterProceduralAnalysis
-
Main interface to perform IPA over a given DML program.
- analyzeProgram(int) - Method in class org.apache.sysds.hops.ipa.InterProceduralAnalysis
-
Main interface to perform IPA over a given DML program.
- analyzeSparkConfiguation(SparkConf) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext.SparkClusterConfig
-
- analyzeSparkConfiguationLegacy(SparkConf) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext.SparkClusterConfig
-
- analyzeSubProgram() - Method in class org.apache.sysds.hops.ipa.InterProceduralAnalysis
-
- and(EstimatorBitsetMM.BitsetMatrix) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix1
-
- and(EstimatorBitsetMM.BitsetMatrix) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix2
-
- And - Class in org.apache.sysds.runtime.functionobjects
-
- Append - Class in org.apache.sysds.lops
-
- Append(Lop, Lop, Lop, Types.DataType, Types.ValueType, boolean, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.Append
-
- append(MatrixBlock, MatrixBlock, boolean) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- append(MatrixValue, ArrayList<IndexedMatrixValue>, int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- append(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- append(int, int, double) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Append a value to the end of the physical representation.
- append(int, int, double) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- append(int, int, double) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- append(int, int, double) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- append(int, double) - Method in class org.apache.sysds.runtime.data.SparseRow
-
Appends a value to the end of the sparse row.
- append(int, double) - Method in class org.apache.sysds.runtime.data.SparseRowScalar
-
- append(int, double) - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- append(MatrixValue, ArrayList<IndexedMatrixValue>, int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- append(FrameBlock, FrameBlock, boolean) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Appends the given argument frameblock 'that' to this frameblock by
creating a deep copy to prevent side effects.
- append(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- append(MatrixBlock, MatrixBlock, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- append(MatrixBlock[], MatrixBlock, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- append(MatrixValue, ArrayList<IndexedMatrixValue>, int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- append(MatrixValue, ArrayList<IndexedMatrixValue>, int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- append(MatrixValue, ArrayList<IndexedMatrixValue>, int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- APPEND_MEM_MULTIPLIER - Static variable in class org.apache.sysds.hops.BinaryOp
-
- appendCell(long, long, Object) - Method in class org.apache.sysds.runtime.instructions.spark.data.FrameReblockBuffer
-
- appendCell(long, long, double) - Method in class org.apache.sysds.runtime.instructions.spark.data.ReblockBuffer
-
- appendColumn(String[]) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Append a column of value type STRING as the last column of
the data frame.
- appendColumn(boolean[]) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Append a column of value type BOOLEAN as the last column of
the data frame.
- appendColumn(int[]) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Append a column of value type INT as the last column of
the data frame.
- appendColumn(long[]) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Append a column of value type LONG as the last column of
the data frame.
- appendColumn(float[]) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Append a column of value type float as the last column of
the data frame.
- appendColumn(double[]) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Append a column of value type DOUBLE as the last column of
the data frame.
- appendColumns(double[][]) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Append a set of column of value type DOUBLE at the end of the frame
in order to avoid repeated allocation with appendColumns.
- AppendCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- AppendCPInstruction.AppendType - Enum in org.apache.sysds.runtime.instructions.cp
-
- AppendFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
-
- AppendG - Class in org.apache.sysds.lops
-
TODO Additional compiler enhancements:
1) Partial Shuffle Elimination - Any full or aligned blocks could be directly output from the mappers
to the result index.
- AppendG(Lop, Lop, Lop, Lop, Types.DataType, Types.ValueType, boolean, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.AppendG
-
- AppendGAlignedSP - Class in org.apache.sysds.lops
-
- AppendGAlignedSP(Lop, Lop, Lop, Types.DataType, Types.ValueType, boolean) - Constructor for class org.apache.sysds.lops.AppendGAlignedSP
-
- AppendGAlignedSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- AppendGAlignedSPInstruction.ShiftColumnIndex - Class in org.apache.sysds.runtime.instructions.spark
-
- AppendGSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- AppendGSPInstruction.MergeWithShiftedBlocks - Class in org.apache.sysds.runtime.instructions.spark
-
- AppendGSPInstruction.ShiftMatrix - Class in org.apache.sysds.runtime.instructions.spark
-
- AppendM - Class in org.apache.sysds.lops
-
- AppendM(Lop, Lop, Lop, Types.DataType, Types.ValueType, boolean, boolean, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.AppendM
-
- AppendM.CacheType - Enum in org.apache.sysds.lops
-
- AppendMSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- appendOpcode(StringBuilder) - Method in class org.apache.sysds.lops.DnnTransform
-
- appendOperands(int, int, String, StringBuilder) - Method in class org.apache.sysds.lops.DnnTransform
-
- appendParam(Object) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
-
- appendParams(Object...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
-
- AppendR - Class in org.apache.sysds.lops
-
- AppendR(Lop, Lop, Types.DataType, Types.ValueType, boolean, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.AppendR
-
- appendRow(Object[]) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Append a row to the end of the data frame, where all row fields
are boxed objects according to the schema.
- appendRow(String[]) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Append a row to the end of the data frame, where all row fields
are string encoded.
- appendRow(int, SparseRow) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- appendRow(int, SparseRow, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- appendRowToSparse(SparseBlock, MatrixBlock, int, int, int, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- AppendRSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- appendToSparse(MatrixBlock, int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- appendToSparse(MatrixBlock, int, int, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- appendValue(DblArray, IntArrayList) - Method in class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap
-
- appendValue(double, IntArrayList) - Method in class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap
-
- appendValue(int) - Method in class org.apache.sysds.runtime.compress.utils.IntArrayList
-
- appendValue(int, int, double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Append value is only used when values are appended at the end of each row for the sparse representation
This can only be called, when the caller knows the access pattern of the block
- apply(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ADictionary
-
Applies the scalar operation on the dictionary.
- apply(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.Dictionary
-
- apply(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.QDictionary
-
- apply(String) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock.FrameMapFunction
-
- apply(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.Encoder
-
Encode input data blockwise according to existing transform meta
data (transform apply).
- apply(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderBin
-
- apply(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderComposite
-
- apply(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderDummycode
-
- apply(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderFeatureHash
-
- apply(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
-
- apply(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
-
- apply(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderPassThrough
-
- apply(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderRecode
-
- applyScalarOp(ScalarOperator, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ADictionary
-
Applies the scalar operation on the dictionary.
- applyScalarOp(ScalarOperator, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.Dictionary
-
- applyScalarOp(ScalarOperator, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.QDictionary
-
- argVals - Variable in class org.apache.sysds.api.DMLOptions
-
- ArithmeticBinaryGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
- asArrayList(T...) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
-
- asin(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs an "asin" operation on a matrix on the GPU
- asIndexRange() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
-
- asList(List<T>...) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
-
- asMatrixCharacteristics() - Method in class org.apache.sysds.api.mlcontext.Metadata
-
Convert the metadata to a DataCharacteristics object.
- assembleTrainingData(JavaPairRDD<MatrixIndexes, MatrixBlock>, JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
Assemble the matrix of features and labels according to the rowID
- asSet(T...) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
-
- asSet(T[]...) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
-
- asSet(List<T>...) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
-
- assignColumns(int, ColGroup[], MatrixBlock, CompressionSettings) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupFactory
-
Method for producing the final ColGroupList stored inside the CompressedMatrixBlock.
- AssignmentStatement - Class in org.apache.sysds.parser
-
- AssignmentStatement(DataIdentifier, Expression) - Constructor for class org.apache.sysds.parser.AssignmentStatement
-
- AssignmentStatement(DataIdentifier, Expression, ParseInfo) - Constructor for class org.apache.sysds.parser.AssignmentStatement
-
- AssignmentStatement(ParserRuleContext, DataIdentifier, Expression) - Constructor for class org.apache.sysds.parser.AssignmentStatement
-
- AssignmentStatement(ParserRuleContext, DataIdentifier, Expression, String) - Constructor for class org.apache.sysds.parser.AssignmentStatement
-
- AssignmentStatementContext(DmlParser.StatementContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.AssignmentStatementContext
-
- atan(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs an "atan" operation on a matrix on the GPU
- AtomicExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.AtomicExpressionContext
-
- AUTHORPARAM - Static variable in class org.apache.sysds.parser.DataExpression
-
- available() - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- AVAILABLE_GPUS - Static variable in class org.apache.sysds.conf.DMLConfig
-
- AVAILABLE_GPUS - Static variable in class org.apache.sysds.runtime.instructions.gpu.context.GPUContextPool
-
GPUs to use, can specify -1 to use all, comma separated list of GPU numbers, a specific GPU or a range
- awaitTermination(long, TimeUnit) - Method in class org.apache.sysds.runtime.util.CommonThreadPool
-
- axpy(ExecutionContext, GPUContext, String, MatrixObject, MatrixObject, String, double) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs daxpy operation
- C - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- c2 - Variable in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
- CacheableData<T extends CacheBlock> - Class in org.apache.sysds.runtime.controlprogram.caching
-
Each object of this class is a cache envelope for some large piece of data
called "cache block".
- CacheableData.CacheStatus - Enum in org.apache.sysds.runtime.controlprogram.caching
-
Defines all possible cache status types for a data blob.
- cacheBinaryCellRDD(JavaPairRDD<MatrixIndexes, MatrixCell>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- CacheBlock - Interface in org.apache.sysds.runtime.controlprogram.caching
-
Interface for all blocks handled by lazy write buffer.
- CacheBlockFactory - Class in org.apache.sysds.runtime.controlprogram.caching
-
Factory to create instances of matrix/frame blocks given
internal codes.
- CacheBlockFactory() - Constructor for class org.apache.sysds.runtime.controlprogram.caching.CacheBlockFactory
-
- CacheDataInput - Class in org.apache.sysds.runtime.controlprogram.caching
-
- CacheDataInput(byte[]) - Constructor for class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- CacheDataOutput - Class in org.apache.sysds.runtime.controlprogram.caching
-
Custom DataOutput to serialize directly into the given byte array.
- CacheDataOutput(int) - Constructor for class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
-
- CacheDataOutput(byte[]) - Constructor for class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
-
- CachedReuseVariables - Class in org.apache.sysds.runtime.controlprogram.parfor
-
- CachedReuseVariables() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.CachedReuseVariables
-
- cacheEvictionLocalFilePath - Static variable in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- cacheEvictionLocalFilePrefix - Static variable in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- cacheMatrixObject(String) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- CacheStatistics - Class in org.apache.sysds.runtime.controlprogram.caching
-
This singleton provides basic caching statistics in CP.
- CacheStatistics() - Constructor for class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- CacheStatistics.Stat - Enum in org.apache.sysds.runtime.controlprogram.caching
-
- CACHING_ASYNC_FILECLEANUP - Static variable in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- CACHING_BUFFER_PAGECACHE - Static variable in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- CACHING_BUFFER_POLICY - Static variable in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- CACHING_BUFFER_SIZE - Static variable in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- CACHING_COUNTER_GROUP_NAME - Static variable in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- CACHING_EVICTION_FILEEXTENSION - Static variable in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- CACHING_THRESHOLD - Static variable in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- CACHING_WRITE_CACHE_ON_READ - Static variable in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- calculateIndexedDimensions(HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- call(Tuple2<Integer, LinkedList<Tuple2<Long, Tuple2<MatrixBlock, MatrixBlock>>>>) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionerSparkAggregator
-
Row-wise combine the matrix
- call(Tuple2<Long, Tuple2<MatrixBlock, MatrixBlock>>) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionerSparkMapper
-
Do data partitioning
- call() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.LocalPSWorker
-
- call(Tuple2<Integer, Tuple2<MatrixBlock, MatrixBlock>>) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.SparkPSWorker
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.DataPartitionerRemoteSparkMapper
-
- call(Tuple2<Long, Iterable<Writable>>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.DataPartitionerRemoteSparkReducer
-
- call(Iterator<Tuple2<Long, Iterable<Writable>>>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteDPParForSparkWorker
-
- call(Task) - Method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForSparkWorker
-
- call(Tuple2<MatrixIndexes, Tuple2<Iterable<MatrixBlock>, MatrixBlock>>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeRemoteSparkWCompare
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.AggregateUnarySPInstruction.RDDUAggFunction2
-
- call(Tuple2<TensorIndexes, TensorBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.AggregateUnarySPInstruction.RDDUTensorAggFunction2
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.AppendGAlignedSPInstruction.ShiftColumnIndex
-
- call(Tuple2<MatrixIndexes, Tuple2<Iterable<MatrixBlock>, Iterable<MatrixBlock>>>) - Method in class org.apache.sysds.runtime.instructions.spark.AppendGSPInstruction.MergeWithShiftedBlocks
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.AppendGSPInstruction.ShiftMatrix
-
- call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.BinUaggChainSPInstruction.RDDBinUaggChainFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.BuiltinNarySPInstruction.PadBlocksFunction
-
- call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.CompressionSPInstruction.CompressionFunction
-
- call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.CtableSPInstruction.MapJoinSignature1
-
- call(Tuple2<MatrixBlock, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.CtableSPInstruction.MapJoinSignature2
-
- call(Tuple2<Tuple2<MatrixBlock, MatrixBlock>, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.CtableSPInstruction.MapJoinSignature3
-
- call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.functions.AggregateDropCorrectionFunction
-
- call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ComputeBinaryBlockNnzFunction
-
- call(Tuple2<Long, FrameBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ConvertFrameBlockToIJVLines
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ConvertMatrixBlockToIJVLines
-
- call(String) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ConvertStringToLongTextPair
-
- call(Tuple2<MatrixIndexes, MatrixCell>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.CopyBinaryCellFunction
-
- call(FrameBlock) - Method in class org.apache.sysds.runtime.instructions.spark.functions.CopyFrameBlockFunction
-
- call(Tuple2<LongWritable, FrameBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.CopyFrameBlockPairFunction
-
- call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.functions.CopyMatrixBlockFunction
-
- call(Iterator<Tuple2<MatrixIndexes, MatrixBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.CopyMatrixBlockPairFunction
-
- call(BasicTensorBlock) - Method in class org.apache.sysds.runtime.instructions.spark.functions.CopyTensorBlockFunction
-
- call(Iterator<Tuple2<TensorIndexes, BasicTensorBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.CopyTensorBlockPairFunction
-
- call(Tuple2<LongWritable, Text>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.CopyTextInputFunction
-
- call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.functions.CreateSparseBlockFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ExtractBlockForBinaryReblock
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ExtractGroup.ExtractGroupBroadcast
-
- call(Tuple2<MatrixIndexes, Tuple2<MatrixBlock, MatrixBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ExtractGroup.ExtractGroupJoin
-
- call(Tuple2<MatrixIndexes, Tuple2<Tuple2<MatrixBlock, MatrixBlock>, MatrixBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ExtractGroupNWeights
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.FilterDiagMatrixBlocksFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.FilterNonEmptyBlocksFunction
-
- call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.functions.FilterNonEmptyBlocksFunction2
-
- call(Row) - Method in class org.apache.sysds.runtime.instructions.spark.functions.GetMIMBFromRow
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.IsBlockInList
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.IsBlockInRange
-
- call(Tuple2<Long, FrameBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.IsFrameBlockInRange
-
- call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.functions.MapInputSignature
-
- call(Tuple2<MatrixBlock[], MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.MapJoinSignature
-
- call(Tuple2<MatrixBlock, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.MatrixMatrixBinaryOpFunction
-
- call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.functions.MatrixScalarUnaryFunction
-
- call(Iterator<Tuple2<MatrixIndexes, MatrixBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.MatrixVectorBinaryOpPartitionFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.OuterVectorBinaryOpFunction
-
- call(WeightedCell, WeightedCell) - Method in class org.apache.sysds.runtime.instructions.spark.functions.PerformGroupByAggInCombiner
-
- call(Iterable<WeightedCell>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.PerformGroupByAggInReducer
-
- call(Tuple2<TensorIndexes, TensorBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ReblockTensorFunction
-
- call(Iterator<MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.RecomputeNnzFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ReorgMapFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ReplicateBlockFunction
-
- call(Tuple2<TensorIndexes, TensorBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ReplicateTensorFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ReplicateVectorFunction
-
- call(Tuple2<TensorBlock, TensorBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.TensorTensorBinaryOpFunction
-
- call(Iterator<Tuple2<TensorIndexes, TensorBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.TensorTensorBinaryOpPartitionFunction
-
- call(Iterator<Tuple2<Long, FrameBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeBuild2Function
-
- call(Iterator<Tuple2<Long, FrameBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeBuildFunction
-
- call(Tuple2<Integer, Iterable<FrameBlock.ColumnMetadata>>) - Method in class org.apache.sysds.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeGroup2Function
-
- call(Tuple2<Integer, Iterable<Object>>) - Method in class org.apache.sysds.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeGroupFunction
-
- call(WeightedCell) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.CreateMatrixCell
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDMapGroupedAggFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDMapGroupedAggFunction2
-
- call(Tuple2<MatrixIndexes, Tuple2<MatrixBlock, MatrixBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDRemoveEmptyFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDRemoveEmptyFunctionInMem
-
- call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDReplaceFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDRExpandFunction
-
- call(Tuple2<Long, FrameBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTransformApplyFunction
-
- call(Tuple2<Long, FrameBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTransformApplyOffsetFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTransformDecodeExpandFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTransformDecodeFunction
-
- call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.SpoofSPInstruction.ReplicateRightFactorFunction
-
- call(Tuple2<Long, FrameBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils.LongFrameToLongWritableFrameFunction
-
- call(Tuple2<LongWritable, FrameBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils.LongWritableFrameToLongFrameFunction
-
- call(Tuple2<LongWritable, Text>) - Method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils.LongWritableTextToLongTextFunction
-
- call(Tuple2<LongWritable, FrameBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils.LongWritableToSerFunction
-
- call(Iterator<Tuple2<MatrixIndexes, MatrixCell>>) - Method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils.BinaryCellToBinaryBlockFunction
-
- call(Row) - Method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils.DataFrameExtractIDFunction
-
- call(Tuple2<Row, Long>) - Method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtilsExt.AddRowID
-
- call() - Method in class org.apache.sysds.runtime.io.FrameReaderTextCellParallel.ReadTask
-
- call() - Method in class org.apache.sysds.runtime.io.IOUtilFunctions.CountRowsTask
-
- call() - Method in class org.apache.sysds.runtime.io.ReaderTextCellParallel.CountNnzTask
-
- call() - Method in class org.apache.sysds.runtime.io.ReaderTextCellParallel.ReadTask
-
- call() - Method in class org.apache.sysds.runtime.io.TensorWriterBinaryBlockParallel.WriteFileTask
-
- call() - Method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNRelu.ReluBackward
-
- callInstruction(String, CPOperand, CPOperand[], long[]) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
-
- canAllocate(long) - Method in class org.apache.sysds.runtime.instructions.gpu.context.CudaMemoryAllocator
-
Check if there is enough memory to allocate a pointer of given size
- canAllocate(long) - Method in interface org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryAllocator
-
Check if there is enough memory to allocate a pointer of given size
- canAllocate(long) - Method in class org.apache.sysds.runtime.instructions.gpu.context.UnifiedMemoryAllocator
-
Check if there is enough memory to allocate a pointer of given size
- capacity() - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Get the total length of allocated blocks.
- capacity() - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- capacity() - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- capacity() - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- capacity() - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- capacity() - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- capacity() - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
-
- capacity() - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
-
- capacity() - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
-
- capacity() - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
-
- capacity() - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
-
- capacity() - Method in class org.apache.sysds.runtime.data.DenseBlockLString
-
- capacity() - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- capacity() - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- CAPACITY - Static variable in class org.apache.sysds.runtime.io.ReaderTextCellParallel.CellBuffer
-
- cardinality(T, List<T>) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
-
- cardRatio - Variable in class org.apache.sysds.runtime.compress.cocode.PlanningCoCoder.GroupableColInfo
-
- CAST_AS_BOOLEAN_OPCODE - Static variable in class org.apache.sysds.lops.UnaryCP
-
- CAST_AS_DOUBLE_OPCODE - Static variable in class org.apache.sysds.lops.UnaryCP
-
- CAST_AS_FRAME_OPCODE - Static variable in class org.apache.sysds.lops.UnaryCP
-
- CAST_AS_INT_OPCODE - Static variable in class org.apache.sysds.lops.UnaryCP
-
- CAST_AS_MATRIX_OPCODE - Static variable in class org.apache.sysds.lops.UnaryCP
-
- CAST_AS_SCALAR_OPCODE - Static variable in class org.apache.sysds.lops.UnaryCP
-
- CastSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- castToDouble(ScalarObject) - Static method in class org.apache.sysds.runtime.instructions.cp.ScalarObjectFactory
-
- castToLong(ScalarObject) - Static method in class org.apache.sysds.runtime.instructions.cp.ScalarObjectFactory
-
- CATEGORY_CACHE - Static variable in class org.apache.sysds.runtime.util.LocalFileUtils
-
- CATEGORY_CODEGEN - Static variable in class org.apache.sysds.runtime.util.LocalFileUtils
-
- CATEGORY_LINEAGE - Static variable in class org.apache.sysds.runtime.util.LocalFileUtils
-
- CATEGORY_PARTITIONING - Static variable in class org.apache.sysds.runtime.util.LocalFileUtils
-
- CATEGORY_RESULTMERGE - Static variable in class org.apache.sysds.runtime.util.LocalFileUtils
-
- CATEGORY_WORK - Static variable in class org.apache.sysds.runtime.util.LocalFileUtils
-
- cbind(EstimatorBitsetMM.BitsetMatrix) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix1
-
- cbind(ExecutionContext, GPUContext, String, MatrixObject, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
- cbindMatrix(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
- CDATA_BEGIN - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- CDATA_END - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- ceil(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs an "ceil" operation on a matrix on the GPU
- Cell - Class in org.apache.sysds.runtime.controlprogram.parfor.util
-
Helper class for representing text cell and binary cell records in order to
allow for buffering and buffered read/write.
- Cell(long, long, double) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.util.Cell
-
- cell - Variable in class org.apache.sysds.runtime.controlprogram.parfor.util.PairWritableCell
-
- CELL_BUFFER_SIZE - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.util.StagingFileUtils
-
- CellBuffer() - Constructor for class org.apache.sysds.runtime.io.ReaderTextCellParallel.CellBuffer
-
- CellIndex(int, int) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixValue.CellIndex
-
- CentralMoment - Class in org.apache.sysds.lops
-
Lop to perform cross product operation
- CentralMoment(Lop, Lop, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.CentralMoment
-
- CentralMoment(Lop, Lop, Lop, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.CentralMoment
-
- CentralMomentCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- CentralMomentSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- chainMatrixMultOperations(MatrixBlock, MatrixBlock, MatrixBlock, MapMultChain.ChainType) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- chainMatrixMultOperations(MatrixBlock, MatrixBlock, MatrixBlock, MapMultChain.ChainType, int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- chainMatrixMultOperations(MatrixBlock, MatrixBlock, MatrixBlock, MapMultChain.ChainType) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- chainMatrixMultOperations(MatrixBlock, MatrixBlock, MatrixBlock, MapMultChain.ChainType, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedWorkerHandler
-
- channelSums(GPUContext, String, MatrixObject, MatrixObject, long, long) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Perform channel_sums operations: out = rowSums(matrix(colSums(A), rows=C, cols=HW))
- channelSums(MatrixBlock, MatrixBlock, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNN
-
Perform channel sum operation
- CHAR_SIZE - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
- charArrayCost(int) - Static method in class org.apache.sysds.utils.MemoryEstimates
-
- check(boolean, String, Object...) - Static method in exception org.apache.sysds.hops.HopsException
-
If the condition fails, print the message formatted with objects.
- check(boolean, Hop, String, Object...) - Static method in exception org.apache.sysds.hops.HopsException
-
If the condition fails, print the Op and its Id, along with the message formatted with objects.
- CHECK - Static variable in class org.apache.sysds.parser.ParForStatementBlock
-
- CHECK_PRIVACY - Static variable in class org.apache.sysds.api.DMLScript
-
- checkAllDataTypes(Types.DataType) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- checkAndCleanupLeafNodes() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- checkAndCleanupRecursiveFunc(Set<String>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- checkAndCreateStagingDir(String) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
- checkAndRaiseErrorCSVEmptyField(String, boolean, boolean) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- checkAndRaiseErrorCSVNumColumns(String, String, String[], long) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- checkAndReplaceCP(Instruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.FEDInstructionUtils
-
- checkAndReplaceSP(Instruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.FEDInstructionUtils
-
- checkAndSetForcedPlatform() - Method in class org.apache.sysds.hops.Hop
-
- checkAndSetInvalidCPDimsAndSize() - Method in class org.apache.sysds.hops.Hop
-
- checkArity() - Method in class org.apache.sysds.hops.AggBinaryOp
-
- checkArity() - Method in class org.apache.sysds.hops.AggUnaryOp
-
- checkArity() - Method in class org.apache.sysds.hops.BinaryOp
-
- checkArity() - Method in class org.apache.sysds.hops.codegen.SpoofFusedOp
-
- checkArity() - Method in class org.apache.sysds.hops.DataGenOp
-
- checkArity() - Method in class org.apache.sysds.hops.DataOp
-
Check for N (READ) or N+1 (WRITE) inputs.
- checkArity() - Method in class org.apache.sysds.hops.DnnOp
-
- checkArity() - Method in class org.apache.sysds.hops.FunctionOp
-
FunctionOps may have any number of inputs.
- checkArity() - Method in class org.apache.sysds.hops.Hop
-
Check whether this Hop has a correct number of inputs.
- checkArity() - Method in class org.apache.sysds.hops.IndexingOp
-
- checkArity() - Method in class org.apache.sysds.hops.LeftIndexingOp
-
- checkArity() - Method in class org.apache.sysds.hops.LiteralOp
-
- checkArity() - Method in class org.apache.sysds.hops.NaryOp
-
MultipleOp may have any number of inputs.
- checkArity() - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- checkArity() - Method in class org.apache.sysds.hops.QuaternaryOp
-
- checkArity() - Method in class org.apache.sysds.hops.ReorgOp
-
- checkArity() - Method in class org.apache.sysds.hops.TernaryOp
-
- checkArity() - Method in class org.apache.sysds.hops.UnaryOp
-
- checkAvgRowsGteCols(List<Hop>) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- checkConsistentRows(List<Hop>, List<Hop>) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- checkCPCheckpoint(DataCharacteristics) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- checkCPReblock(ExecutionContext, String) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
CP Reblock check for spark instructions; in contrast to MR, we can not
rely on the input file sizes because inputs might be passed via rdds.
- checkCycles(LineageItem) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
-
- CheckedConstraintsLog - Class in org.apache.sysds.runtime.privacy
-
Class counting the checked privacy constraints and the loaded privacy constraints.
- CheckedConstraintsLog() - Constructor for class org.apache.sysds.runtime.privacy.CheckedConstraintsLog
-
- checkHasDelimitedFormat(String, boolean) - Method in class org.apache.sysds.parser.DataExpression
-
- checkHasMatrixMarketFormat(String, String, boolean) - Method in class org.apache.sysds.parser.DataExpression
-
- checkInputDataTypes(Hop, Types.DataType...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- checkInputParameterType(String, Object) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Verify that the type of input parameter value is supported.
- checkInputValueType(String, Object) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Verify that the type of input value is supported.
- checkInputValueTypes(Map<String, Object>) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Verify that the types of input values are supported.
- checkMapMultChain() - Method in class org.apache.sysds.hops.AggBinaryOp
-
MapMultChain: Determine if XtwXv/XtXv pattern applies for this aggbinary
and if yes which type.
- checkMaxStringLength(long) - Static method in class org.apache.sysds.runtime.instructions.cp.StringObject
-
- checkNaN() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Checks for existing NaN values in the matrix block.
- checkNonZeros() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Basic debugging primitive to check correctness of nnz.
- checkNumFields(String, int) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- checkNumFields(String[], int) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- checkNumFields(String[], int, int) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- checkNumFields(String[], int...) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- checkNumFields(String, int, int) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- Checkpoint - Class in org.apache.sysds.lops
-
Lop for checkpoint operations.
- Checkpoint(Lop, Types.DataType, Types.ValueType, String) - Constructor for class org.apache.sysds.lops.Checkpoint
-
TODO change string parameter storage.level to StorageLevel as soon as we can assume
that Spark libraries are always available.
- CHECKPOINT_SPARSE_CSR - Static variable in class org.apache.sysds.lops.Checkpoint
-
- CheckpointSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- checkPrivacy - Variable in class org.apache.sysds.api.DMLOptions
-
- checkPrivacy() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
-
- checkProgramCorrectness(ProgramBlock, StatementBlock, Set<String>) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanChecker
-
- checkResult(int) - Static method in class org.apache.sysds.runtime.instructions.gpu.context.JCudaKernels
-
- checkSerialized() - Method in class org.apache.sysds.runtime.controlprogram.caching.ByteBuffer
-
- checkSparkBroadcastMemoryBudget(double) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- checkSparkBroadcastMemoryBudget(long, long, long, long) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- checkSparkCollectMemoryBudget(DataCharacteristics, long) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- checkSparkCollectMemoryBudget(DataCharacteristics, long, boolean) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- checkSparseBlockCSRConversion(DataCharacteristics) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- checkSparseRows() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- checkSparseRows(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Basic debugging primitive to check sparse block column ordering.
- checkTransposeSelf() - Method in class org.apache.sysds.hops.AggBinaryOp
-
TSMM: Determine if XtX pattern applies for this aggbinary and if yes
which type.
- checkValidity(int, int, long, boolean) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Validate the correctness of the internal data structures of the different
sparse block implementations.
- checkValidity(int, int, long, boolean) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- checkValidity(int, int, long, boolean) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- checkValidity(int, int, long, boolean) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- clean - Variable in class org.apache.sysds.api.DMLOptions
-
- cleanup() - Static method in class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
-
- cleanup(long, long...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- cleanupBlock(boolean, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Allows to cleanup all previously allocated sparserows or denseblocks.
- cleanupBroadcastVariable(Broadcast<?>) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
This call destroys a broadcast variable at all executors and the driver.
- cleanupCacheableData(CacheableData<?>) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- cleanupCacheableData(CacheableData<?>) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- cleanupCacheDir() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- cleanupCacheDir(boolean) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
Deletes the DML-script-specific caching working dir.
- cleanupCachedVariables(long) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForSparkWorker
-
- cleanupCodeGenerator() - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
-
- cleanupData(ExecutionContext, Data) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
- cleanupData(ExecutionContext, String) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
- cleanupDataObject(Data) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- cleanupHadoopExecution(DMLConfig) - Static method in class org.apache.sysds.api.DMLScript
-
- cleanupListObject(ExecutionContext, String) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
Clean up the list object according to its own data status
- cleanupListObject(ExecutionContext, String, boolean[]) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
Clean up the list object according to the given array of data status (i.e., false => not be removed)
- cleanupListObject(ExecutionContext, ListObject) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
- cleanupListObject(ExecutionContext, ListObject, boolean[]) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
- cleanupListObject(ListObject) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
- cleanupLiveOutVariables(List<StatementBlock>, VariableSet) - Method in class org.apache.sysds.parser.DMLTranslator
-
- cleanupRcWorkingDirectory(String) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
- cleanupRDDVariable(JavaPairRDD<?, ?>) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
This call removes an rdd variable from executor memory and disk if required.
- cleanupRuntimeInstructions(ArrayList<Instruction>, String...) - Static method in class org.apache.sysds.api.jmlc.JMLCUtils
-
Cleanup runtime instructions, removing rmvar instructions for
any of the given output variable names.
- cleanupRuntimeInstructions(ArrayList<Instruction>, HashSet<String>) - Static method in class org.apache.sysds.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.sysds.api.jmlc.JMLCUtils
-
Removes rmvar instructions that would remove any of the given outputs.
- cleanupThreadLocalMemory() - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- cleanupThreadLocalMemory() - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupValue
-
- cleanupThreadLocalSchedulerPool(int) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- cleanupUnreferenced(Hop...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- cleanupWorkingDirectories() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForUtils
-
Cleanup all temporary files created by this SystemDS process.
- cleanupWorkingDirectoriesOnShutdown() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForUtils
-
Cleanup all temporary files created by this SystemDS process,
on shutdown via exit or interrupt.
- cleanupWorkingDirectory() - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
- cleanupWorkingDirectory(String) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
- clear() - Static method in class org.apache.sysds.runtime.controlprogram.caching.PageCache
-
- clear() - Method in class org.apache.sysds.runtime.controlprogram.federated.ExecutionContextMap
-
- clear() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
-
- clear() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMapping
-
- clear() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingAbstract
-
- clear() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingRuntime
-
- clearAll() - Method in class org.apache.sysds.api.mlcontext.Script
-
Clear the script string, inputs, outputs, and symbol table.
- clearAll() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
- clearBlocks() - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- clearCheckedConstraints() - Static method in class org.apache.sysds.runtime.privacy.PrivacyMonitor
-
- clearClassCache() - Static method in class org.apache.sysds.runtime.codegen.CodegenUtils
-
- clearClassCache(Class<?>) - Static method in class org.apache.sysds.runtime.codegen.CodegenUtils
-
- clearData() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- clearData(long) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
Sets the cache block reference to null
, abandons the old block.
- clearData(String, boolean) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Clears the data associated with this
GPUObject
instance
- clearDedupBlock() - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- clearDensePointer() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Removes the dense pointer and potential soft reference
- clearFederatedWorkers() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
-
- clearInputs() - Method in class org.apache.sysds.api.mlcontext.Script
-
Clear the inputs.
- clearIO() - Method in class org.apache.sysds.api.mlcontext.Script
-
Clear the inputs and outputs, but not the symbol table.
- clearIOS() - Method in class org.apache.sysds.api.mlcontext.Script
-
Clear the inputs, outputs, and symbol table.
- clearLineageMap() - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- clearLocalConfigs() - Static method in class org.apache.sysds.conf.ConfigurationManager
-
Removes the thread-local dml and compiler configurations, leading to
a reinitialization on the next get unless set in between.
- clearMemEstimate() - Method in class org.apache.sysds.hops.Hop
-
- clearMemory() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
- clearMemory() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryManager
-
Clear the allocated GPU objects
- clearOutputs() - Method in class org.apache.sysds.api.mlcontext.Script
-
Clear the outputs.
- clearParameters() - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Remove all current values bound to input or output variables.
- clearPinnedData() - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Remove all references to pinned variables from this script.
- clearShadowPointer() - Method in class org.apache.sysds.runtime.instructions.gpu.context.ShadowBuffer
-
Removes the content from shadow buffer
- clearSymbolTable() - Method in class org.apache.sysds.api.mlcontext.Script
-
Clear the symbol table.
- clearTemporaryMemory() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
- clearTemporaryMemory() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryManager
-
Clears up the memory used by non-dirty pointers.
- clearValidCompression() - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
-
Clear all the compression types allowed in the compression.
- clearVariables(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.CachedReuseVariables
-
- clen - Variable in class org.apache.sysds.runtime.codegen.SpoofOperator.SideInput
-
- clen - Variable in class org.apache.sysds.runtime.io.ReadProperties
-
- clone(boolean) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Creates a cloned instance of the prepared script, which
allows for concurrent execution without side effects.
- clone() - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
- clone() - Method in class org.apache.sysds.conf.CompilerConfig
-
- clone() - Method in class org.apache.sysds.conf.DMLConfig
-
- clone() - Method in class org.apache.sysds.hops.AggBinaryOp
-
- clone() - Method in class org.apache.sysds.hops.AggUnaryOp
-
- clone() - Method in class org.apache.sysds.hops.BinaryOp
-
- clone() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- clone() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
-
- clone() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeOuterProduct
-
- clone() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
-
- clone() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
-
- clone() - Method in class org.apache.sysds.hops.codegen.SpoofFusedOp
-
- clone() - Method in class org.apache.sysds.hops.cost.VarStats
-
- clone() - Method in class org.apache.sysds.hops.DataGenOp
-
- clone() - Method in class org.apache.sysds.hops.DataOp
-
- clone() - Method in class org.apache.sysds.hops.DnnOp
-
- clone() - Method in class org.apache.sysds.hops.FunctionOp
-
- clone() - Method in class org.apache.sysds.hops.Hop
-
- clone() - Method in class org.apache.sysds.hops.IndexingOp
-
- clone() - Method in class org.apache.sysds.hops.LeftIndexingOp
-
- clone() - Method in class org.apache.sysds.hops.LiteralOp
-
- clone() - Method in class org.apache.sysds.hops.NaryOp
-
- clone() - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- clone() - Method in class org.apache.sysds.hops.QuaternaryOp
-
- clone() - Method in class org.apache.sysds.hops.recompile.RecompileStatus
-
- clone() - Method in class org.apache.sysds.hops.ReorgOp
-
- clone() - Method in class org.apache.sysds.hops.TernaryOp
-
- clone() - Method in class org.apache.sysds.hops.UnaryOp
-
- clone() - Method in class org.apache.sysds.runtime.compress.colgroup.ADictionary
-
Returns a deep clone of the dictionary.
- clone() - Method in class org.apache.sysds.runtime.compress.colgroup.Dictionary
-
- clone() - Method in class org.apache.sysds.runtime.compress.colgroup.QDictionary
-
- clone() - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
-
- clone(boolean) - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- clone() - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- clone() - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
-
- clone(int) - Method in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
- clone() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
- clone() - Method in class org.apache.sysds.runtime.meta.MetaData
-
- clone() - Method in class org.apache.sysds.runtime.meta.MetaDataFormat
-
- cloneFunctionBlock() - Method in interface org.apache.sysds.common.Types.FunctionBlock
-
- cloneFunctionBlock() - Method in class org.apache.sysds.parser.FunctionStatementBlock
-
- cloneFunctionBlock() - Method in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
-
- cloneInstruction(Instruction, long, boolean, boolean) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- close() - Method in class org.apache.sysds.api.jmlc.Connection
-
Close connection to SystemDS, which clears the
thread-local DML and compiler configurations.
- close() - Method in class org.apache.sysds.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(Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateBase
-
Indicates if the template must be closed at the current hop; either
due to final operations (e.g., aggregate) or unsupported operations.
- close(Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateCell
-
- close(Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateMultiAgg
-
- close(Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateOuterProduct
-
- close(Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateRow
-
- close() - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- close() - Method in class org.apache.sysds.runtime.io.BinaryBlockSerialization.MatrixBlockDeserializer
-
- close() - Method in class org.apache.sysds.runtime.io.BinaryBlockSerialization.MatrixBlockSerializer
-
- close() - Method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNConvolutionAlgorithm
-
Deallocates the tensor and filter descriptors as well as allocated workspace
- close() - Method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNInputRowFetcher
-
Deallocates temporary pointer
- close() - Method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNPoolingDescriptors
-
- close() - Method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNRnnAlgorithm
-
- close() - Method in class org.apache.sysds.runtime.util.BinaryBlockRecordReader
-
- close() - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
-
- closeInput() - Method in class org.apache.sysds.runtime.controlprogram.parfor.LocalTaskQueue
-
Synchronized (logical) insert of a NO_MORE_TASKS symbol at the end of the FIFO queue in order to
mark that no more tasks will be inserted into the queue.
- closeSilently(Closeable) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- closeSilently(RecordReader<?, ?>) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- CM - Class in org.apache.sysds.runtime.functionobjects
-
GENERAL NOTE:
* 05/28/2014: We decided to do handle weights consistently to SPSS in an operation-specific manner,
i.e., we (1) round instead of casting where required (e.g.
- CM_COV_Object - Class in org.apache.sysds.runtime.instructions.cp
-
- CM_COV_Object() - Constructor for class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
- CM_N_COVCell - Class in org.apache.sysds.runtime.matrix.data
-
- CM_N_COVCell() - Constructor for class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- cmOperations(CMOperator) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- cmOperations(CMOperator, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- cmOperations(CMOperator) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- cmOperations(CMOperator, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- CMOperator - Class in org.apache.sysds.runtime.matrix.operators
-
- CMOperator(ValueFunction, CMOperator.AggregateOperationTypes) - Constructor for class org.apache.sysds.runtime.matrix.operators.CMOperator
-
- CMOperator.AggregateOperationTypes - Enum in org.apache.sysds.runtime.matrix.operators
-
- CNode - Class in org.apache.sysds.hops.codegen.cplan
-
- CNode() - Constructor for class org.apache.sysds.hops.codegen.cplan.CNode
-
- CNodeBinary - Class in org.apache.sysds.hops.codegen.cplan
-
- CNodeBinary(CNode, CNode, CNodeBinary.BinType) - Constructor for class org.apache.sysds.hops.codegen.cplan.CNodeBinary
-
- CNodeBinary.BinType - Enum in org.apache.sysds.hops.codegen.cplan
-
- CNodeCell - Class in org.apache.sysds.hops.codegen.cplan
-
- CNodeCell(ArrayList<CNode>, CNode) - Constructor for class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- CNodeData - Class in org.apache.sysds.hops.codegen.cplan
-
- CNodeData(Hop) - Constructor for class org.apache.sysds.hops.codegen.cplan.CNodeData
-
- CNodeData(Hop, long, long, Types.DataType) - Constructor for class org.apache.sysds.hops.codegen.cplan.CNodeData
-
- CNodeData(CNodeData, String) - Constructor for class org.apache.sysds.hops.codegen.cplan.CNodeData
-
- CNodeMultiAgg - Class in org.apache.sysds.hops.codegen.cplan
-
- CNodeMultiAgg(ArrayList<CNode>, ArrayList<CNode>) - Constructor for class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
-
- CNodeNary - Class in org.apache.sysds.hops.codegen.cplan
-
- CNodeNary(CNode[], CNodeNary.NaryType) - Constructor for class org.apache.sysds.hops.codegen.cplan.CNodeNary
-
- CNodeNary.NaryType - Enum in org.apache.sysds.hops.codegen.cplan
-
- CNodeOuterProduct - Class in org.apache.sysds.hops.codegen.cplan
-
- CNodeOuterProduct(ArrayList<CNode>, CNode, MMTSJ.MMTSJType) - Constructor for class org.apache.sysds.hops.codegen.cplan.CNodeOuterProduct
-
- CNodeRow - Class in org.apache.sysds.hops.codegen.cplan
-
- CNodeRow(ArrayList<CNode>, CNode) - Constructor for class org.apache.sysds.hops.codegen.cplan.CNodeRow
-
- CNodeTernary - Class in org.apache.sysds.hops.codegen.cplan
-
- CNodeTernary(CNode, CNode, CNode, CNodeTernary.TernaryType) - Constructor for class org.apache.sysds.hops.codegen.cplan.CNodeTernary
-
- CNodeTernary.TernaryType - Enum in org.apache.sysds.hops.codegen.cplan
-
- CNodeTpl - Class in org.apache.sysds.hops.codegen.cplan
-
- CNodeTpl(ArrayList<CNode>, CNode) - Constructor for class org.apache.sysds.hops.codegen.cplan.CNodeTpl
-
- CNodeUnary - Class in org.apache.sysds.hops.codegen.cplan
-
- CNodeUnary(CNode, CNodeUnary.UnaryType) - Constructor for class org.apache.sysds.hops.codegen.cplan.CNodeUnary
-
- CNodeUnary.UnaryType - Enum in org.apache.sysds.hops.codegen.cplan
-
- CODEGEN - Static variable in class org.apache.sysds.conf.DMLConfig
-
- codegen(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- codegen(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeBinary
-
- codegen(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- codegen(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeData
-
- codegen(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
-
- codegen(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeNary
-
- codegen(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeOuterProduct
-
- codegen(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
-
- codegen(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTernary
-
- codegen() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
-
- codegen(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeUnary
-
- CODEGEN_COMPILER - Static variable in class org.apache.sysds.conf.DMLConfig
-
- CODEGEN_LITERALS - Static variable in class org.apache.sysds.conf.DMLConfig
-
- CODEGEN_OPTIMIZER - Static variable in class org.apache.sysds.conf.DMLConfig
-
- CODEGEN_PLANCACHE - Static variable in class org.apache.sysds.conf.DMLConfig
-
- CodegenUtils - Class in org.apache.sysds.runtime.codegen
-
- CodegenUtils() - Constructor for class org.apache.sysds.runtime.codegen.CodegenUtils
-
- codgenHopsDAG(DMLProgram) - Method in class org.apache.sysds.parser.DMLTranslator
-
- codgenHopsDAG(Program) - Method in class org.apache.sysds.parser.DMLTranslator
-
- codgenHopsDAG(ProgramBlock) - Method in class org.apache.sysds.parser.DMLTranslator
-
- col2imOverSingleImage(int, MatrixBlock, DnnParameters) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNIm2Col
-
- colEnd - Variable in class org.apache.sysds.runtime.util.IndexRange
-
- ColGroup - Class in org.apache.sysds.runtime.compress.colgroup
-
Class that stores information about a column group within a compressed matrix block.
- ColGroup.CompressionType - Enum in org.apache.sysds.runtime.compress.colgroup
-
Public Group types supported
Note For instance DDC is called DDC not DDC1, or DDC2 which is a specific subtype of the DDC.
- ColGroupConverter - Class in org.apache.sysds.runtime.compress.colgroup
-
Utility functions for ColGroup to convert ColGroups or MatrixBlocks.
- ColGroupConverter() - Constructor for class org.apache.sysds.runtime.compress.colgroup.ColGroupConverter
-
- ColGroupDDC - Class in org.apache.sysds.runtime.compress.colgroup
-
Class to encapsulate information about a column group that is encoded with dense dictionary encoding (DDC).
- ColGroupDDC1 - Class in org.apache.sysds.runtime.compress.colgroup
-
Class to encapsulate information about a column group that is encoded with dense dictionary encoding (DDC) using 1
byte codes.
- ColGroupDDC2 - Class in org.apache.sysds.runtime.compress.colgroup
-
Class to encapsulate information about a column group that is encoded with dense dictionary encoding (DDC) using 2
byte codes.
- ColGroupFactory - Class in org.apache.sysds.runtime.compress.colgroup
-
Factory pattern for constructing ColGroups.
- ColGroupFactory() - Constructor for class org.apache.sysds.runtime.compress.colgroup.ColGroupFactory
-
- ColGroupIO - Class in org.apache.sysds.runtime.compress.colgroup
-
This has the IO responsibility of ColGroups, such that it enables to read and write ColGroups to and from a DataInput
and DataOutput
- ColGroupIO() - Constructor for class org.apache.sysds.runtime.compress.colgroup.ColGroupIO
-
- ColGroupOffset - Class in org.apache.sysds.runtime.compress.colgroup
-
Base class for column groups encoded with various types of bitmap encoding.
- ColGroupOLE - Class in org.apache.sysds.runtime.compress.colgroup
-
Class to encapsulate information about a column group that is encoded with simple lists of offsets for each set of
distinct values.
- ColGroupRLE - Class in org.apache.sysds.runtime.compress.colgroup
-
A group of columns compressed with a single run-length encoded bitmap.
- ColGroupSizes - Class in org.apache.sysds.runtime.compress.colgroup
-
- ColGroupSizes() - Constructor for class org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
-
- ColGroupUncompressed - Class in org.apache.sysds.runtime.compress.colgroup
-
Column group type for columns that are stored as dense arrays of doubles.
- ColGroupValue - Class in org.apache.sysds.runtime.compress.colgroup
-
Base class for column groups encoded with value dictionary.
- colInd - Variable in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
integer array of nnz values' column indices
- ColIndexes(int[]) - Constructor for class org.apache.sysds.runtime.compress.cocode.PlanningCoCodingGroup.ColIndexes
-
- CollectionUtils - Class in org.apache.sysds.runtime.util
-
- CollectionUtils() - Constructor for class org.apache.sysds.runtime.util.CollectionUtils
-
- colLower - Variable in class org.apache.sysds.parser.dml.DmlParser.IndexedExpressionContext
-
- colsC - Variable in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfo
-
- colsKnown() - Method in class org.apache.sysds.hops.Hop
-
- colsKnown() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- colsKnown() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- colSpan() - Method in class org.apache.sysds.runtime.util.IndexRange
-
- colStart - Variable in class org.apache.sysds.runtime.util.IndexRange
-
- colsUC - Variable in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfo
-
- column - Variable in class org.apache.sysds.runtime.matrix.data.MatrixValue.CellIndex
-
- COLUMN_WISE - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
-
- COLUMNBLOCKCOUNTPARAM - Static variable in class org.apache.sysds.parser.DataExpression
-
- ColumnGroupIterator - Class in org.apache.sysds.runtime.compress.utils
-
- ColumnGroupIterator(int, int, int, int, boolean, List<ColGroup>) - Constructor for class org.apache.sysds.runtime.compress.utils.ColumnGroupIterator
-
- ColumnGroupPartitioner - Class in org.apache.sysds.runtime.compress.cocode
-
- ColumnGroupPartitioner() - Constructor for class org.apache.sysds.runtime.compress.cocode.ColumnGroupPartitioner
-
- ColumnGroupPartitionerBinPacking - Class in org.apache.sysds.runtime.compress.cocode
-
Column group partitioning with bin packing heuristic.
- ColumnGroupPartitionerBinPacking() - Constructor for class org.apache.sysds.runtime.compress.cocode.ColumnGroupPartitionerBinPacking
-
- ColumnGroupPartitionerStatic - Class in org.apache.sysds.runtime.compress.cocode
-
Column group partitioning with static distribution heuristic.
- ColumnGroupPartitionerStatic() - Constructor for class org.apache.sysds.runtime.compress.cocode.ColumnGroupPartitionerStatic
-
- columnMajorDenseToRowMajorSparse(GPUContext, cusparseHandle, Pointer, int, int) - Static method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Convenience method to convert a CSR matrix to a dense matrix on the GPU
Since the allocated matrix is temporary, bookkeeping is not updated.
- ColumnMetadata(long) - Constructor for class org.apache.sysds.runtime.matrix.data.FrameBlock.ColumnMetadata
-
- ColumnMetadata(long, String) - Constructor for class org.apache.sysds.runtime.matrix.data.FrameBlock.ColumnMetadata
-
- ColumnMetadata(FrameBlock.ColumnMetadata) - Constructor for class org.apache.sysds.runtime.matrix.data.FrameBlock.ColumnMetadata
-
- columnPartitioner - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
-
The selected method for column partitioning used in CoCoding compressed columns
- colUpper - Variable in class org.apache.sysds.parser.dml.DmlParser.IndexedExpressionContext
-
- COMBINEDINPUT - Static variable in class org.apache.sysds.lops.GroupedAggregate
-
- COMMANDLINE_NAMED_ID - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- COMMANDLINE_NAMED_ID - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- COMMANDLINE_NAMED_ID() - Method in class org.apache.sysds.parser.dml.DmlParser.CommandlineParamExpressionContext
-
- COMMANDLINE_POSITION_ID - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- COMMANDLINE_POSITION_ID - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- COMMANDLINE_POSITION_ID() - Method in class org.apache.sysds.parser.dml.DmlParser.CommandlinePositionExpressionContext
-
- commandLineParam - Variable in class org.apache.sysds.parser.dml.DmlParser.IfdefAssignmentStatementContext
-
- CommandlineParamExpressionContext(DmlParser.DataIdentifierContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.CommandlineParamExpressionContext
-
- CommandlinePositionExpressionContext(DmlParser.DataIdentifierContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.CommandlinePositionExpressionContext
-
- CommonThreadPool - Class in org.apache.sysds.runtime.util
-
This common thread pool provides an abstraction to obtain a shared
thread pool, specifically the ForkJoinPool.commonPool, for all requests
of the maximum degree of parallelism.
- CommonThreadPool(ExecutorService) - Constructor for class org.apache.sysds.runtime.util.CommonThreadPool
-
- compact(int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Re-allocate physical row if physical size exceeds
logical size plus resize factor.
- compact(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- compact(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- compact(int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- compact() - Method in class org.apache.sysds.runtime.data.SparseRow
-
In-place compaction of non-zero-entries; removes zero entries
and shifts non-zero entries to the left if necessary.
- compact() - Method in class org.apache.sysds.runtime.data.SparseRowScalar
-
- compact() - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- compactEmptyBlock() - Method in interface org.apache.sysds.runtime.controlprogram.caching.CacheBlock
-
Free unnecessarily allocated empty block.
- compactEmptyBlock() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- compactEmptyBlock() - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- compactEmptyBlock() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- Comparator() - Constructor for class org.apache.sysds.runtime.matrix.data.TripleIndexes.Comparator
-
- compare(Hop) - Method in class org.apache.sysds.hops.AggBinaryOp
-
- compare(Hop) - Method in class org.apache.sysds.hops.AggUnaryOp
-
- compare(Hop) - Method in class org.apache.sysds.hops.BinaryOp
-
- compare(Hop) - Method in class org.apache.sysds.hops.codegen.SpoofFusedOp
-
- compare(Hop, Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateCell.HopInputComparator
-
- compare(Hop, Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateRow.HopInputComparator
-
- compare(Hop) - Method in class org.apache.sysds.hops.DataGenOp
-
- compare(Hop) - Method in class org.apache.sysds.hops.DataOp
-
- compare(Hop) - Method in class org.apache.sysds.hops.DnnOp
-
- compare(Hop) - Method in class org.apache.sysds.hops.FunctionOp
-
- compare(Hop) - Method in class org.apache.sysds.hops.Hop
-
- compare(Hop) - Method in class org.apache.sysds.hops.IndexingOp
-
- compare(Hop) - Method in class org.apache.sysds.hops.LeftIndexingOp
-
- compare(Hop) - Method in class org.apache.sysds.hops.LiteralOp
-
- compare(Hop) - Method in class org.apache.sysds.hops.NaryOp
-
- compare(Hop) - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- compare(Hop) - Method in class org.apache.sysds.hops.QuaternaryOp
-
- compare(Hop) - Method in class org.apache.sysds.hops.ReorgOp
-
- compare(Hop) - Method in class org.apache.sysds.hops.TernaryOp
-
- compare(Hop) - Method in class org.apache.sysds.hops.UnaryOp
-
- compare(N, N) - Method in class org.apache.sysds.lops.compile.LopComparator
-
- compare(DblArrayIntListHashMap.DArrayIListEntry, DblArrayIntListHashMap.DArrayIListEntry) - Method in class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap.DArrayIListEntry
-
- compare(DoubleIntListHashMap.DIListEntry, DoubleIntListHashMap.DIListEntry) - Method in class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap.DIListEntry
-
- compare(WritableComparable, WritableComparable) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeRemoteGrouping
-
- compare(WritableComparable, WritableComparable) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeRemoteSorting
-
- compare(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Equals
-
- compare(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Equals
-
- compare(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.Equals
-
- compare(String, String) - Method in class org.apache.sysds.runtime.functionobjects.Equals
-
- compare(double, double) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThan
-
- compare(long, long) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThan
-
- compare(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThan
-
- compare(String, String) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThan
-
- compare(double, double) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThanEquals
-
- compare(long, long) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThanEquals
-
- compare(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThanEquals
-
- compare(String, String) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThanEquals
-
- compare(double, double) - Method in class org.apache.sysds.runtime.functionobjects.LessThan
-
- compare(long, long) - Method in class org.apache.sysds.runtime.functionobjects.LessThan
-
- compare(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.LessThan
-
- compare(String, String) - Method in class org.apache.sysds.runtime.functionobjects.LessThan
-
- compare(double, double) - Method in class org.apache.sysds.runtime.functionobjects.LessThanEquals
-
- compare(long, long) - Method in class org.apache.sysds.runtime.functionobjects.LessThanEquals
-
- compare(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.LessThanEquals
-
- compare(String, String) - Method in class org.apache.sysds.runtime.functionobjects.LessThanEquals
-
- compare(double, double) - Method in class org.apache.sysds.runtime.functionobjects.NotEquals
-
- compare(long, long) - Method in class org.apache.sysds.runtime.functionobjects.NotEquals
-
- compare(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.NotEquals
-
- compare(String, String) - Method in class org.apache.sysds.runtime.functionobjects.NotEquals
-
- compare(double, double) - Method in class org.apache.sysds.runtime.functionobjects.ValueComparisonFunction
-
- compare(long, long) - Method in class org.apache.sysds.runtime.functionobjects.ValueComparisonFunction
-
- compare(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.ValueComparisonFunction
-
- compare(String, String) - Method in class org.apache.sysds.runtime.functionobjects.ValueComparisonFunction
-
- compare(KahanObject, KahanObject) - Static method in class org.apache.sysds.runtime.instructions.cp.KahanObject
-
- compare(GPUObject, GPUObject) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryManager.EvictionPolicyBasedComparator
-
- compare(RDDSortUtils.ValueIndexPair, RDDSortUtils.ValueIndexPair) - Method in class org.apache.sysds.runtime.instructions.spark.utils.RDDSortUtils.IndexComparator
-
- compare(RDDSortUtils.ValuesIndexPair, RDDSortUtils.ValuesIndexPair) - Method in class org.apache.sysds.runtime.instructions.spark.utils.RDDSortUtils.IndexComparator2
-
- compare(DnnParameters) - Method in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixIndexes
-
- compare(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.matrix.data.MatrixIndexes
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.sysds.runtime.matrix.data.TripleIndexes.Comparator
-
- compare(TripleIndexes, TripleIndexes) - Method in class org.apache.sysds.runtime.matrix.data.TripleIndexes.Comparator
-
- compare(double[], double[]) - Static method in class org.apache.sysds.runtime.util.SortUtils
-
- compareSize(Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
Compares the size of outputs from hop1 and hop2, in terms of number
of matrix cells.
- compareTo(CustomErrorListener.ParseIssue) - Method in class org.apache.sysds.parser.dml.CustomErrorListener.ParseIssue
-
Order by parse issues primarily by line number, and secondarily by
character position.
- compareTo(DblArrayIntListHashMap.DArrayIListEntry) - Method in class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap.DArrayIListEntry
-
- compareTo(DoubleIntListHashMap.DIListEntry) - Method in class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap.DIListEntry
-
- compareTo(FederatedRange) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
-
- compareTo(ResultMergeTaggedMatrixIndexes) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeTaggedMatrixIndexes
-
- compareTo(TensorIndexes) - Method in class org.apache.sysds.runtime.data.TensorIndexes
-
- compareTo(CM_COV_Object) - Method in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
- compareTo(Object) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- compareTo(Object) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- compareTo(MatrixCell) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- compareTo(Object) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- compareTo(MatrixIndexes) - Method in class org.apache.sysds.runtime.matrix.data.MatrixIndexes
-
- compareTo(TripleIndexes) - Method in class org.apache.sysds.runtime.matrix.data.TripleIndexes
-
- compareTo(Object) - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
-
- compareTo(Object) - Method in class org.apache.sysds.runtime.matrix.data.WeightedPair
-
- compareTo(Types.ValueType, Object, Object) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- compareVersion(String, String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
Compares two version strings of format x.y.z, where x is major,
y is minor, and z is maintenance release.
- compile(Script) - Method in class org.apache.sysds.api.mlcontext.ScriptExecutor
-
- compile(Script, boolean) - Method in class org.apache.sysds.api.mlcontext.ScriptExecutor
-
Compile a DML or PYDML script.
- compileClass(String, String) - Static method in class org.apache.sysds.runtime.codegen.CodegenUtils
-
- CompilerConfig - Class in org.apache.sysds.conf
-
Basic wrapper for all compiler configurations that are configured
dynamically on a per script invocation basis.
- CompilerConfig() - Constructor for class org.apache.sysds.conf.CompilerConfig
-
- CompilerConfig(CompilerConfig) - Constructor for class org.apache.sysds.conf.CompilerConfig
-
- CompilerConfig.ConfigType - Enum in org.apache.sysds.conf
-
- COMPLEX_DATA_TYPES - Static variable in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Complex data types supported by the MLContext API.
- COMPONENTS_DELIM - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- compRatios - Variable in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfo
-
- compress(int[], int, ABitmap, ColGroup.CompressionType, CompressionSettings, MatrixBlock) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupFactory
-
Method for compressing an ColGroup.
- compress(MatrixBlock) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
-
- compress(MatrixBlock, CompressionSettings) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
-
- compress(MatrixBlock, int) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
-
- compress(MatrixBlock, int, CompressionSettings) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
-
The main method for compressing the input matrix.
- compressColGroups(MatrixBlock, HashMap<Integer, Double>, List<int[]>, CompressionSettings, int) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupFactory
-
The actual compression method, that handles the logic of compressing multiple columns together.
- COMPRESSED_LINALG - Static variable in class org.apache.sysds.conf.DMLConfig
-
- COMPRESSED_LOSSY - Static variable in class org.apache.sysds.conf.DMLConfig
-
- COMPRESSED_VALID_COMPRESSIONS - Static variable in class org.apache.sysds.conf.DMLConfig
-
- CompressedMatrixBlock - Class in org.apache.sysds.runtime.compress
-
- CompressedMatrixBlock() - Constructor for class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
Constructor for building an empty Compressed Matrix block object.
- CompressedMatrixBlockFactory - Class in org.apache.sysds.runtime.compress
-
Factory pattern to construct a CompressedMatrixBlock.
- CompressedMatrixBlockFactory() - Constructor for class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
-
- CompressedSizeEstimator - Class in org.apache.sysds.runtime.compress.estim
-
Main abstract class for estimating size of compressions on columns.
- CompressedSizeEstimatorExact - Class in org.apache.sysds.runtime.compress.estim
-
Exact compressed size estimator (examines entire dataset).
- CompressedSizeEstimatorExact(MatrixBlock, CompressionSettings) - Constructor for class org.apache.sysds.runtime.compress.estim.CompressedSizeEstimatorExact
-
- CompressedSizeEstimatorFactory - Class in org.apache.sysds.runtime.compress.estim
-
- CompressedSizeEstimatorFactory() - Constructor for class org.apache.sysds.runtime.compress.estim.CompressedSizeEstimatorFactory
-
- CompressedSizeEstimatorSample - Class in org.apache.sysds.runtime.compress.estim
-
- CompressedSizeEstimatorSample(MatrixBlock, CompressionSettings, int) - Constructor for class org.apache.sysds.runtime.compress.estim.CompressedSizeEstimatorSample
-
CompressedSizeEstimatorSample, samples from the input data and estimates the size of the compressed matrix.
- CompressedSizeInfo - Class in org.apache.sysds.runtime.compress.estim
-
A helper reusable object for maintaining information about estimated compression
- CompressedSizeInfo(CompressedSizeInfoColGroup[], List<Integer>, List<Integer>, HashMap<Integer, Double>, int) - Constructor for class org.apache.sysds.runtime.compress.estim.CompressedSizeInfo
-
- CompressedSizeInfoColGroup - Class in org.apache.sysds.runtime.compress.estim
-
Information collected about a specific ColGroup's compression size.
- CompressedSizeInfoColGroup(EstimationFactors, Set<ColGroup.CompressionType>) - Constructor for class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
-
- Compression - Class in org.apache.sysds.lops
-
- Compression(Lop, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.Compression
-
- Compression.CompressConfig - Enum in org.apache.sysds.lops
-
- CompressionCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- CompressionFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.CompressionSPInstruction.CompressionFunction
-
- compressionInfo - Variable in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfo
-
- CompressionSettings - Class in org.apache.sysds.runtime.compress
-
Compression Settings class, used as a bundle of parameters inside the Compression framework.
- CompressionSettingsBuilder - Class in org.apache.sysds.runtime.compress
-
Builder pattern for Compression Settings.
- CompressionSettingsBuilder() - Constructor for class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
-
- CompressionSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- CompressionSPInstruction.CompressionFunction - Class in org.apache.sysds.runtime.instructions.spark
-
- CompressionStatistics - Class in org.apache.sysds.runtime.compress
-
- CompressionStatistics() - Constructor for class org.apache.sysds.runtime.compress.CompressionStatistics
-
- ComputationCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- ComputationFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
-
- ComputationSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- compute(double, double) - Method in class org.apache.sysds.runtime.util.RandNPair
-
- compute(Random) - Method in class org.apache.sysds.runtime.util.RandNPair
-
- ComputeBinaryBlockNnzFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- ComputeBinaryBlockNnzFunction(LongAccumulator) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.ComputeBinaryBlockNnzFunction
-
- computeBlockIndex(long, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
Computes the 1-based block index based on the global cell index and block size meta
data.
- computeBlockNumber(int[], long[], int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
Calculates the number of the block this index refers to (basically a linearisation).
- computeBlockSize(long, long, long) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
Computes the actual block size based on matrix dimension, block index, and block size
meta data.
- computeBlocksPerPartition(long, long, long) - Static method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBroadcast
-
- computeBlocksPerPartition(long[], int) - Static method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBroadcast
-
- computeBoundsInformation(Hop) - Method in class org.apache.sysds.hops.Hop
-
- computeBoundsInformation(Hop, LocalVariableMap) - Static method in class org.apache.sysds.hops.Hop
-
- computeBoundsInformation(Hop, LocalVariableMap, HashMap<Long, Double>) - Static method in class org.apache.sysds.hops.Hop
-
- computeCellInBlock(long, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
Computes the 0-based cell-in-block index based on the global cell index and block
size meta data.
- computeCellIndex(long, int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
Computes the global 1-based cell index based on the block index, block size meta data,
and specific 0-based in-block cell index.
- computeCompressedSizeInfos(int) - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeEstimator
-
Multi threaded version of extracting Compression Size info
- computeDataCharacteristics(JavaPairRDD<MatrixIndexes, MatrixCell>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
Utility to compute dimensions and non-zeros in a given RDD of binary cells.
- computeDataType(Expression, Expression, boolean) - Static method in class org.apache.sysds.parser.Expression
-
Compute data type based on expressions.
- computeDataType(Identifier, Identifier, boolean) - Static method in class org.apache.sysds.parser.Expression
-
Compute data type based on identifiers.
- computeDataType() - Method in class org.apache.sysds.parser.Identifier
-
- computeDedupBlock(ProgramBlock, ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageDedupUtils
-
- computeDimension(int, int, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.DiagIndex
-
- computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.DiagIndex
-
- computeDimension(int, int, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.IndexFunction
-
- computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.IndexFunction
-
- computeDimension(int, int, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.OffsetColumnIndex
-
- computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.OffsetColumnIndex
-
- computeDimension(int, int, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.ReduceAll
-
- computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.ReduceAll
-
- computeDimension(int, int, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.ReduceCol
-
- computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.ReduceCol
-
- computeDimension(int, int, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.ReduceDiag
-
- computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.ReduceDiag
-
- computeDimension(int, int, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.ReduceRow
-
- computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.ReduceRow
-
- computeDimension(int, int, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.RevIndex
-
- computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.RevIndex
-
- computeDimension(int, int, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.SortIndex
-
- computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.SortIndex
-
- computeDimension(int, int, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.SwapIndex
-
- computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.SwapIndex
-
- computeIQMCorrection(double, double, double, double, double, double) - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- computeMemEstimate(MemoTable) - Method in class org.apache.sysds.hops.AggBinaryOp
-
- computeMemEstimate(MemoTable) - Method in class org.apache.sysds.hops.FunctionOp
-
- computeMemEstimate(MemoTable) - Method in class org.apache.sysds.hops.Hop
-
Computes the estimate of memory required to store the input/output of this hop in memory.
- computeMemEstimate(MemoTable) - Method in class org.apache.sysds.hops.IndexingOp
-
- computeMemEstimate(MemoTable) - Method in class org.apache.sysds.hops.LeftIndexingOp
-
- computeMemEstimate(MemoTable) - Method in class org.apache.sysds.hops.NaryOp
-
- computeMemEstimate(MemoTable) - Method in class org.apache.sysds.hops.UnaryOp
-
- computeNextTensorIndexes(TensorCharacteristics, long[]) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
Computes the next tensor indexes array.
- computeNNZ(GPUContext, Pointer, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Utility to compute number of non-zeroes on the GPU
- computeNnz(double[], int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- computeNnz(float[], int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- computeNnz(long[], int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- computeNnz(int[], int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- computeNnz(BitSet, int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- computeNnz(String[], int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- computeNnz(SparseBlock, int[], int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- computeNNZperBlock(long, long, int, double) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDatagen
-
Deprecated.
- computeNumPaths(ProgramBlock, ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageDedupUtils
-
- computeOutputCharacteristics(long, long, long) - Method in enum org.apache.sysds.lops.WeightedDivMM.WDivMMType
-
- computeSizeInformation(Hop) - Static method in class org.apache.sysds.hops.Hop
-
- computeSizeInformation(Hop, LocalVariableMap) - Method in class org.apache.sysds.hops.Hop
-
- computeSizeInformation(Hop, LocalVariableMap, HashMap<Long, Long>) - Method in class org.apache.sysds.hops.Hop
-
- computeSliceInfo(TensorCharacteristics, long[], int[], int[]) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
Computes the slice dimensions and offsets for the block slice of another tensor with the size given by
TensorCharacteristics
.
- computeTensorIndexes(TensorCharacteristics, long) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
Computes the tensor indexes array given a blockIndex we ant to compute.
- computeValueType(Expression, Expression, boolean) - Static method in class org.apache.sysds.parser.Expression
-
Compute value type based on expressions.
- computeValueType(Identifier, Identifier, boolean) - Static method in class org.apache.sysds.parser.Expression
-
Compute value type based on identifiers.
- computeValueType(Expression, Types.ValueType, Types.ValueType, boolean) - Static method in class org.apache.sysds.parser.Expression
-
- computeZeroIndicatorVector() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
-
- concatIntIDsToLong(int, int) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.util.IDHandler
-
- concatOperandParts(String...) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- concatOperands(String...) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- concatStrings(String...) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- ConditionalPredicate - Class in org.apache.sysds.parser
-
- ConditionalPredicate(Expression) - Constructor for class org.apache.sysds.parser.ConditionalPredicate
-
- CONF_STATS - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- configFile - Variable in class org.apache.sysds.api.DMLOptions
-
- ConfigurableAPI - Interface in org.apache.sysds.api
-
This interface defines the programmatic access to dml configuration properties
(as defined in SystemDS-config.xml) to ensure API consistency across all APIs.
- ConfigurationManager - Class in org.apache.sysds.conf
-
Singleton for accessing the parsed and merged system configuration.
- ConfigurationManager() - Constructor for class org.apache.sysds.conf.ConfigurationManager
-
- Connection - Class in org.apache.sysds.api.jmlc
-
Interaction with SystemDS using the JMLC (Java Machine Learning Connector) API is initiated with
a
Connection
object.
- Connection() - Constructor for class org.apache.sysds.api.jmlc.Connection
-
Connection constructor, the starting point for any other JMLC API calls.
- Connection(CompilerConfig.ConfigType...) - Constructor for class org.apache.sysds.api.jmlc.Connection
-
Connection constructor, the starting point for any other JMLC API calls.
- Connection(DMLConfig, CompilerConfig.ConfigType...) - Constructor for class org.apache.sysds.api.jmlc.Connection
-
Connection constructor, the starting point for any other JMLC API calls.
- Connection(DMLConfig) - Constructor for class org.apache.sysds.api.jmlc.Connection
-
Connection constructor, the starting point for any other JMLC API calls.
- ConstDoubleIdExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.ConstDoubleIdExpressionContext
-
- ConstFalseExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.ConstFalseExpressionContext
-
- ConstIdentifier - Class in org.apache.sysds.parser
-
- ConstIdentifier() - Constructor for class org.apache.sysds.parser.ConstIdentifier
-
- ConstIntIdExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.ConstIntIdExpressionContext
-
- constructAndSetLopsDataFlowProperties() - Method in class org.apache.sysds.hops.Hop
-
- constructCompilerConfig(DMLConfig) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- constructCompilerConfig(CompilerConfig, DMLConfig) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- constructCplan(Hop, CPlanMemoTable, boolean) - Method in class org.apache.sysds.hops.codegen.template.TemplateBase
-
Constructs a single cplan rooted at the given hop, according
to the plan given in the memo structure for this particular
hop and its recursive inputs.
- constructCplan(Hop, CPlanMemoTable, boolean) - Method in class org.apache.sysds.hops.codegen.template.TemplateCell
-
- constructCplan(Hop, CPlanMemoTable, boolean) - Method in class org.apache.sysds.hops.codegen.template.TemplateMultiAgg
-
- constructCplan(Hop, CPlanMemoTable, boolean) - Method in class org.apache.sysds.hops.codegen.template.TemplateOuterProduct
-
- constructCplan(Hop, CPlanMemoTable, boolean) - Method in class org.apache.sysds.hops.codegen.template.TemplateRow
-
- constructDnnLops(LopProperties.ExecType, ArrayList<Hop>) - Method in class org.apache.sysds.hops.DnnOp
-
- constructFunctionKey(String, String) - Static method in class org.apache.sysds.parser.DMLProgram
-
- constructHops(DMLProgram) - Method in class org.apache.sysds.parser.DMLTranslator
-
- constructHops(DMLProgram, boolean) - Method in class org.apache.sysds.parser.DMLTranslator
-
- constructHops(StatementBlock) - Method in class org.apache.sysds.parser.DMLTranslator
-
- constructHopsForConditionalPredicate(StatementBlock) - Method in class org.apache.sysds.parser.DMLTranslator
-
- constructHopsForForControlBlock(ForStatementBlock) - Method in class org.apache.sysds.parser.DMLTranslator
-
Constructs Hops for a given ForStatementBlock or ParForStatementBlock, respectively.
- constructHopsForFunctionControlBlock(FunctionStatementBlock) - Method in class org.apache.sysds.parser.DMLTranslator
-
- constructHopsForIfControlBlock(IfStatementBlock) - Method in class org.apache.sysds.parser.DMLTranslator
-
- constructHopsForIterablePredicate(ForStatementBlock) - Method in class org.apache.sysds.parser.DMLTranslator
-
Constructs all predicate Hops (for FROM, TO, INCREMENT) of an iterable predicate
and assigns these Hops to the passed statement block.
- constructHopsForWhileControlBlock(WhileStatementBlock) - Method in class org.apache.sysds.parser.DMLTranslator
-
- constructLineageFromHops(Hop[], String, Hop[], HashMap<Long, Hop>) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
-
- constructLops() - Method in class org.apache.sysds.hops.AggBinaryOp
-
NOTE: overestimated mem in case of transpose-identity matmult, but 3/2 at worst
and existing mem estimate advantageous in terms of consistency hops/lops,
and some special cases internally materialize the transpose for better cache locality
- constructLops() - Method in class org.apache.sysds.hops.AggUnaryOp
-
- constructLops() - Method in class org.apache.sysds.hops.BinaryOp
-
- constructLops() - Method in class org.apache.sysds.hops.codegen.SpoofFusedOp
-
- constructLops() - Method in class org.apache.sysds.hops.DataGenOp
-
- constructLops() - Method in class org.apache.sysds.hops.DataOp
-
- constructLops() - Method in class org.apache.sysds.hops.DnnOp
-
- constructLops() - Method in class org.apache.sysds.hops.FunctionOp
-
- constructLops() - Method in class org.apache.sysds.hops.Hop
-
- constructLops() - Method in class org.apache.sysds.hops.IndexingOp
-
- constructLops() - Method in class org.apache.sysds.hops.LeftIndexingOp
-
- constructLops() - Method in class org.apache.sysds.hops.LiteralOp
-
- constructLops() - Method in class org.apache.sysds.hops.NaryOp
-
Construct the corresponding Lops for this Hop
- constructLops() - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- constructLops() - Method in class org.apache.sysds.hops.QuaternaryOp
-
- constructLops() - Method in class org.apache.sysds.hops.ReorgOp
-
- constructLops() - Method in class org.apache.sysds.hops.TernaryOp
-
- constructLops() - Method in class org.apache.sysds.hops.UnaryOp
-
- constructLops(DMLProgram) - Method in class org.apache.sysds.parser.DMLTranslator
-
- constructLops(StatementBlock) - Method in class org.apache.sysds.parser.DMLTranslator
-
- constructParameterMap(String[]) - Static method in class org.apache.sysds.runtime.instructions.cp.ParameterizedBuiltinCPInstruction
-
- constructParameterMap(String[]) - Static method in class org.apache.sysds.runtime.instructions.fed.ParameterizedBuiltinFEDInstruction
-
- constructParameterMap(String[]) - Static method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction
-
- constructRecodeMapEntry(String, Long) - Static method in class org.apache.sysds.runtime.transform.encode.EncoderRecode
-
Returns the Recode map entry which consists of concatenation of code, delimiter and token.
- constructSortByValueLop(Lop, SortKeys.OperationTypes, Types.DataType, Types.ValueType, LopProperties.ExecType) - Static method in class org.apache.sysds.lops.SortKeys
-
- constructSortByValueLop(Lop, Lop, SortKeys.OperationTypes, Types.DataType, Types.ValueType, LopProperties.ExecType) - Static method in class org.apache.sysds.lops.SortKeys
-
- constructSPAppendLop(Hop, Hop, Types.DataType, Types.ValueType, boolean, Hop) - Static method in class org.apache.sysds.hops.BinaryOp
-
- ConstStringIdExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.ConstStringIdExpressionContext
-
- ConstTrueExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.ConstTrueExpressionContext
-
- contains(String, boolean, boolean) - Static method in enum org.apache.sysds.common.Builtins
-
- contains(String) - Static method in enum org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
-
- contains(String) - Static method in enum org.apache.sysds.hops.codegen.cplan.CNodeNary.NaryType
-
- contains(String) - Static method in enum org.apache.sysds.hops.codegen.cplan.CNodeTernary.TernaryType
-
- contains(String) - Static method in enum org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
-
- contains(long) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- contains(long, TemplateBase.TemplateType) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- contains(long, CPlanMemoTable.MemoTableEntry, TemplateBase.TemplateType) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- contains(long, boolean, TemplateBase.TemplateType...) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- contains(String) - Static method in enum org.apache.sysds.parser.BuiltinConstant
-
- contains(Collection<ParForStatementBlock.ResultVar>, String) - Static method in class org.apache.sysds.parser.ParForStatementBlock.ResultVar
-
- contains(CPOperand) - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- contains(CPOperand) - Method in class org.apache.sysds.runtime.lineage.LineageMap
-
- contains(long[]) - Method in class org.apache.sysds.runtime.privacy.finegrained.DataRange
-
Returns true if the given index is in the data range.
- containsAny(Collection<T>, Collection<T>) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
-
- containsAnyName(Set<String>) - Method in class org.apache.sysds.parser.VariableSet
-
- containsAtLeastOneFunction(ProgramBlock) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.ProgramRecompiler
-
- containsBinary(CNode, CNodeBinary.BinType) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- containsFunction(String) - Method in class org.apache.sysds.parser.FunctionDictionary
-
- containsFunction(String, boolean) - Method in class org.apache.sysds.parser.FunctionDictionary
-
- containsFunctionCallInstruction(BasicProgramBlock) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
-
- containsFunctionProgramBlock(String, String) - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- containsFunctionProgramBlock(String, boolean) - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- containsFunctionProgramBlock(String, String, boolean) - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- containsHop(Hop) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- containsID() - Method in class org.apache.sysds.runtime.instructions.spark.data.DatasetObject
-
- containsInput(Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- containsKey(String) - Method in class org.apache.sysds.runtime.lineage.LineageMap
-
- containsNotIn(long, Collection<TemplateBase.TemplateType>, boolean) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- containsOmitSpec(String, String[]) - Static method in class org.apache.sysds.runtime.transform.meta.TfMetaUtils
-
- containsOp(ArrayList<Hop>, Class<? extends Hop>) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- containsOuterProduct(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- containsOuterProduct(Hop, Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- containsOutput(String) - Method in class org.apache.sysds.hops.FunctionOp
-
- containsRandDataGen(HashSet<LineageItem>, LineageItem) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
-
- containsSecondOrderBuiltin(ArrayList<Hop>) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- containsSecondOrderCall() - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Indicates if the function call graph, i.e., functions that are transitively
reachable from the main program, contains a second-order builtin function call
(e.g., eval, paramserv), which prohibits the removal of unused functions.
- containsSeq() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- containsSeq() - Method in class org.apache.sysds.runtime.codegen.SpoofCellwise
-
- containsSparkInstruction(BasicProgramBlock, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
-
- containsSparkInstruction(ArrayList<Instruction>, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
-
- containsTopLevel(long) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- containsTransposeOperation(ArrayList<Hop>) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- containsValue(double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- containsVariable(String) - Method in class org.apache.sysds.parser.VariableSet
-
- containsVariable(CPOperand) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- containsVariable(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- containsVars(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.CachedReuseVariables
-
- containsZero() - Method in class org.apache.sysds.runtime.compress.utils.ABitmap
-
- containsZero(double[], int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- controlStatement() - Method in class org.apache.sysds.parser.AssignmentStatement
-
- controlStatement() - Method in class org.apache.sysds.parser.ForStatement
-
- controlStatement() - Method in class org.apache.sysds.parser.FunctionStatement
-
- controlStatement() - Method in class org.apache.sysds.parser.IfStatement
-
- controlStatement() - Method in class org.apache.sysds.parser.ImportStatement
-
- controlStatement() - Method in class org.apache.sysds.parser.MultiAssignmentStatement
-
- controlStatement() - Method in class org.apache.sysds.parser.OutputStatement
-
- controlStatement() - Method in class org.apache.sysds.parser.PathStatement
-
- controlStatement() - Method in class org.apache.sysds.parser.PrintStatement
-
- controlStatement() - Method in class org.apache.sysds.parser.Statement
-
- controlStatement() - Method in class org.apache.sysds.parser.WhileStatement
-
- conv2d(GPUContext, String, MatrixObject, MatrixObject, MatrixObject, int, int, int, int, int, int, int, int, int, int, int, int, int, double) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNN
-
Performs a 2D convolution
- conv2d(MatrixBlock, MatrixBlock, MatrixBlock, DnnParameters) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNN
-
This method performs convolution (i.e.
- conv2d(MatrixBlock, MatrixBlock, MatrixBlock, DnnParameters) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixNative
-
This method performs convolution (i.e.
- conv2dBackwardData(GPUContext, String, MatrixObject, MatrixObject, MatrixObject, int, int, int, int, int, int, int, int, int, int, int, int, int, double) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNN
-
This method computes the backpropogation errors for previous layer of convolution operation
- conv2dBackwardData(MatrixBlock, MatrixBlock, MatrixBlock, DnnParameters) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNN
-
This method computes the backpropogation errors for previous layer of convolution operation
- conv2dBackwardData(MatrixBlock, MatrixBlock, MatrixBlock, DnnParameters) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixNative
-
This method computes the backpropagation errors for previous layer of convolution operation
- conv2dBackwardDataDense(double[], double[], double[], int, int, int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysds.utils.NativeHelper
-
- conv2dBackwardFilter(GPUContext, String, MatrixObject, MatrixObject, MatrixObject, int, int, int, int, int, int, int, int, int, int, int, int, int, double) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNN
-
This method computes the backpropogation errors for filter of convolution operation
- conv2dBackwardFilter(MatrixBlock, MatrixBlock, MatrixBlock, DnnParameters) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNN
-
This method computes the backpropogation errors for filter of convolution operation
- conv2dBackwardFilter(MatrixBlock, MatrixBlock, MatrixBlock, DnnParameters) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixNative
-
This method computes the backpropogation errors for filter of convolution operation
- conv2dBackwardFilterDense(double[], double[], double[], int, int, int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysds.utils.NativeHelper
-
- conv2dBackwardFilterSparseDense(int, int, int[], double[], double[], double[], int, int, int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysds.utils.NativeHelper
-
- conv2dBiasAdd(GPUContext, String, MatrixObject, MatrixObject, MatrixObject, MatrixObject, int, int, int, int, int, int, int, int, int, int, int, int, int, double) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNN
-
Does a 2D convolution followed by a bias_add
- conv2dDense(double[], double[], double[], int, int, int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysds.utils.NativeHelper
-
- conv2dSparse(int, int, int[], double[], double[], double[], int, int, int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysds.utils.NativeHelper
-
- convert(MatrixIndexes, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.BinaryBlockToTextCellConverter
-
Before calling convert, please make sure to setBlockSize(blen, blen);
- convert(K1, V1) - Method in interface org.apache.sysds.runtime.matrix.data.Converter
-
- convert(LongWritable, Text) - Method in class org.apache.sysds.runtime.matrix.data.TextToBinaryCellConverter
-
- CONVERT_MCSR_TO_CSR_ON_DEEP_SERIALIZE - Static variable in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- convertDFSchemaToFrameSchema(StructType, String[], Types.ValueType[], boolean) - Static method in class org.apache.sysds.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.
- ConvertedDMLSyntax(String, String, ArrayList<ParameterExpression>) - Constructor for class org.apache.sysds.parser.dml.DmlSyntacticValidator.ConvertedDMLSyntax
-
- 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.sysds.runtime.matrix.data
-
- convertFormatType(String) - Static method in class org.apache.sysds.parser.Expression
-
Convert string format type to Hop.FileFormatTypes
.
- ConvertFrameBlockToIJVLines - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- ConvertFrameBlockToIJVLines() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.ConvertFrameBlockToIJVLines
-
- convertFrameSchemaToDFSchema(Types.ValueType[], boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
This function will convert Frame schema into DataFrame schema
- convertInputParametersForParser(Map<String, Object>) - Static method in class org.apache.sysds.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.sysds.api.mlcontext.MLContextUtil
-
Convert input types to internal SystemDS representations
- convertInputType(String, Object, Metadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Convert input types to internal SystemDS representations
- ConvertMatrixBlockToIJVLines - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- ConvertMatrixBlockToIJVLines(int) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.ConvertMatrixBlockToIJVLines
-
- convertMBtoPy4JDenseArr(MatrixBlock) - Static method in class org.apache.sysds.runtime.util.Py4jConverterUtils
-
- convertPy4JArrayToMB(byte[], int, int) - Static method in class org.apache.sysds.runtime.util.Py4jConverterUtils
-
- convertPy4JArrayToMB(byte[], int, int, Types.ValueType) - Static method in class org.apache.sysds.runtime.util.Py4jConverterUtils
-
- convertPy4JArrayToMB(byte[], int, int, boolean, Types.ValueType) - Static method in class org.apache.sysds.runtime.util.Py4jConverterUtils
-
- convertSciPyCOOToMB(byte[], byte[], byte[], int, int, int) - Static method in class org.apache.sysds.runtime.util.Py4jConverterUtils
-
- ConvertStringToLongTextPair - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- ConvertStringToLongTextPair() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.ConvertStringToLongTextPair
-
- convertToArray2DRowRealMatrix(MatrixBlock) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
Helper method that converts SystemDS matrix variable (varname
) into a Array2DRowRealMatrix format,
which is useful in invoking Apache CommonsMath.
- convertToBlockRealMatrix(MatrixBlock) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- convertToBooleanVector(MatrixBlock) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- convertToDenseBlock(MatrixBlock) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- convertToDenseBlock(MatrixBlock, boolean) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- convertToDMLSyntax(ParserRuleContext, String, String, ArrayList<ParameterExpression>, Token) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- convertToDoubleList(MatrixBlock) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- convertToDoubleMatrix(String, String) - Method in class org.apache.sysds.api.jmlc.Connection
-
Converts an input string representation of a matrix in csv or textcell format
into a dense double array.
- convertToDoubleMatrix(String, int, int) - Method in class org.apache.sysds.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.sysds.api.jmlc.Connection
-
Converts an input stream of a string matrix in textcell format
into a dense double array.
- convertToDoubleMatrix(InputStream, int, int, String) - Method in class org.apache.sysds.api.jmlc.Connection
-
Converts an input stream of a string matrix in csv or textcell format
into a dense double array.
- convertToDoubleMatrix(MatrixBlock) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
Creates a two-dimensional double matrix of the input matrix block.
- convertToDoubleVector(MatrixBlock) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- convertToDoubleVector(MatrixBlock, boolean) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- convertToDoubleVector(MatrixBlock, boolean, boolean) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- convertToFrame(String, String) - Method in class org.apache.sysds.api.jmlc.Connection
-
Converts an input string representation of a frame in csv or textcell format
into a frame block.
- convertToFrame(InputStream, String) - Method in class org.apache.sysds.api.jmlc.Connection
-
Converts an input stream of a string frame in csv or textcell format
into a frame block.
- convertToFrame(String, int, int) - Method in class org.apache.sysds.api.jmlc.Connection
-
Converts an input string representation of a frame in textcell format
into a frame block.
- convertToFrame(InputStream, int, int) - Method in class org.apache.sysds.api.jmlc.Connection
-
Converts an input stream of a string frame in textcell format
into a frame block.
- convertToFrame(InputStream, int, int, String) - Method in class org.apache.sysds.api.jmlc.Connection
-
Converts an input stream of a frame in csv or textcell format
into a frame block.
- convertToFrameBlock(String[][]) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
Converts a two dimensions string array into a frame block of
value type string.
- convertToFrameBlock(String[][], Types.ValueType[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- convertToFrameBlock(String[][], Types.ValueType[], String[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- convertToFrameBlock(MatrixBlock) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
Converts a matrix block into a frame block of value type double.
- convertToFrameBlock(MatrixBlock, Types.ValueType) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
Converts a matrix block into a frame block of a given value type.
- convertToFrameBlock(MatrixBlock, Types.ValueType[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- convertToIntVector(MatrixBlock) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- convertToLongVector(MatrixBlock) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- convertToMatrix(String, String) - Method in class org.apache.sysds.api.jmlc.Connection
-
Converts an input string representation of a matrix in csv or textcell format
into a matrix block.
- convertToMatrix(InputStream, String) - Method in class org.apache.sysds.api.jmlc.Connection
-
Converts an input stream of a string matrix in csv or textcell format
into a matrix block.
- convertToMatrix(String, int, int) - Method in class org.apache.sysds.api.jmlc.Connection
-
Converts an input string representation of a matrix in textcell format
into a matrix block.
- convertToMatrix(InputStream, int, int) - Method in class org.apache.sysds.api.jmlc.Connection
-
Converts an input stream of a string matrix in text format
into a matrix block.
- convertToMatrix(InputStream, int, int, String) - Method in class org.apache.sysds.api.jmlc.Connection
-
Converts an input stream of a string matrix in csv or text format
into a matrix block.
- convertToMatrixBlock(double[][]) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
Creates a dense Matrix Block and copies the given double matrix into it.
- convertToMatrixBlock(int[][]) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
Converts an Integer matrix to an MatrixBlock
- convertToMatrixBlock(double[], boolean) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
Creates a dense Matrix Block and copies the given double vector into it.
- convertToMatrixBlock(HashMap<MatrixIndexes, Double>) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- convertToMatrixBlock(HashMap<MatrixIndexes, Double>, int, int) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
NOTE: this method also ensures the specified matrix dimensions
- convertToMatrixBlock(CTableMap) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- convertToMatrixBlock(CTableMap, int, int) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
NOTE: this method also ensures the specified matrix dimensions
- convertToMatrixBlock(FrameBlock) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
Converts a frame block with arbitrary schema into a matrix block.
- convertToMatrixBlock(RealMatrix) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- convertToMatrixBlockPartitions(MatrixBlock, boolean) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- convertToStringFrame(String, String) - Method in class org.apache.sysds.api.jmlc.Connection
-
Converts an input string representation of a frame in csv or textcell format
into a dense string array.
- convertToStringFrame(String, int, int) - Method in class org.apache.sysds.api.jmlc.Connection
-
Converts an input stream of a string frame in textcell format
into a dense string array.
- convertToStringFrame(InputStream, int, int) - Method in class org.apache.sysds.api.jmlc.Connection
-
Converts an input stream of a string frame in textcell format
into a dense string array.
- convertToStringFrame(InputStream, int, int, String) - Method in class org.apache.sysds.api.jmlc.Connection
-
Converts an input stream of a string frame in csv or text format
into a dense string array.
- convertToStringFrame(FrameBlock) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
Converts a frame block with arbitrary schema into a two dimensional
string array.
- convertToTensorBlock(MatrixBlock, Types.ValueType, boolean) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- coordinateMatrixToBinaryBlock(JavaSparkContext, CoordinateMatrix, DataCharacteristics, boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- coordinateMatrixToBinaryBlock(SparkContext, CoordinateMatrix, DataCharacteristics, boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- copy(BasicTensorBlock) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- copy(int[], int[], BasicTensorBlock) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
Copy a part of another BasicTensorBlock
- copy(DataTensorBlock) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- copy(int[], int[], DataTensorBlock) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
Copy a part of another DataTensorBlock
- copy(SparseRow) - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- copy(TensorBlock) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- copy(int[], int[], TensorBlock) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
Copy a part of another TensorBlock
- copy() - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- copy(MatrixValue, boolean) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- copy(MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- copy(FrameBlock) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- copy(int, int, int, int, FrameBlock) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- copy(MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- copy(MatrixValue, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- copy(int, int, int, int, MatrixBlock, boolean) - Method in class org.apache.sysds.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.sysds.runtime.matrix.data.MatrixCell
-
- copy(MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- copy(MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- copy(MatrixValue, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- copy(MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
-
- copy(MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.WeightedPair
-
- copyBinaryBlockMatrix(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysds.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.sysds.runtime.instructions.spark.utils.SparkUtils
-
Creates a partitioning-preserving copy of the input matrix RDD.
- copyBinaryBlockTensor(JavaPairRDD<TensorIndexes, BasicTensorBlock>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
Creates a partitioning-preserving deep copy of the input tensor RDD, where
the indexes and values are copied.
- copyBinaryBlockTensor(JavaPairRDD<TensorIndexes, BasicTensorBlock>, boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
Creates a partitioning-preserving copy of the input tensor RDD.
- CopyBinaryCellFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- CopyBinaryCellFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.CopyBinaryCellFunction
-
- copyColGroup(ColGroup) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConverter
-
Copy col group instance with deep copy of column indices but shallow copy of actual contents;
- copyDataGenOp(DataGenOp, double, double) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
Assumes that min and max are literal ops, needs to be checked from outside.
- copyExact(int[], int[], TensorBlock) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
Copy a part of another TensorBlock
.
- copyExecutionContext(ExecutionContext, int) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
- copyFileOnHDFS(String, String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- CopyFrameBlockFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
General purpose copy function for binary block rdds.
- CopyFrameBlockFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.CopyFrameBlockFunction
-
- CopyFrameBlockFunction(boolean) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.CopyFrameBlockFunction
-
- CopyFrameBlockPairFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
General purpose copy function for binary block rdds.
- CopyFrameBlockPairFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.CopyFrameBlockPairFunction
-
- CopyFrameBlockPairFunction(boolean) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.CopyFrameBlockPairFunction
-
- copyFrom(DmlParser.DataIdentifierContext) - Method in class org.apache.sysds.parser.dml.DmlParser.DataIdentifierContext
-
- copyFrom(DmlParser.DataTypeContext) - Method in class org.apache.sysds.parser.dml.DmlParser.DataTypeContext
-
- copyFrom(DmlParser.ExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlParser.ExpressionContext
-
- copyFrom(DmlParser.FunctionStatementContext) - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionStatementContext
-
- copyFrom(DmlParser.IterablePredicateContext) - Method in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateContext
-
- copyFrom(DmlParser.StatementContext) - Method in class org.apache.sysds.parser.dml.DmlParser.StatementContext
-
- copyLineNumbers(Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- copyLineNumbers(MatrixBlock, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- copyLineNumbers(MatrixObject, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- copyList(ListObject, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
Deep copy the list object
- CopyMatrixBlockFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
General purpose copy function for binary block rdds.
- CopyMatrixBlockFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.CopyMatrixBlockFunction
-
- CopyMatrixBlockFunction(boolean) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.CopyMatrixBlockFunction
-
- CopyMatrixBlockPairFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
General purpose copy function for binary block rdds.
- CopyMatrixBlockPairFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.CopyMatrixBlockPairFunction
-
- CopyMatrixBlockPairFunction(boolean) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.CopyMatrixBlockPairFunction
-
- copyNonZerosToUpperTriangle(MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysds.runtime.compress.utils.LinearAlgebraUtils
-
- copyOf(Types.ValueType[], Types.ValueType[]) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- copyOriginalFunctions() - Method in class org.apache.sysds.parser.DMLProgram
-
- copyOriginalFunctions() - Method in class org.apache.sysds.parser.FunctionDictionary
-
- copyPtrToHost(CSRPointer, int, long, int[], int[]) - Static method in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
Static method to copy a CSR sparse matrix from Device to host
- copyRowBlocks(MatrixBlock, int, MatrixBlock, int, int, int) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- copyRowBlocks(MatrixBlock, long, MatrixBlock, int, int, int) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- copyRowBlocks(MatrixBlock, int, MatrixBlock, long, long, long) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- copyRowBlocks(MatrixBlock, long, MatrixBlock, long, long, long) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- copySettings(CompressionSettings) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
-
Copy the settings from another CompressionSettings Builder, modifies this, not that.
- copyShallow(BasicTensorBlock) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- copyShallow(MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- copySparseBlock(SparseBlock.Type, SparseBlock, boolean) - Static method in class org.apache.sysds.runtime.data.SparseBlockFactory
-
- CopyTensorBlockFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
General purpose copy function for binary block rdds.
- CopyTensorBlockFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.CopyTensorBlockFunction
-
- CopyTensorBlockFunction(boolean) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.CopyTensorBlockFunction
-
- CopyTensorBlockPairFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
General purpose copy function for binary block rdds.
- CopyTensorBlockPairFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.CopyTensorBlockPairFunction
-
- CopyTensorBlockPairFunction(boolean) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.CopyTensorBlockPairFunction
-
- CopyTextInputFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- CopyTextInputFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.CopyTextInputFunction
-
- copyToDevice(GPUContext, CSRPointer, int, long, int[], int[], double[]) - Static method in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
Static method to copy a CSR sparse matrix from Host to Device
- copyToDoubleVector(MatrixBlock, double[], int) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- copyUpperToLowerTriangle(MatrixBlock) - Static method in class org.apache.sysds.runtime.compress.utils.LinearAlgebraUtils
-
- copyUpperToLowerTriangle(MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
Used for all version of TSMM where the result is known to be symmetric.
- copyWithNewID(long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
-
Make a copy of the FederatedData
metadata, but use another varID (refer to another object on worker)
- copyWithNewID(long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedLocalData
-
- copyWithNewID() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- copyWithNewID(long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- copyWithNewID(long, long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- corePropagation(PrivacyConstraint.PrivacyLevel[], OperatorType) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
Returns the output privacy level based on the given input privacy levels and operator type.
- correction - Variable in class org.apache.sysds.runtime.matrix.operators.AggregateOperator
-
- CorrMatrixBlock - Class in org.apache.sysds.runtime.instructions.spark.data
-
- CorrMatrixBlock() - Constructor for class org.apache.sysds.runtime.instructions.spark.data.CorrMatrixBlock
-
- CorrMatrixBlock(MatrixBlock) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.CorrMatrixBlock
-
- CorrMatrixBlock(MatrixBlock, MatrixBlock) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.CorrMatrixBlock
-
- cos(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs an "cos" operation on a matrix on the GPU
- cosh(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs an "cosh" operation on a matrix on the GPU
- COST_MIN_EPS - Static variable in class org.apache.sysds.hops.codegen.opt.PlanSelectionFuseCostBasedV2
-
- COST_MIN_EPS_NUM_POINTS - Static variable in class org.apache.sysds.hops.codegen.opt.PlanSelectionFuseCostBasedV2
-
- COST_PRUNING - Static variable in class org.apache.sysds.hops.codegen.opt.PlanSelectionFuseCostBasedV2
-
- CostEstimationWrapper - Class in org.apache.sysds.hops.cost
-
- CostEstimationWrapper() - Constructor for class org.apache.sysds.hops.cost.CostEstimationWrapper
-
- CostEstimationWrapper.CostType - Enum in org.apache.sysds.hops.cost
-
- CostEstimator - Class in org.apache.sysds.hops.cost
-
- CostEstimator() - Constructor for class org.apache.sysds.hops.cost.CostEstimator
-
- CostEstimator - Class in org.apache.sysds.runtime.controlprogram.parfor.opt
-
Base class for all potential cost estimators
TODO account for shared read-only matrices when computing aggregated stats
- CostEstimator() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator
-
- CostEstimator.DataFormat - Enum in org.apache.sysds.runtime.controlprogram.parfor.opt
-
- CostEstimator.ExcludeType - Enum in org.apache.sysds.runtime.controlprogram.parfor.opt
-
- CostEstimator.TestMeasure - Enum in org.apache.sysds.runtime.controlprogram.parfor.opt
-
- CostEstimatorHops - Class in org.apache.sysds.runtime.controlprogram.parfor.opt
-
- CostEstimatorHops(OptTreePlanMappingAbstract) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimatorHops
-
- CostEstimatorRuntime - Class in org.apache.sysds.runtime.controlprogram.parfor.opt
-
Cost estimator for runtime programs.
- CostEstimatorRuntime(OptTreePlanMappingAbstract, LocalVariableMap) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimatorRuntime
-
- CostEstimatorStaticRuntime - Class in org.apache.sysds.hops.cost
-
- CostEstimatorStaticRuntime() - Constructor for class org.apache.sysds.hops.cost.CostEstimatorStaticRuntime
-
- countAgg(double[], int[], int[], int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
-
- countAgg(double[], int[], int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
-
- CountDistinctOperator - Class in org.apache.sysds.runtime.matrix.operators
-
- CountDistinctOperator(AggregateUnaryCPInstruction.AUType) - Constructor for class org.apache.sysds.runtime.matrix.operators.CountDistinctOperator
-
- CountDistinctOperator(CountDistinctOperator.CountDistinctTypes) - Constructor for class org.apache.sysds.runtime.matrix.operators.CountDistinctOperator
-
- CountDistinctOperator(CountDistinctOperator.CountDistinctTypes, Hash.HashType) - Constructor for class org.apache.sysds.runtime.matrix.operators.CountDistinctOperator
-
- CountDistinctOperator.CountDistinctTypes - Enum in org.apache.sysds.runtime.matrix.operators
-
- countDistributedOperations(Program) - Static method in class org.apache.sysds.utils.Explain
-
Counts the number of compiled MRJob/Spark instructions in the
given runtime program.
- countEntries(long) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- countEntries(long, TemplateBase.TemplateType) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- countNnz(String[]) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
Returns the number of non-zero entries but avoids the expensive
string to double parsing.
- countNnz(String[], int, int) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
Returns the number of non-zero entries but avoids the expensive
string to double parsing.
- CountNnzTask(InputSplit, TextInputFormat, JobConf, int[], boolean) - Constructor for class org.apache.sysds.runtime.io.ReaderTextCellParallel.CountNnzTask
-
- countNonZeros() - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Compute the number of non-zero values, which potentially
makes a full pass over the underlying blocks.
- countNonZeros(int) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Compute the number of non-zero values for the given row,
which potentially makes a full pass over the underlying row.
- countNonZeros(int, int, int, int) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Compute the number of non-zero values, which potentially
makes a full pass over the underlying blocks in the row range.
- countNonZeros() - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
-
- countNonZeros(int) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
-
- countNonZeros(int, int, int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
-
- countNonZeros() - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
-
- countNonZeros(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
-
- countNonZeros(int, int, int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
-
- countNonZeros(double[], int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- countNonZerosPerRow(int[], int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Count the number of non-zeros per row
- countNonZerosPerRow(int[], int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
-
- countNonZerosPerRow(int[], int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
- countNonZerosPerRow(int[], int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
-
- countNonZerosPerRow(int[], int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- countNonZerosPerRow(int, int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- countNumColumnsCSV(InputSplit[], InputFormat, JobConf, String) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
Counts the number of columns in a given collection of csv file splits.
- countPinnedData() - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
-
- countPlanRefs() - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- CountRowsTask(InputSplit, TextInputFormat, JobConf) - Constructor for class org.apache.sysds.runtime.io.IOUtilFunctions.CountRowsTask
-
- CountRowsTask(InputSplit, TextInputFormat, JobConf, boolean) - Constructor for class org.apache.sysds.runtime.io.IOUtilFunctions.CountRowsTask
-
- countTokensCSV(String, String) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
Counts the number of tokens defined by the given delimiter, respecting
the rules for quotes and escapes defined in RFC4180,
with robustness for various special cases.
- countVectorIntermediates(CNode) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- COV - Class in org.apache.sysds.runtime.functionobjects
-
GENERAL NOTE:
* 05/28/2014: We decided to do handle weights consistently to SPSS in an operation-specific manner,
i.e., we (1) round instead of casting where required (e.g.
- CoVariance - Class in org.apache.sysds.lops
-
Lop to compute covariance between two 1D matrices
- CoVariance(Lop, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.CoVariance
-
- CoVariance(Lop, Lop, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.CoVariance
-
- CoVariance(Lop, Lop, Lop, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.CoVariance
-
- CovarianceCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- CovarianceSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- covOperations(COVOperator, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- covOperations(COVOperator, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- covOperations(COVOperator, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- covOperations(COVOperator, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- COVOperator - Class in org.apache.sysds.runtime.matrix.operators
-
- COVOperator(COV) - Constructor for class org.apache.sysds.runtime.matrix.operators.COVOperator
-
- CP_CHILD_THREAD - Static variable in class org.apache.sysds.lops.Lop
-
- CP_PARALLEL_IO - Static variable in class org.apache.sysds.conf.DMLConfig
-
- CP_PARALLEL_OPS - Static variable in class org.apache.sysds.conf.DMLConfig
-
- CP_ROOT_THREAD_ID - Static variable in class org.apache.sysds.lops.Lop
-
- CPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- CPInstruction.CPType - Enum in org.apache.sysds.runtime.instructions.cp
-
- CPInstructionParser - Class in org.apache.sysds.runtime.instructions
-
- CPInstructionParser() - Constructor for class org.apache.sysds.runtime.instructions.CPInstructionParser
-
- CPlanCSERewriter - Class in org.apache.sysds.hops.codegen.template
-
- CPlanCSERewriter() - Constructor for class org.apache.sysds.hops.codegen.template.CPlanCSERewriter
-
- CPlanMemoTable - Class in org.apache.sysds.hops.codegen.template
-
- CPlanMemoTable() - Constructor for class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- CPlanMemoTable.MemoTableEntry - Class in org.apache.sysds.hops.codegen.template
-
- CPlanMemoTable.MemoTableEntrySet - Class in org.apache.sysds.hops.codegen.template
-
- CPlanOpRewriter - Class in org.apache.sysds.hops.codegen.template
-
This cplan rewriter is meant to be the central place for any cplan
enhancements before code generation.
- CPlanOpRewriter() - Constructor for class org.apache.sysds.hops.codegen.template.CPlanOpRewriter
-
- CpmmSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
Cpmm: cross-product matrix multiplication operation (distributed matrix multiply
by join over common dimension and subsequent aggregation of partial results).
- CPOperand - Class in org.apache.sysds.runtime.instructions.cp
-
- CPOperand() - Constructor for class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- CPOperand(String) - Constructor for class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- CPOperand(String, Types.ValueType, Types.DataType) - Constructor for class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- CPOperand(String, Types.ValueType, Types.DataType, boolean) - Constructor for class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- CPOperand(ScalarObject) - Constructor for class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- CPOperand(CPOperand) - Constructor for class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- CPOperand(String, Data) - Constructor for class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- CPThreshold - Static variable in class org.apache.sysds.hops.Hop
-
- create() - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
-
Create the CompressionSettings object to use in the compression.
- create(ListObject, String, Statement.PSUpdateType, ExecutionContext, int) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.LocalParamServer
-
- CREATE_UNSCOPED_RESULTVARS - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- createAbstractOptNodes(ArrayList<Hop>, LocalVariableMap, Set<String>) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
-
- createAbstractOptTree(int, double, ParForStatementBlock, ParForProgramBlock, Set<String>, ExecutionContext) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
-
- createAggUnaryOp(Hop, String) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createAggUnaryOp(Hop, Types.AggOp, Types.Direction) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createBinary(Hop, Hop, String) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createBinary(Hop, Hop, Types.OpOp2) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createBinary(Hop, Hop, Types.OpOp2, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createBinaryMinus(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createBitset(int, int) - Static method in class org.apache.sysds.hops.estim.EstimatorBitsetMM
-
- createBitset(MatrixBlock) - Static method in class org.apache.sysds.hops.estim.EstimatorBitsetMM
-
- createCacheableData(CacheBlock) - Static method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- createCNodeData(Hop, boolean) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- createColName(int) - Static method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- createColNames(int) - Static method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- createColNames(int, int) - Static method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- createCompatibleTemplates(TemplateBase.TemplateType, TemplateBase.CloseType) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- createComputeNnz(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createContext() - Static method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContextFactory
-
- createContext(Program) - Static method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContextFactory
-
- createContext(LocalVariableMap, Program) - Static method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContextFactory
-
- createContext(boolean, Program) - Static method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContextFactory
-
- createContext(boolean, boolean, Program) - Static method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContextFactory
-
- createCutVarName(boolean) - Static method in class org.apache.sysds.hops.rewrite.StatementBlockRewriteRule
-
- createDataGenOp(Hop, double) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createDataGenOp(Hop, Hop, double) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createDataGenOp(Hop, boolean, Hop, boolean, double) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createDataGenOpByVal(Hop, Hop, Hop, Types.DataType, Types.ValueType, double) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createDataGenOpByVal(ArrayList<LiteralOp>, long, long) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createDataOp(String, Hop, Types.OpOpData) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createDecoder(String, String[], Types.ValueType[], FrameBlock) - Static method in class org.apache.sysds.runtime.transform.decode.DecoderFactory
-
- createDecoder(String, String[], Types.ValueType[], FrameBlock, int) - Static method in class org.apache.sysds.runtime.transform.decode.DecoderFactory
-
- createDecoder(String, String[], Types.ValueType[], FrameBlock, int, int) - Static method in class org.apache.sysds.runtime.transform.decode.DecoderFactory
-
- createDecoder(String, String[], Types.ValueType[], FrameBlock, int, int, int) - Static method in class org.apache.sysds.runtime.transform.decode.DecoderFactory
-
- createDedupPatch(ProgramBlock, ExecutionContext) - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- createDeepCopyExecutionContext(ExecutionContext) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
Creates a deep copy of the given execution context.
- createDeepCopyForProgramBlock(ForProgramBlock, long, int, Program, Set<String>, Set<String>, boolean, boolean) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- createDeepCopyFunctionProgramBlock(String, String, long, int, Program, Set<String>, Set<String>, boolean) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
This creates a deep copy of a function program block.
- createDeepCopyFunctionProgramBlock(FunctionProgramBlock, Set<String>, Set<String>) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- createDeepCopyFunctionStatementBlock(FunctionStatementBlock, Set<String>, Set<String>) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- createDeepCopyIfProgramBlock(IfProgramBlock, long, int, Program, Set<String>, Set<String>, boolean, boolean) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- createDeepCopyInstructionSet(ArrayList<Instruction>, long, int, Program, Set<String>, Set<String>, boolean, boolean) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
Creates a deep copy of an array of instructions and replaces the placeholders of parworker
IDs with the concrete IDs of this parfor instance.
- createDeepCopyParForProgramBlock(ParForProgramBlock, long, int, Program, Set<String>, Set<String>, boolean, boolean) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- createDeepCopyWhileProgramBlock(WhileProgramBlock, long, int, Program, Set<String>, Set<String>, boolean, boolean) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- createDenseBlock(int, int) - Static method in class org.apache.sysds.runtime.data.DenseBlockFactory
-
- createDenseBlock(int[]) - Static method in class org.apache.sysds.runtime.data.DenseBlockFactory
-
- createDenseBlock(Types.ValueType, int[]) - Static method in class org.apache.sysds.runtime.data.DenseBlockFactory
-
- createDenseBlock(BitSet, int[]) - Static method in class org.apache.sysds.runtime.data.DenseBlockFactory
-
- createDenseBlock(String[], int[]) - Static method in class org.apache.sysds.runtime.data.DenseBlockFactory
-
- createDenseBlock(double[], int[]) - Static method in class org.apache.sysds.runtime.data.DenseBlockFactory
-
- createDenseBlock(float[], int[]) - Static method in class org.apache.sysds.runtime.data.DenseBlockFactory
-
- createDenseBlock(long[], int[]) - Static method in class org.apache.sysds.runtime.data.DenseBlockFactory
-
- createDenseBlock(int[], int[]) - Static method in class org.apache.sysds.runtime.data.DenseBlockFactory
-
- createDenseBlock(double[], int, int) - Static method in class org.apache.sysds.runtime.data.DenseBlockFactory
-
- createDenseBlock(float[], int, int) - Static method in class org.apache.sysds.runtime.data.DenseBlockFactory
-
- createDenseBlock(Types.ValueType, DenseBlock.Type, int[]) - Static method in class org.apache.sysds.runtime.data.DenseBlockFactory
-
- createDirIfNotExistOnHDFS(String, String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- createDirIfNotExistOnHDFS(Path, String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- createDistributedUniqueID() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.util.IDHandler
-
Creates a unique identifier with the pattern <process_id>_<host_ip>.
- CREATEDPARAM - Static variable in class org.apache.sysds.parser.DataExpression
-
- createdSparkContext() - Static method in class org.apache.sysds.utils.Statistics
-
- createEncoder(String, String[], int, FrameBlock) - Static method in class org.apache.sysds.runtime.transform.encode.EncoderFactory
-
- createEncoder(String, String[], int, FrameBlock, int, int) - Static method in class org.apache.sysds.runtime.transform.encode.EncoderFactory
-
- createEncoder(String, String[], Types.ValueType[], int, FrameBlock) - Static method in class org.apache.sysds.runtime.transform.encode.EncoderFactory
-
- createEncoder(String, String[], Types.ValueType[], FrameBlock) - Static method in class org.apache.sysds.runtime.transform.encode.EncoderFactory
-
- createEncoder(String, String[], Types.ValueType[], FrameBlock, int, int) - Static method in class org.apache.sysds.runtime.transform.encode.EncoderFactory
-
- createExecutionContext(ExecutionContext, LocalVariableMap, String, String, int) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
- createForStatementBlockCopy(ForStatementBlock, boolean) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- createFrameBlocksForReuse(Types.ValueType[], String[], long) - Static method in class org.apache.sysds.runtime.io.FrameWriter
-
- CreateFrameEncoder(long, String, int) - Constructor for class org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction.CreateFrameEncoder
-
- createFrameObject(FrameBlock) - Static method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- createFrameReader(Types.FileFormat) - Static method in class org.apache.sysds.runtime.io.FrameReaderFactory
-
- createFrameReader(Types.FileFormat, FileFormatProperties) - Static method in class org.apache.sysds.runtime.io.FrameReaderFactory
-
- createFrameWriter(Types.FileFormat) - Static method in class org.apache.sysds.runtime.io.FrameWriterFactory
-
- createFrameWriter(Types.FileFormat, FileFormatProperties) - Static method in class org.apache.sysds.runtime.io.FrameWriterFactory
-
- createGPUObject(MatrixObject) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
- createIfStatementBlockCopy(IfStatementBlock, boolean) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- createIndexingOp(Hop, long, long) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createIndexingOp(Hop, long, long, long, long) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createIndexingOp(Hop, Hop, Hop, Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createInstance(Class<?>) - Static method in class org.apache.sysds.runtime.codegen.CodegenUtils
-
- createLeftIndexingOp(Hop, Hop, Hop, Hop, Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createLiteralLop(Types.ValueType, String) - Static method in class org.apache.sysds.lops.Data
-
Method to create literal LOPs.
- createLiteralOp(ScalarObject) - Static method in class org.apache.sysds.runtime.instructions.cp.ScalarObjectFactory
-
- createLiteralOp(ScalarObject, UnaryOp) - Static method in class org.apache.sysds.runtime.instructions.cp.ScalarObjectFactory
-
- createLiteralOp(Types.ValueType, String) - Static method in class org.apache.sysds.runtime.instructions.cp.ScalarObjectFactory
-
- createLocalFileIfNotExist(String) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
- createLocalFileIfNotExist(String, String) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
- createMatrixBlocksForReuse(long, long, int, boolean, long) - Static method in class org.apache.sysds.runtime.io.MatrixWriter
-
- CreateMatrixCell(int, Operator) - Constructor for class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.CreateMatrixCell
-
- createMatrixMultiply(Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createMatrixObject(MatrixBlock) - Static method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- createMatrixReader(Types.FileFormat) - Static method in class org.apache.sysds.runtime.io.MatrixReaderFactory
-
- createMatrixReader(ReadProperties) - Static method in class org.apache.sysds.runtime.io.MatrixReaderFactory
-
- createMatrixWriter(Types.FileFormat) - Static method in class org.apache.sysds.runtime.io.MatrixWriterFactory
-
- createMatrixWriter(Types.FileFormat, int, FileFormatProperties) - Static method in class org.apache.sysds.runtime.io.MatrixWriterFactory
-
- createNary(Types.OpOpN, Hop...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createOffsetLop(Hop, boolean) - Static method in class org.apache.sysds.hops.Hop
-
- createOptNode(Instruction, LocalVariableMap, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
-
- createOptNodes(ArrayList<Instruction>, LocalVariableMap, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
-
- createOptTree(int, double, Optimizer.PlanInputType, ParForStatementBlock, ParForProgramBlock, ExecutionContext) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
-
- createParameterizedBuiltinOp(Hop, LinkedHashMap<String, Hop>, Types.ParamBuiltinOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createParser() - Static method in class org.apache.sysds.parser.ParserFactory
-
- createParser(Map<String, String>) - Static method in class org.apache.sysds.parser.ParserFactory
-
Factory method for creating parser wrappers
- createPartialTsmmCbind(Hop, Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createPartition(int, int) - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- createPartitionedMatrixObject(MatrixObject, String) - Method in class org.apache.sysds.runtime.controlprogram.parfor.DataPartitioner
-
- createPartitionedMatrixObject(MatrixObject, String, boolean) - Method in class org.apache.sysds.runtime.controlprogram.parfor.DataPartitioner
-
- createPartitionedMatrixObject(MatrixObject, MatrixObject, boolean) - Method in class org.apache.sysds.runtime.controlprogram.parfor.DataPartitioner
-
Creates a partitioned matrix object based on the given input matrix object,
according to the specified split format.
- createPlanSelector() - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
-
Factory method for alternative plan selection policies.
- createRandomMatrixGenerator(String, int, int, int, double, double, double, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDatagen
-
- createReachable(int) - Method in class org.apache.sysds.lops.Lop
-
- createReorg(Hop, String) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createReorg(Hop, Types.ReOrgOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createReorg(ArrayList<Hop>, Types.ReOrgOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createReport() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.StatisticMonitor
-
Creates a nested statistic report of all parfor and parworker instances.
- createResponse(Object) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedWorkerHandler
-
- createReuseMatrixBlock(ParForProgramBlock.PDataPartitionFormat, int, int) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.DataPartitioner
-
- createRuntimeProgramBlock(Program, StatementBlock, DMLConfig) - Method in class org.apache.sysds.parser.DMLTranslator
-
- createScalarIndexing(Hop, long, long) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createScalarObject(Types.ValueType, String) - Static method in class org.apache.sysds.runtime.instructions.cp.ScalarObjectFactory
-
- createScalarObject(Types.ValueType, Object) - Static method in class org.apache.sysds.runtime.instructions.cp.ScalarObjectFactory
-
- createScalarObject(Types.ValueType, double) - Static method in class org.apache.sysds.runtime.instructions.cp.ScalarObjectFactory
-
- createScalarObject(Types.ValueType, ScalarObject) - Static method in class org.apache.sysds.runtime.instructions.cp.ScalarObjectFactory
-
- createScalarObject(LiteralOp) - Static method in class org.apache.sysds.runtime.instructions.cp.ScalarObjectFactory
-
- createScalarObject(Types.ValueType, LiteralOp) - Static method in class org.apache.sysds.runtime.instructions.cp.ScalarObjectFactory
-
- createSeqDataGenOp(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createSeqDataGenOp(Hop, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createServer(SparkConf, LocalParamServer, String) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcFactory
-
Create and start the server
- createShallowCopy(MatrixObject) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
- createShallowCopyForProgramBlock(ForProgramBlock, Program) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- createSideInput(MatrixBlock) - Static method in class org.apache.sysds.runtime.codegen.CodegenUtils
-
- createSparkPSProxy(SparkConf, int, LongAccumulator) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcFactory
-
- createSparseBlock(int) - Static method in class org.apache.sysds.runtime.data.SparseBlockFactory
-
- createSparseBlock(SparseBlock.Type, int) - Static method in class org.apache.sysds.runtime.data.SparseBlockFactory
-
- createSparseBlock(SparseBlock.Type, SparseRow) - Static method in class org.apache.sysds.runtime.data.SparseBlockFactory
-
- CreateSparseBlockFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
General purpose copy function for binary block values.
- CreateSparseBlockFunction(SparseBlock.Type) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.CreateSparseBlockFunction
-
- createsSplitDag() - Method in class org.apache.sysds.hops.rewrite.MarkForLineageReuse
-
- createsSplitDag() - Method in class org.apache.sysds.hops.rewrite.RewriteCompressedReblock
-
- createsSplitDag() - Method in class org.apache.sysds.hops.rewrite.RewriteForLoopVectorization
-
- createsSplitDag() - Method in class org.apache.sysds.hops.rewrite.RewriteHoistLoopInvariantOperations
-
- createsSplitDag() - Method in class org.apache.sysds.hops.rewrite.RewriteInjectSparkLoopCheckpointing
-
- createsSplitDag() - Method in class org.apache.sysds.hops.rewrite.RewriteMarkLoopVariablesUpdateInPlace
-
- createsSplitDag() - Method in class org.apache.sysds.hops.rewrite.RewriteMergeBlockSequence
-
- createsSplitDag() - Method in class org.apache.sysds.hops.rewrite.RewriteRemoveEmptyBasicBlocks
-
- createsSplitDag() - Method in class org.apache.sysds.hops.rewrite.RewriteRemoveUnnecessaryBranches
-
- createsSplitDag() - Method in class org.apache.sysds.hops.rewrite.RewriteSplitDagDataDependentOperators
-
- createsSplitDag() - Method in class org.apache.sysds.hops.rewrite.RewriteSplitDagUnknownCSVRead
-
- createsSplitDag() - Method in class org.apache.sysds.hops.rewrite.StatementBlockRewriteRule
-
Indicates if the rewrite potentially splits dags, which is used
for phase ordering of rewrites.
- createStatementBlockCopy(StatementBlock, long, boolean, boolean) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- createSum(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createSystemDSSparkConf() - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
Sets up a SystemDS-preferred Spark configuration based on the implicit
default configuration (as passed via configurations from outside).
- createTasks() - Method in class org.apache.sysds.runtime.controlprogram.parfor.TaskPartitioner
-
Creates and returns set of all tasks for given problem at once.
- createTasks(LocalTaskQueue<Task>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.TaskPartitioner
-
Creates set of all tasks for given problem, but streams them directly
into task queue.
- createTasks() - Method in class org.apache.sysds.runtime.controlprogram.parfor.TaskPartitionerFactoring
-
- createTasks(LocalTaskQueue<Task>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.TaskPartitionerFactoring
-
- createTasks() - Method in class org.apache.sysds.runtime.controlprogram.parfor.TaskPartitionerFixedsize
-
- createTasks(LocalTaskQueue<Task>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.TaskPartitionerFixedsize
-
- createTemplate(TemplateBase.TemplateType) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- createTemplate(TemplateBase.TemplateType, TemplateBase.CloseType) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- createTensorReader(Types.FileFormat) - Static method in class org.apache.sysds.runtime.io.TensorReaderFactory
-
- createTensorWriter(Types.FileFormat) - Static method in class org.apache.sysds.runtime.io.TensorWriterFactory
-
- createTernary(Hop, Hop, Hop, String) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createTernary(Hop, Hop, Hop, Types.OpOp3) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createTernary(Hop, Hop, Hop, Hop, Hop, Types.OpOp3) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createTransientRead(String, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createTransientRead(String, MatrixBlock) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createTransientRead(String, MatrixObject) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createTransientWrite(String, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createTranspose(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createTsmm(Hop, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createUnary(Hop, String) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createUnary(Hop, Types.OpOp1) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createValueHop(Hop, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- createVarname() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- createWhileStatementBlockCopy(WhileStatementBlock, boolean) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- createWorkingDirectory() - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
- createWorkingDirectoryWithUUID(String) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
- crossProduct(int, Long...) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntrySet
-
- CSRPointer - Class in org.apache.sysds.runtime.instructions.gpu.context
-
Compressed Sparse Row (CSR) format for CUDA
Generalized matrix multiply is implemented for CSR format in the cuSparse library among other operations
Since we assume that the matrix is stored with zero-based indexing (i.e.
- CSVInputOutputInfo - Static variable in class org.apache.sysds.runtime.io.InputOutputInfo
-
- CSVReBlock - Class in org.apache.sysds.lops
-
Lop to convert CSV data into SystemDS data format
- CSVReBlock(Lop, int, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.CSVReBlock
-
- CSVReblockSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- csvToBinaryBlock(JavaSparkContext, JavaPairRDD<LongWritable, Text>, DataCharacteristics, Types.ValueType[], boolean, String, boolean, double, Set<String>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- csvToBinaryBlock(JavaSparkContext, JavaRDD<String>, DataCharacteristics, Types.ValueType[], boolean, String, boolean, double, Set<String>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- csvToBinaryBlock(JavaSparkContext, JavaPairRDD<LongWritable, Text>, DataCharacteristics, boolean, String, boolean, double, Set<String>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
-
- csvToBinaryBlock(JavaSparkContext, JavaRDD<String>, DataCharacteristics, boolean, String, boolean, double, Set<String>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
-
- csvToRowRDD(JavaSparkContext, String, String, Types.ValueType[]) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- csvToRowRDD(JavaSparkContext, JavaRDD<String>, String, Types.ValueType[]) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- Ctable - Class in org.apache.sysds.lops
-
Lop to perform ternary operation.
- Ctable(Lop[], Ctable.OperationTypes, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.Ctable
-
- Ctable(Lop[], Ctable.OperationTypes, Types.DataType, Types.ValueType, boolean, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.Ctable
-
- CTable - Class in org.apache.sysds.runtime.functionobjects
-
- Ctable.OperationTypes - Enum in org.apache.sysds.lops
-
- CtableCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- CTableMap - Class in org.apache.sysds.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.sysds.runtime.matrix.data.CTableMap
-
- CTableMap(LongLongDoubleHashMap.EntryType) - Constructor for class org.apache.sysds.runtime.matrix.data.CTableMap
-
- ctableOperations(Operator, double, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- ctableOperations(Operator, double, double, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- ctableOperations(Operator, MatrixIndexes, double, boolean, int, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- ctableOperations(Operator, MatrixValue, double, boolean, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- ctableOperations(Operator, MatrixValue, MatrixValue, CTableMap) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- ctableOperations(Operator, MatrixValue, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- ctableOperations(Operator, MatrixValue, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- ctableOperations(Operator, MatrixValue, double, boolean, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- ctableOperations(Operator, double, double, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- ctableOperations(Operator, MatrixIndexes, double, boolean, int, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- ctableOperations(Operator, double, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- ctableOperations(Operator, double, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
D = ctable(A,v2,W)
this <- A; scalarThat <- v2; that2 <- W; result <- D
(i1,j1,v1) from input1 (this)
(v2) from sclar_input2 (scalarThat)
(i3,j3,w) from input3 (that2)
- ctableOperations(Operator, double, double, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
D = ctable(A,v2,w)
this <- A; scalar_that <- v2; scalar_that2 <- w; result <- D
(i1,j1,v1) from input1 (this)
(v2) from sclar_input2 (scalarThat)
(w) from scalar_input3 (scalarThat2)
- ctableOperations(Operator, MatrixIndexes, double, boolean, int, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Specific ctable case of ctable(seq(...),X), where X is the only
matrix input.
- ctableOperations(Operator, MatrixValue, double, boolean, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
D = ctable(A,B,w)
this <- A; that <- B; scalar_that2 <- w; result <- D
(i1,j1,v1) from input1 (this)
(i1,j1,v2) from input2 (that)
(w) from scalar_input3 (scalarThat2)
NOTE: This method supports both vectors and matrices.
- ctableOperations(Operator, MatrixValue, MatrixValue, CTableMap) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
D = ctable(A,B,W)
this <- A; that <- B; that2 <- W; result <- D
(i1,j1,v1) from input1 (this)
(i1,j1,v2) from input2 (that)
(i1,j1,w) from input3 (that2)
- ctableOperations(Operator, MatrixValue, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- ctableOperations(Operator, MatrixValue, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- ctableOperations(Operator, MatrixValue, double, boolean, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- ctableOperations(Operator, double, double, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- ctableOperations(Operator, MatrixIndexes, double, boolean, int, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- ctableOperations(Operator, double, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- ctableOperations(Operator, MatrixValue, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- ctableOperations(Operator, MatrixValue, double, boolean, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- ctableOperations(Operator, double, double, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- ctableOperations(Operator, MatrixIndexes, double, boolean, int, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- ctableOperations(Operator, double, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- ctableSeqOperations(MatrixValue, double, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- ctableSeqOperations(MatrixValue, double, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
D = ctable(seq,A,w)
this <- seq; thatMatrix <- A; thatScalar <- w; result <- D
(i1,j1,v1) from input1 (this)
(i1,j1,v2) from input2 (that)
(w) from scalar_input3 (scalarThat2)
- CtableSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- CtableSPInstruction.MapJoinSignature1 - Class in org.apache.sysds.runtime.instructions.spark
-
- CtableSPInstruction.MapJoinSignature2 - Class in org.apache.sysds.runtime.instructions.spark
-
- CtableSPInstruction.MapJoinSignature3 - Class in org.apache.sysds.runtime.instructions.spark
-
- ctxAndFilenameToParseInfo(ParserRuleContext, String) - Static method in interface org.apache.sysds.parser.ParseInfo
-
- ctype - Variable in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- cublasaxpy(cublasHandle, int, Pointer, Pointer, int, Pointer, int) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cublasaxpy(cublasHandle, int, Pointer, Pointer, int, Pointer, int) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cublasaxpy(cublasHandle, int, Pointer, Pointer, int, Pointer, int) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cublasdot(cublasHandle, int, Pointer, int, Pointer, int, Pointer) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cublasdot(cublasHandle, int, Pointer, int, Pointer, int, Pointer) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cublasdot(cublasHandle, int, Pointer, int, Pointer, int, Pointer) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cublasgeam(cublasHandle, int, int, int, int, Pointer, Pointer, int, Pointer, Pointer, int, Pointer, int) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cublasgeam(cublasHandle, int, int, int, int, Pointer, Pointer, int, Pointer, Pointer, int, Pointer, int) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cublasgeam(cublasHandle, int, int, int, int, Pointer, Pointer, int, Pointer, Pointer, int, Pointer, int) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cublasgemm(cublasHandle, int, int, int, int, int, Pointer, Pointer, int, Pointer, int, Pointer, Pointer, int) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cublasgemm(cublasHandle, int, int, int, int, int, Pointer, Pointer, int, Pointer, int, Pointer, Pointer, int) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cublasgemm(cublasHandle, int, int, int, int, int, Pointer, Pointer, int, Pointer, int, Pointer, Pointer, int) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cublasgemv(cublasHandle, int, int, int, Pointer, Pointer, int, Pointer, int, Pointer, Pointer, int) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cublasgemv(cublasHandle, int, int, int, Pointer, Pointer, int, Pointer, int, Pointer, Pointer, int) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cublasgemv(cublasHandle, int, int, int, Pointer, Pointer, int, Pointer, int, Pointer, Pointer, int) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cublassyrk(cublasHandle, int, int, int, int, Pointer, Pointer, int, Pointer, Pointer, int) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cublassyrk(cublasHandle, int, int, int, int, Pointer, Pointer, int, Pointer, Pointer, int) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cublassyrk(cublasHandle, int, int, int, int, Pointer, Pointer, int, Pointer, Pointer, int) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cublastrsm(cublasHandle, int, int, int, int, int, int, Pointer, Pointer, int, Pointer, int) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cublastrsm(cublasHandle, int, int, int, int, int, int, Pointer, Pointer, int, Pointer, int) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cublastrsm(cublasHandle, int, int, int, int, int, int, Pointer, Pointer, int, Pointer, int) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cudaAllocCount - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaAllocFailedCount - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaAllocFailedTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaAllocReuseCount - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaAllocSuccessCount - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaAllocSuccessTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaAllocTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaDeAllocCount - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaDeAllocTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaDenseToSparseCount - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaDenseToSparseTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaDouble2FloatCount - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaDouble2FloatTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaEvictCount - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaEvictMemcpyTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaEvictSizeCount - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaEvictSizeTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaEvictTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaFloat2DoubleCount - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaFloat2DoubleTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaForcedClearLazyFreedEvictTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaForcedClearUnpinnedEvictTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaFreeHelper(String, Pointer, boolean) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Does cudaFree calls, lazily.
- cudaFromDevCount - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaFromDevTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaFromDevToShadowCount - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaFromDevToShadowTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaFromShadowToDevCount - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaFromShadowToDevTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaFromShadowToHostCount - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaFromShadowToHostTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaGetDevice() - Static method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Returns which device is currently being used.
- cudaInitTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaLibrariesInitTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- CudaMemoryAllocator - Class in org.apache.sysds.runtime.instructions.gpu.context
-
- CudaMemoryAllocator() - Constructor for class org.apache.sysds.runtime.instructions.gpu.context.CudaMemoryAllocator
-
- cudaMemSet0Count - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaMemSet0Time - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaSparseConversionCount - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaSparseConversionTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaSparseToDenseCount - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaSparseToDenseTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- CudaSupportFunctions - Interface in org.apache.sysds.runtime.matrix.data
-
DESIGN DOCUMENTATION FOR SUPPORTING LOWER PRECISION:
1.
- cudaSupportFunctions - Static variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
- cudaToDevCount - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudaToDevTime - Static variable in class org.apache.sysds.utils.GPUStatistics
-
- cudnnGetConvolutionBackwardDataAlgorithm(GPUContext, String, int, int, int, int, int, int, int, int, int, int, int, int, int, long) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNConvolutionAlgorithm
-
Factory method to get the algorithm wrapper for convolution backward data
- cudnnGetConvolutionBackwardFilterAlgorithm(GPUContext, String, int, int, int, int, int, int, int, int, int, int, int, int, int, long) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNConvolutionAlgorithm
-
Factory method to get the algorithm wrapper for convolution backward filter
- cudnnGetConvolutionForwardAlgorithm(GPUContext, String, int, int, int, int, int, int, int, int, int, int, int, int, int, long) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNConvolutionAlgorithm
-
Factory method to get the algorithm wrapper for convolution forward
- cudnnPoolingBackwardDescriptors(GPUContext, String, int, int, int, int, int, int, int, int, int, int, int, int, int, LibMatrixDNN.PoolingType) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNPoolingDescriptors
-
Get descriptors for maxpooling backward operation
- cudnnPoolingDescriptors(GPUContext, String, int, int, int, int, int, int, int, int, int, int, int, int, int, LibMatrixDNN.PoolingType) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNPoolingDescriptors
-
Get descriptors for maxpooling operation
- cumaggregateUnaryMatrix(MatrixBlock, MatrixBlock, UnaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
-
- cumaggregateUnaryMatrix(MatrixBlock, MatrixBlock, UnaryOperator, double[]) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
-
- cumaggregateUnaryMatrix(MatrixBlock, MatrixBlock, UnaryOperator, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
-
- CumulativeAggregateSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- CumulativeOffsetBinary - Class in org.apache.sysds.lops
-
- CumulativeOffsetBinary(Lop, Lop, Types.DataType, Types.ValueType, Types.AggOp, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.CumulativeOffsetBinary
-
- CumulativeOffsetBinary(Lop, Lop, Types.DataType, Types.ValueType, double, boolean, Types.AggOp, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.CumulativeOffsetBinary
-
- CumulativeOffsetSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- CumulativePartialAggregate - Class in org.apache.sysds.lops
-
- CumulativePartialAggregate(Lop, Types.DataType, Types.ValueType, Types.AggOp, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.CumulativePartialAggregate
-
- cumulativeScan(ExecutionContext, GPUContext, String, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Cumulative scan
- cumulativeSumProduct(ExecutionContext, GPUContext, String, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Cumulative sum-product kernel cascade invokation
- CURRENT_NATIVE_BLAS_STATE - Static variable in class org.apache.sysds.utils.NativeHelper
-
- cusolverDngeqrf(cusolverDnHandle, int, int, Pointer, int, Pointer, Pointer, int, Pointer) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cusolverDngeqrf(cusolverDnHandle, int, int, Pointer, int, Pointer, Pointer, int, Pointer) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusolverDngeqrf(cusolverDnHandle, int, int, Pointer, int, Pointer, Pointer, int, Pointer) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusolverDngeqrf_bufferSize(cusolverDnHandle, int, int, Pointer, int, int[]) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cusolverDngeqrf_bufferSize(cusolverDnHandle, int, int, Pointer, int, int[]) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusolverDngeqrf_bufferSize(cusolverDnHandle, int, int, Pointer, int, int[]) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusolverDnormqr(cusolverDnHandle, int, int, int, int, int, Pointer, int, Pointer, Pointer, int, Pointer, int, Pointer) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cusolverDnormqr(cusolverDnHandle, int, int, int, int, int, Pointer, int, Pointer, Pointer, int, Pointer, int, Pointer) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusolverDnormqr(cusolverDnHandle, int, int, int, int, int, Pointer, int, Pointer, Pointer, int, Pointer, int, Pointer) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusparsecsr2csc(cusparseHandle, int, int, int, Pointer, Pointer, Pointer, Pointer, Pointer, Pointer, int, int) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cusparsecsr2csc(cusparseHandle, int, int, int, Pointer, Pointer, Pointer, Pointer, Pointer, Pointer, int, int) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusparsecsr2csc(cusparseHandle, int, int, int, Pointer, Pointer, Pointer, Pointer, Pointer, Pointer, int, int) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusparsecsr2dense(cusparseHandle, int, int, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, int) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cusparsecsr2dense(cusparseHandle, int, int, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, int) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusparsecsr2dense(cusparseHandle, int, int, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, int) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusparsecsrgeam(cusparseHandle, int, int, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cusparsecsrgeam(cusparseHandle, int, int, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusparsecsrgeam(cusparseHandle, int, int, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusparsecsrgemm(cusparseHandle, int, int, int, int, int, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cusparsecsrgemm(cusparseHandle, int, int, int, int, int, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusparsecsrgemm(cusparseHandle, int, int, int, int, int, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusparsecsrmm2(cusparseHandle, int, int, int, int, int, int, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, int, Pointer, Pointer, int) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cusparsecsrmm2(cusparseHandle, int, int, int, int, int, int, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, int, Pointer, Pointer, int) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusparsecsrmm2(cusparseHandle, int, int, int, int, int, int, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, int, Pointer, Pointer, int) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusparsecsrmv(cusparseHandle, int, int, int, int, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, Pointer, Pointer) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cusparsecsrmv(cusparseHandle, int, int, int, int, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, Pointer, Pointer) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusparsecsrmv(cusparseHandle, int, int, int, int, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer, Pointer, Pointer, Pointer) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusparsedense2csr(cusparseHandle, int, int, cusparseMatDescr, Pointer, int, Pointer, Pointer, Pointer, Pointer) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cusparsedense2csr(cusparseHandle, int, int, cusparseMatDescr, Pointer, int, Pointer, Pointer, Pointer, Pointer) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusparsedense2csr(cusparseHandle, int, int, cusparseMatDescr, Pointer, int, Pointer, Pointer, Pointer, Pointer) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- cusparsennz(cusparseHandle, int, int, int, cusparseMatDescr, Pointer, int, Pointer, Pointer) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- cusparsennz(cusparseHandle, int, int, int, cusparseMatDescr, Pointer, int, Pointer, Pointer) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- cusparsennz(cusparseHandle, int, int, int, cusparseMatDescr, Pointer, int, Pointer, Pointer) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- CustomErrorListener - Class in org.apache.sysds.parser.dml
-
- CustomErrorListener() - Constructor for class org.apache.sysds.parser.dml.CustomErrorListener
-
- CustomErrorListener.ParseIssue - Class in org.apache.sysds.parser.dml
-
A parse issue (such as an parse error or a parse warning).
- CustomErrorListener.ParseIssueType - Enum in org.apache.sysds.parser.dml
-
Parse issues can be syntax errors, validation errors, and validation
warnings.
- CustomHashMap - Class in org.apache.sysds.runtime.compress.utils
-
This class provides a memory-efficient base for Custom HashMaps for restricted use cases.
- CustomHashMap() - Constructor for class org.apache.sysds.runtime.compress.utils.CustomHashMap
-
- customKernelSuffix - Static variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
- Dag<N extends Lop> - Class in org.apache.sysds.lops.compile
-
Class to maintain a DAG of lops and compile it into
runtime instructions, incl piggybacking into jobs.
- Dag() - Constructor for class org.apache.sysds.lops.compile.Dag
-
- DArrayIListEntry(DblArray, IntArrayList) - Constructor for class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap.DArrayIListEntry
-
- DASH - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- Data - Class in org.apache.sysds.lops
-
Lop to represent data objects.
- Data(Types.OpOpData, Lop, HashMap<String, Lop>, String, String, Types.DataType, Types.ValueType, Types.FileFormat) - Constructor for class org.apache.sysds.lops.Data
-
Constructor to setup read or write LOP
In case of write: input
must be provided.
- Data - Class in org.apache.sysds.runtime.instructions.cp
-
- DATA_FIELD_DELIM - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- DATA_PARTITIONER - Static variable in class org.apache.sysds.parser.ParForStatementBlock
-
- DataAugmentation - Class in org.apache.sysds.utils
-
- DataAugmentation() - Constructor for class org.apache.sysds.utils.DataAugmentation
-
- DataCharacteristics - Class in org.apache.sysds.runtime.meta
-
- DataCharacteristics() - Constructor for class org.apache.sysds.runtime.meta.DataCharacteristics
-
- DataConverter - Class in org.apache.sysds.runtime.util
-
This class provides methods to read and write matrix blocks from to HDFS using different data formats.
- DataConverter() - Constructor for class org.apache.sysds.runtime.util.DataConverter
-
- dataCorruption(FrameBlock, double, double, double, double, double) - Static method in class org.apache.sysds.utils.DataAugmentation
-
This function returns a new frame block with error introduced in the data:
Typos in string values, null values, outliers in numeric data and swapped elements.
- DataExpression - Class in org.apache.sysds.parser
-
- DataExpression() - Constructor for class org.apache.sysds.parser.DataExpression
-
- DataExpression(Expression.DataOp, HashMap<String, Expression>, ParseInfo) - Constructor for class org.apache.sysds.parser.DataExpression
-
- DataExpression(ParserRuleContext, Expression.DataOp, HashMap<String, Expression>, String) - Constructor for class org.apache.sysds.parser.DataExpression
-
- DataFrameExtractIDFunction(int) - Constructor for class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils.DataFrameExtractIDFunction
-
- dataFrameToBinaryBlock(JavaSparkContext, Dataset<Row>, DataCharacteristics, boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- dataFrameToBinaryBlock(JavaSparkContext, Dataset<Row>, DataCharacteristics, boolean, Pair<String[], Types.ValueType[]>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- dataFrameToBinaryBlock(JavaSparkContext, Dataset<Row>, DataCharacteristics, boolean, boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
-
- dataFrameToFrameBinaryBlocks(Dataset<Row>, FrameMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a DataFrame
to a JavaPairRDD<Long, FrameBlock>
binary-block frame.
- dataFrameToFrameObject(Dataset<Row>) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a DataFrame
to a FrameObject
.
- dataFrameToFrameObject(Dataset<Row>, FrameMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a DataFrame
to a FrameObject
.
- dataFrameToMatrixBinaryBlocks(Dataset<Row>) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a DataFrame
to a
JavaPairRDD<MatrixIndexes, MatrixBlock>
binary-block matrix.
- dataFrameToMatrixBinaryBlocks(Dataset<Row>, MatrixMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a DataFrame
to a
JavaPairRDD<MatrixIndexes, MatrixBlock>
binary-block matrix.
- dataFrameToMatrixObject(Dataset<Row>) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a DataFrame
to a MatrixObject
.
- dataFrameToMatrixObject(Dataset<Row>, MatrixMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a DataFrame
to a MatrixObject
.
- DataGen - Class in org.apache.sysds.lops
-
Defines a LOP that generates data.
- DataGen(Types.OpOpDG, DataIdentifier, HashMap<String, Lop>, String, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.DataGen
-
Creates a new Rand-LOP.
- DataGenCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- DataGenOp - Class in org.apache.sysds.hops
-
A DataGenOp can be rand (or matrix constructor), sequence, and sample -
these operators have different parameters and use a map of parameter type to hop position.
- DataGenOp(Types.OpOpDG, DataIdentifier, HashMap<String, Hop>) - Constructor for class org.apache.sysds.hops.DataGenOp
-
Creates a new Rand HOP.
- DataGenOp(Types.OpOpDG, DataIdentifier) - Constructor for class org.apache.sysds.hops.DataGenOp
-
- DataIdentifier - Class in org.apache.sysds.parser
-
- DataIdentifier(DataIdentifier) - Constructor for class org.apache.sysds.parser.DataIdentifier
-
- DataIdentifier(String) - Constructor for class org.apache.sysds.parser.DataIdentifier
-
- DataIdentifier(String, Types.DataType) - Constructor for class org.apache.sysds.parser.DataIdentifier
-
- DataIdentifier(String, Types.DataType, Types.ValueType) - Constructor for class org.apache.sysds.parser.DataIdentifier
-
- DataIdentifier() - Constructor for class org.apache.sysds.parser.DataIdentifier
-
- dataIdentifier() - Method in class org.apache.sysds.parser.dml.DmlParser.AccumulatorAssignmentStatementContext
-
- dataIdentifier() - Method in class org.apache.sysds.parser.dml.DmlParser.AssignmentStatementContext
-
- dataIdentifier() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- dataIdentifier() - Method in class org.apache.sysds.parser.dml.DmlParser.DataIdExpressionContext
-
- dataIdentifier() - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionCallAssignmentStatementContext
-
- dataIdentifier - Variable in class org.apache.sysds.parser.dml.DmlParser.FunctionCallMultiAssignmentStatementContext
-
- dataIdentifier() - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionCallMultiAssignmentStatementContext
-
- dataIdentifier(int) - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionCallMultiAssignmentStatementContext
-
- dataIdentifier() - Method in class org.apache.sysds.parser.dml.DmlParser.IfdefAssignmentStatementContext
-
- dataIdentifier(int) - Method in class org.apache.sysds.parser.dml.DmlParser.IfdefAssignmentStatementContext
-
- DataIdentifierContext(ParserRuleContext, int) - Constructor for class org.apache.sysds.parser.dml.DmlParser.DataIdentifierContext
-
- DataIdentifierContext() - Constructor for class org.apache.sysds.parser.dml.DmlParser.DataIdentifierContext
-
- DataIdExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.DataIdExpressionContext
-
- dataInfo - Variable in class org.apache.sysds.parser.dml.DmlParser.DataIdentifierContext
-
- DataOp - Class in org.apache.sysds.hops
-
A DataOp can be either a persistent read/write or transient read/write - writes will always have at least one input,
but all types can have parameters (e.g., for csv literals of delimiter, header, etc).
- DataOp(String, Types.DataType, Types.ValueType, Types.OpOpData, String, long, long, long, int) - Constructor for class org.apache.sysds.hops.DataOp
-
READ operation for Matrix w/ dim1, dim2.
- DataOp(String, Types.DataType, Types.ValueType, Types.OpOpData, String, long, long, long, MatrixObject.UpdateType, int) - Constructor for class org.apache.sysds.hops.DataOp
-
- DataOp(String, Types.DataType, Types.ValueType, Types.OpOpData, HashMap<String, Hop>) - Constructor for class org.apache.sysds.hops.DataOp
-
READ operation for Matrix / SQL operation for tensor
This constructor supports expressions in parameters
- DataOp(String, Types.DataType, Types.ValueType, Hop, Types.OpOpData, String) - Constructor for class org.apache.sysds.hops.DataOp
-
- DataOp(String, Types.DataType, Types.ValueType, Types.OpOpData, Hop, HashMap<String, Hop>) - Constructor for class org.apache.sysds.hops.DataOp
-
WRITE operation for Matrix
This constructor supports expression in parameters
- DataPartitioner - Class in org.apache.sysds.runtime.controlprogram.parfor
-
This is the base class for all data partitioner.
- DataPartitionerLocal - Class in org.apache.sysds.runtime.controlprogram.parfor
-
Partitions a given matrix into row or column partitions with a two pass-approach.
- DataPartitionerLocal(ParForProgramBlock.PartitionFormat, int) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.DataPartitionerLocal
-
DataPartitionerLocal constructor.
- DataPartitionerRemoteSpark - Class in org.apache.sysds.runtime.controlprogram.parfor
-
MR job class for submitting parfor remote partitioning MR jobs.
- DataPartitionerRemoteSpark(ParForProgramBlock.PartitionFormat, ExecutionContext, long, int, boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.DataPartitionerRemoteSpark
-
- DataPartitionerRemoteSparkMapper - Class in org.apache.sysds.runtime.controlprogram.parfor
-
NOTE: for the moment we only support binary block here
TODO extend impl for binarycell and textcell
Interface of Writable output in order to support both PairWritableBlock and PairWritableCell.
- DataPartitionerRemoteSparkMapper(DataCharacteristics, Types.FileFormat, ParForProgramBlock.PDataPartitionFormat, int) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.DataPartitionerRemoteSparkMapper
-
- DataPartitionerRemoteSparkReducer - Class in org.apache.sysds.runtime.controlprogram.parfor
-
- DataPartitionerRemoteSparkReducer(String, Types.FileFormat, int) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.DataPartitionerRemoteSparkReducer
-
- DataPartitionerSparkAggregator - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
-
- DataPartitionerSparkAggregator() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionerSparkAggregator
-
- DataPartitionerSparkAggregator(long, long) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionerSparkAggregator
-
- DataPartitionerSparkMapper - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
-
- DataPartitionerSparkMapper(Statement.PSScheme, int, SparkExecutionContext, int) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionerSparkMapper
-
- DataPartitionLocalScheme - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
-
- DataPartitionLocalScheme() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionLocalScheme
-
- DataPartitionLocalScheme.Result - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
-
- DataPartitionSparkScheme - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
-
- DataPartitionSparkScheme() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionSparkScheme
-
- DataRange - Class in org.apache.sysds.runtime.privacy.finegrained
-
A DataRange instance marks a part of a CachableData data object.
- DataRange(long[], long[]) - Constructor for class org.apache.sysds.runtime.privacy.finegrained.DataRange
-
- DatasetObject - Class in org.apache.sysds.runtime.instructions.spark.data
-
- DatasetObject(Dataset<Row>) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.DatasetObject
-
- DatasetObject(Dataset<Row>, boolean, boolean) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.DatasetObject
-
- DataTensorBlock - Class in org.apache.sysds.runtime.data
-
- DataTensorBlock() - Constructor for class org.apache.sysds.runtime.data.DataTensorBlock
-
- DataTensorBlock(int, Types.ValueType) - Constructor for class org.apache.sysds.runtime.data.DataTensorBlock
-
- DataTensorBlock(Types.ValueType[]) - Constructor for class org.apache.sysds.runtime.data.DataTensorBlock
-
- DataTensorBlock(Types.ValueType[], int[]) - Constructor for class org.apache.sysds.runtime.data.DataTensorBlock
-
- DataTensorBlock(Types.ValueType, int[]) - Constructor for class org.apache.sysds.runtime.data.DataTensorBlock
-
- DataTensorBlock(Types.ValueType[], int[], String[][]) - Constructor for class org.apache.sysds.runtime.data.DataTensorBlock
-
- DataTensorBlock(double) - Constructor for class org.apache.sysds.runtime.data.DataTensorBlock
-
- DataTensorBlock(DataTensorBlock) - Constructor for class org.apache.sysds.runtime.data.DataTensorBlock
-
- DataTensorBlock(BasicTensorBlock) - Constructor for class org.apache.sysds.runtime.data.DataTensorBlock
-
- dataType() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- dataType() - Method in class org.apache.sysds.parser.dml.DmlParser.Ml_typeContext
-
- DATATYPE_PREFIX - Static variable in class org.apache.sysds.lops.Lop
-
- DATATYPE_PREFIX - Static variable in class org.apache.sysds.runtime.instructions.Instruction
-
- DataTypeContext(ParserRuleContext, int) - Constructor for class org.apache.sysds.parser.dml.DmlParser.DataTypeContext
-
- DataTypeContext() - Constructor for class org.apache.sysds.parser.dml.DmlParser.DataTypeContext
-
- DATATYPEPARAM - Static variable in class org.apache.sysds.parser.DataExpression
-
- DblArray - Class in org.apache.sysds.runtime.compress.utils
-
Helper class used for bitmap extraction.
- DblArray() - Constructor for class org.apache.sysds.runtime.compress.utils.DblArray
-
- DblArray(double[]) - Constructor for class org.apache.sysds.runtime.compress.utils.DblArray
-
- DblArray(DblArray) - Constructor for class org.apache.sysds.runtime.compress.utils.DblArray
-
- DblArray(double[], boolean) - Constructor for class org.apache.sysds.runtime.compress.utils.DblArray
-
- DblArrayIntListHashMap - Class in org.apache.sysds.runtime.compress.utils
-
This class provides a memory-efficient replacement for HashMap<DblArray,IntArrayList>
for restricted use
cases.
- DblArrayIntListHashMap() - Constructor for class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap
-
- DblArrayIntListHashMap(int) - Constructor for class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap
-
- DblArrayIntListHashMap.DArrayIListEntry - Class in org.apache.sysds.runtime.compress.utils
-
- DCLocalScheme - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
-
Disjoint_Contiguous data partitioner:
for each worker, use a right indexing
operation X[beg:end,] to obtain contiguous,
non-overlapping partitions of rows.
- DCLocalScheme() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.DCLocalScheme
-
- dconv2dBiasAddDense(double[], double[], double[], double[], int, int, int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysds.utils.NativeHelper
-
- DCSparkScheme - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
-
Spark Disjoint_Contiguous data partitioner:
- ddat - Variable in class org.apache.sysds.runtime.codegen.SpoofOperator.SideInput
-
- deallocate() - Method in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
Calls cudaFree lazily on the allocated Pointer
instances
- deallocate(boolean) - Method in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
Calls cudaFree lazily or eagerly on the allocated Pointer
instances
- debug - Variable in class org.apache.sysds.api.DMLOptions
-
- decode(MatrixBlock, FrameBlock) - Method in class org.apache.sysds.runtime.transform.decode.Decoder
-
Block decode API converting a matrix block into a frame block.
- decode(MatrixBlock, FrameBlock) - Method in class org.apache.sysds.runtime.transform.decode.DecoderComposite
-
- decode(MatrixBlock, FrameBlock) - Method in class org.apache.sysds.runtime.transform.decode.DecoderDummycode
-
- decode(MatrixBlock, FrameBlock) - Method in class org.apache.sysds.runtime.transform.decode.DecoderPassThrough
-
- decode(MatrixBlock, FrameBlock) - Method in class org.apache.sysds.runtime.transform.decode.DecoderRecode
-
- DecodeMatrix(long, long, FrameBlock, Decoder) - Constructor for class org.apache.sysds.runtime.instructions.fed.ParameterizedBuiltinFEDInstruction.DecodeMatrix
-
- Decoder - Class in org.apache.sysds.runtime.transform.decode
-
Base class for all transform decoders providing both a row and block
interface for decoding matrices to frames.
- DecoderComposite - Class in org.apache.sysds.runtime.transform.decode
-
Simple composite decoder that applies a list of decoders
in specified order.
- DecoderDummycode - Class in org.apache.sysds.runtime.transform.decode
-
Simple atomic decoder for dummycoded columns.
- DecoderFactory - Class in org.apache.sysds.runtime.transform.decode
-
- DecoderFactory() - Constructor for class org.apache.sysds.runtime.transform.decode.DecoderFactory
-
- DecoderPassThrough - Class in org.apache.sysds.runtime.transform.decode
-
Simple atomic decoder for passing through numeric columns to the output.
- DecoderRecode - Class in org.apache.sysds.runtime.transform.decode
-
Simple atomic decoder for recoded columns.
- decompress() - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- decompress() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
Decompress block.
- decompress(int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
Decompress block.
- decompressToBlock(MatrixBlock, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Decompress the contents of this column group into the specified full matrix block.
- decompressToBlock(MatrixBlock, int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Decompress the contents of this column group into uncompressed packed columns
- decompressToBlock(MatrixBlock, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Decompress to block.
- decompressToBlock(MatrixBlock, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
-
- decompressToBlock(MatrixBlock, int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
-
- decompressToBlock(MatrixBlock, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
-
- decompressToBlock(MatrixBlock, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOffset
-
- decompressToBlock(MatrixBlock, int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOffset
-
- decompressToBlock(MatrixBlock, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOffset
-
- decompressToBlock(MatrixBlock, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
- decompressToBlock(MatrixBlock, int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
- decompressToBlock(MatrixBlock, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
- decompressToBlock(MatrixBlock, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
-
- decompressToBlock(MatrixBlock, int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
-
- decompressToBlock(MatrixBlock, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
-
- decompressToBlock(MatrixBlock, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- decompressToBlock(MatrixBlock, int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- decompressToBlock(MatrixBlock, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- decrementNoOfExecutedSPInst() - Static method in class org.apache.sysds.utils.Statistics
-
- decrementNumReferences() - Method in class org.apache.sysds.runtime.instructions.spark.data.LineageObject
-
- DEDUP_DELIM - Static variable in class org.apache.sysds.runtime.lineage.LineageDedupUtils
-
- dedupItemOpcode - Static variable in class org.apache.sysds.runtime.lineage.LineageItem
-
- deepClone() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
-
- deepCopy() - Method in class org.apache.sysds.runtime.lineage.LineageItem
-
- deepCopyHopsDag(List<Hop>) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
Deep copy of hops dags for parallel recompilation.
- deepCopyHopsDag(Hop) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
Deep copy of hops dags for parallel recompilation.
- DEFAULT_BLOCK_SIZE - Static variable in class org.apache.sysds.conf.DMLConfig
-
- DEFAULT_BLOCK_SIZE - Static variable in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- DEFAULT_BLOCKSIZE - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Default blocksize if unspecified or for testing purposes
- DEFAULT_BUFFER_SIZE - Static variable in class org.apache.sysds.runtime.instructions.spark.data.FrameReblockBuffer
-
- DEFAULT_BUFFER_SIZE - Static variable in class org.apache.sysds.runtime.instructions.spark.data.ReblockBuffer
-
- DEFAULT_DATAFORMAT - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNodeStatistics
-
- DEFAULT_DELIM_DELIMITER - Static variable in class org.apache.sysds.parser.DataExpression
-
- DEFAULT_DELIM_FILL - Static variable in class org.apache.sysds.parser.DataExpression
-
- DEFAULT_DELIM_FILL_VALUE - Static variable in class org.apache.sysds.parser.DataExpression
-
- DEFAULT_DELIM_HAS_HEADER_ROW - Static variable in class org.apache.sysds.parser.DataExpression
-
- DEFAULT_DELIM_SPARSE - Static variable in class org.apache.sysds.parser.DataExpression
-
- DEFAULT_DIMENSION - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNodeStatistics
-
- DEFAULT_DIMS - Static variable in class org.apache.sysds.runtime.data.TensorBlock
-
- DEFAULT_EST_PARALLELISM - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator
-
- DEFAULT_FEDERATED_PORT - Static variable in class org.apache.sysds.conf.DMLConfig
-
- DEFAULT_FRAME_BLOCKSIZE - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Default frame blocksize
- DEFAULT_INPLACE_SPARSEBLOCK - Static variable in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- DEFAULT_JVM_SIZE - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
- DEFAULT_MBS_HDFSREAD_BINARYBLOCK_SPARSE - Static variable in class org.apache.sysds.hops.cost.CostEstimatorStaticRuntime
-
- DEFAULT_MEM_ESTIMATE_CP - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator
-
- DEFAULT_MEM_ESTIMATE_SP - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator
-
- DEFAULT_MEM_SP - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimatorHops
-
- DEFAULT_NA_STRINGS - Static variable in class org.apache.sysds.parser.DataExpression
-
- DEFAULT_NAMESPACE - Static variable in class org.apache.sysds.parser.DMLProgram
-
- DEFAULT_NUMBER_OF_FEDERATED_WORKER_THREADS - Static variable in class org.apache.sysds.conf.DMLConfig
-
- DEFAULT_OPTLEVEL - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Default optimization level if unspecified
- DEFAULT_SHARED_DIR_PERMISSION - Static variable in class org.apache.sysds.conf.DMLConfig
-
- DEFAULT_SIZE - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Default memory size, which is used if the actual estimate can not be computed
e.g., when input/output dimensions are unknown.
- DEFAULT_SPARSEBLOCK - Static variable in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- DEFAULT_SPARSEBLOCK - Static variable in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- DEFAULT_SPARSITY - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNodeStatistics
-
- DEFAULT_STORAGE_LEVEL - Static variable in class org.apache.sysds.lops.Checkpoint
-
- DEFAULT_SYSTEMDS_CONFIG_FILEPATH - Static variable in class org.apache.sysds.conf.DMLConfig
-
- DEFAULT_TIME_ESTIMATE - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator
-
- DEFAULT_TMP - Static variable in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- DEFAULT_VTYPE - Static variable in class org.apache.sysds.runtime.data.TensorBlock
-
- defaultFormat() - Static method in enum org.apache.sysds.common.Types.FileFormat
-
- defaultFormatString() - Static method in enum org.apache.sysds.common.Types.FileFormat
-
- defaultNaString - Static variable in class org.apache.sysds.runtime.util.UtilFunctions
-
- defaultOptions - Static variable in class org.apache.sysds.api.DMLOptions
-
- deleteBlock(String) - Static method in class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
-
- deleteCrcFilesFromLocalFileSystem(FileSystem, Path) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
Delete the CRC files from the local file system associated with a
particular file and its metadata file.
- deleteFileIfExistOnHDFS(String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- deleteFileIfExistOnHDFS(Path, JobConf) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- deleteFileIfExistOnLFS(Path, JobConf) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- deleteFileIfExists(String) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
- deleteFileIfExists(String, boolean) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
- deleteFileWithMTDIfExistOnHDFS(String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- deleteIndexRange(int, int, int) - Method in class org.apache.sysds.runtime.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.sysds.runtime.data.SparseBlockCOO
-
- deleteIndexRange(int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- deleteIndexRange(int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- deleteIndexRange(int, int) - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- deleteRemoveVariableInstructions(Program) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Delete the 'remove variable' instructions from a runtime program.
- DELIM - Static variable in class org.apache.sysds.runtime.instructions.cp.StringInitCPInstruction
-
- DELIM_DELIMITER - Static variable in class org.apache.sysds.parser.DataExpression
-
- DELIM_FILL - Static variable in class org.apache.sysds.parser.DataExpression
-
- DELIM_FILL_VALUE - Static variable in class org.apache.sysds.parser.DataExpression
-
- DELIM_HAS_HEADER_ROW - Static variable in class org.apache.sysds.parser.DataExpression
-
- DELIM_NA_STRING_SEP - Static variable in class org.apache.sysds.parser.DataExpression
-
- DELIM_NA_STRINGS - Static variable in class org.apache.sysds.parser.DataExpression
-
- DELIM_SPARSE - Static variable in class org.apache.sysds.parser.DataExpression
-
- DenseBlock - Class in org.apache.sysds.runtime.data
-
This DenseBlock is an abstraction for different dense, row-major
matrix formats.
- DenseBlock.Type - Enum in org.apache.sysds.runtime.data
-
- DenseBlockBool - Class in org.apache.sysds.runtime.data
-
- DenseBlockBool(int[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockBool
-
- DenseBlockBool(int[], BitSet) - Constructor for class org.apache.sysds.runtime.data.DenseBlockBool
-
- DenseBlockBool(int[], boolean[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockBool
-
- DenseBlockDRB - Class in org.apache.sysds.runtime.data
-
- DenseBlockFactory - Class in org.apache.sysds.runtime.data
-
- DenseBlockFactory() - Constructor for class org.apache.sysds.runtime.data.DenseBlockFactory
-
- DenseBlockFP32 - Class in org.apache.sysds.runtime.data
-
- DenseBlockFP32(int[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockFP32
-
- DenseBlockFP32(int[], float[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockFP32
-
- DenseBlockFP64 - Class in org.apache.sysds.runtime.data
-
- DenseBlockFP64(int[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockFP64
-
- DenseBlockFP64(int[], double[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockFP64
-
- DenseBlockInt32 - Class in org.apache.sysds.runtime.data
-
- DenseBlockInt32(int[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockInt32
-
- DenseBlockInt32(int[], int[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockInt32
-
- DenseBlockInt64 - Class in org.apache.sysds.runtime.data
-
- DenseBlockInt64(int[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockInt64
-
- DenseBlockInt64(int[], long[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockInt64
-
- DenseBlockLBool - Class in org.apache.sysds.runtime.data
-
- DenseBlockLBool(int[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockLBool
-
- DenseBlockLDRB - Class in org.apache.sysds.runtime.data
-
Dense Large Row Blocks have multiple 1D arrays (blocks), which contain complete rows.
- DenseBlockLFP32 - Class in org.apache.sysds.runtime.data
-
- DenseBlockLFP32(int[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockLFP32
-
- DenseBlockLFP64 - Class in org.apache.sysds.runtime.data
-
- DenseBlockLFP64(int[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockLFP64
-
- DenseBlockLInt32 - Class in org.apache.sysds.runtime.data
-
- DenseBlockLInt32(int[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockLInt32
-
- DenseBlockLInt64 - Class in org.apache.sysds.runtime.data
-
- DenseBlockLInt64(int[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockLInt64
-
- DenseBlockLString - Class in org.apache.sysds.runtime.data
-
- DenseBlockLString(int[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockLString
-
- DenseBlockString - Class in org.apache.sysds.runtime.data
-
- DenseBlockString(int[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockString
-
- DenseBlockString(int[], String[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockString
-
- denseColumnMajorToRowMajor() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Convenience method.
- DenseRowIterator - Class in org.apache.sysds.runtime.compress.colgroup
-
- DenseRowIterator(int, int, List<ColGroup>, int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.DenseRowIterator
-
- denseRowMajorToColumnMajor() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Convenience method.
- denseScalarOperationsInPlace(ScalarOperator) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- denseScalarOperationsInPlace(ScalarOperator) - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
-
- denseToSparse() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Converts this GPUObject from dense to sparse format.
- denseTranspose(ExecutionContext, GPUContext, String, Pointer, Pointer, long, long) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Computes C = t(A)
- DensityMap(MatrixBlock, int) - Constructor for class org.apache.sysds.hops.estim.EstimatorDensityMap.DensityMap
-
- DensityMap(MatrixBlock, int, int, int, boolean) - Constructor for class org.apache.sysds.hops.estim.EstimatorDensityMap.DensityMap
-
- dequeueTask() - Method in class org.apache.sysds.runtime.controlprogram.parfor.LocalTaskQueue
-
Synchronized read and delete from the top of the FIFO queue.
- deriveAggregateOperatorCorrectionLocation(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- deriveAggregateOperatorOpcode(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- deriveAndSetStatusFromData() - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- deriveOutputCharacteristics(EstimatorMatrixHistogram.MatrixHistogram, EstimatorMatrixHistogram.MatrixHistogram, double, SparsityEstimator.OpCode, long[]) - Static method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram.MatrixHistogram
-
- deriveOutputHistogram(EstimatorMatrixHistogram.MatrixHistogram, EstimatorMatrixHistogram.MatrixHistogram, double, SparsityEstimator.OpCode, long[]) - Static method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram.MatrixHistogram
-
- descr - Variable in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
descriptor of matrix, only CUSPARSE_MATRIX_TYPE_GENERAL supported
- DESCRIPTIONPARAM - Static variable in class org.apache.sysds.parser.DataExpression
-
- deserialize(String) - Static method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
-
- deserialize(ByteBuffer) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcCall
-
- deserialize(ByteBuffer) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcObject
-
- deserialize(ByteBuffer) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcResponse
-
- deserialize(MatrixBlock) - Method in class org.apache.sysds.runtime.io.BinaryBlockSerialization.MatrixBlockDeserializer
-
- deserialize(Map<String, String>) - Static method in class org.apache.sysds.runtime.lineage.Lineage
-
- deserializeBlock() - Method in class org.apache.sysds.runtime.controlprogram.caching.ByteBuffer
-
- destroy() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Destroys this GPUContext object.
- destroy() - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBroadcast
-
This method cleanups all underlying broadcasts of a partitioned broadcast,
by forward the calls to SparkExecutionContext.cleanupBroadcastVariable.
- detectSchema(SparkExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.UnaryFrameSPInstruction
-
- detectSchemaFromRow(double) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- determineDataPartitionFormat(String) - Method in class org.apache.sysds.parser.ParForStatementBlock
-
Determines the PDataPartitioningFormat for read-only parent variables according
to the access pattern of that variable within the parfor statement block.
- determineFrameFormatIfNeeded(Dataset<Row>, FrameMetadata) - Static method in class org.apache.sysds.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.sysds.api.mlcontext.MLContextConversionUtil
-
If the MatrixFormat of the DataFrame has not been explicitly specified,
attempt to determine the proper MatrixFormat.
- determineMinVectorIntermediates(CNode, CNode) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- determineOutputTypeAsString(LocalVariableMap, String) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Obtain a symbol table output type as a String
- deviceCopy(String, Pointer, Pointer, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs a deep copy of input device double pointer corresponding to matrix
- deviceToHost(GPUContext, Pointer, double[], String, boolean) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- deviceToHost(GPUContext, Pointer, double[], String, boolean) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- deviceToHost(GPUContext, Pointer, double[], String, boolean) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- DF_ID_COLUMN - Static variable in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
-
- DFS_BLOCKSIZE - Static variable in class org.apache.sysds.runtime.util.HDFSTool
-
- DFS_PERMISSIONS_ENABLED - Static variable in class org.apache.sysds.runtime.util.HDFSTool
-
- DFS_REPLICATION - Static variable in class org.apache.sysds.runtime.util.HDFSTool
-
- diag(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
- DiagIndex - Class in org.apache.sysds.runtime.functionobjects
-
- Dictionary - Class in org.apache.sysds.runtime.compress.colgroup
-
This dictionary class aims to encapsulate the storage and operations over unique floating point values of a column
group.
- Dictionary(double[]) - Constructor for class org.apache.sysds.runtime.compress.colgroup.Dictionary
-
- DIGIT - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- DIGIT - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- DIListEntry(double, IntArrayList) - Constructor for class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap.DIListEntry
-
- dimsKnown() - Method in class org.apache.sysds.hops.Hop
-
- dimsKnown(boolean) - Method in class org.apache.sysds.hops.Hop
-
- dimsKnown() - Method in class org.apache.sysds.parser.Identifier
-
- dimsKnown() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- dimsKnown(boolean) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- dimsKnown() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- dimsKnown(boolean) - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- dimsKnown() - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- dimsKnown(boolean) - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- dimsKnownAny() - Method in class org.apache.sysds.hops.Hop
-
- disableBinaryCell() - Method in class org.apache.sysds.runtime.controlprogram.parfor.DataPartitioner
-
- disableCaching() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- disableJVMReuse() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- disableMonitorReport() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- disableOptimization() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- disableRecompileRead() - Method in class org.apache.sysds.hops.DataOp
-
Explicitly disables recompilation of transient reads, this additional information
is required because requiresRecompile is set in a top-down manner, hence any value
set from a consuming operating would be overwritten by opFindExecType.
- disableStatMonitoring() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.StatisticMonitor
-
Globally disables statistic monitor for the currently activ JVM.
- display() - Static method in class org.apache.sysds.runtime.privacy.CheckedConstraintsLog
-
Get string representing all contents of the checked constraints log.
- display(DMLProgram, Program, Explain.ExplainType, Explain.ExplainCounts) - Static method in class org.apache.sysds.utils.Explain
-
- display() - Static method in class org.apache.sysds.utils.Statistics
-
Returns statistics of the DML program that was recently completed as a string
- display(int) - Static method in class org.apache.sysds.utils.Statistics
-
Returns statistics as a string
- displayHits() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- displayHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- displayInputParameters() - Method in class org.apache.sysds.api.mlcontext.Script
-
Display the script input parameters.
- displayInputs(String, Map<String, Object>, LocalVariableMap) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Obtain a display of script inputs.
- displayInputs() - Method in class org.apache.sysds.api.mlcontext.Script
-
Display the script inputs.
- displayInputVariables() - Method in class org.apache.sysds.api.mlcontext.Script
-
Display the script input variables.
- displayMap(String, Map<String, Object>) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Display the keys and values in a Map
- displayMultiLevelHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- displayOutputs(String, Set<String>, LocalVariableMap) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Obtain a display of the script outputs.
- displayOutputs(Set<String>, LocalVariableMap) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Obtain a display of the script outputs.
- displayOutputs() - Method in class org.apache.sysds.api.mlcontext.Script
-
Display the script outputs.
- displayOutputVariables() - Method in class org.apache.sysds.api.mlcontext.Script
-
Display the script output variables.
- displayRewrites() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- displaySet(String, Set<String>) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Display the values in a Set
- displaySymbolTable(String, LocalVariableMap) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Display the keys and values in the symbol table
- displaySymbolTable(LocalVariableMap) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Display the keys and values in the symbol table
- displaySymbolTable() - Method in class org.apache.sysds.api.mlcontext.Script
-
Display the script symbol table.
- displayTime() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- displayTime() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- displayWrites() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- displayWtrites() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- distFunc - Variable in class org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin
-
- Divide - Class in org.apache.sysds.runtime.functionobjects
-
- DIVIDE_PRIME - Static variable in class org.apache.sysds.runtime.util.UtilFunctions
-
- dml(String) - Static method in class org.apache.sysds.api.mlcontext.ScriptFactory
-
Create a DML Script object based on a string.
- DML_FILE_PATH_ANTLR_PARSER - Static variable in class org.apache.sysds.api.DMLScript
-
- DmlBaseListener - Class in org.apache.sysds.parser.dml
-
This class provides an empty implementation of
DmlListener
,
which can be extended to create a listener which only needs to handle a subset
of the available methods.
- DmlBaseListener() - Constructor for class org.apache.sysds.parser.dml.DmlBaseListener
-
- DMLCompressionException - Exception in org.apache.sysds.runtime
-
- DMLCompressionException(String) - Constructor for exception org.apache.sysds.runtime.DMLCompressionException
-
- DMLCompressionException(Exception) - Constructor for exception org.apache.sysds.runtime.DMLCompressionException
-
- DMLCompressionException(String, Exception) - Constructor for exception org.apache.sysds.runtime.DMLCompressionException
-
- DMLConfig - Class in org.apache.sysds.conf
-
- DMLConfig() - Constructor for class org.apache.sysds.conf.DMLConfig
-
- DMLConfig(String) - Constructor for class org.apache.sysds.conf.DMLConfig
-
- DMLConfig(String, boolean) - Constructor for class org.apache.sysds.conf.DMLConfig
-
- DMLConfig(Element) - Constructor for class org.apache.sysds.conf.DMLConfig
-
- DMLConfig(DMLConfig) - Constructor for class org.apache.sysds.conf.DMLConfig
-
- DMLException - Exception in org.apache.sysds.api
-
Exception occurring in the DML framework.
- DMLException() - Constructor for exception org.apache.sysds.api.DMLException
-
- DMLException(String) - Constructor for exception org.apache.sysds.api.DMLException
-
- DMLException(Throwable) - Constructor for exception org.apache.sysds.api.DMLException
-
- DMLException(String, Throwable) - Constructor for exception org.apache.sysds.api.DMLException
-
- dmlFromFile(String) - Static method in class org.apache.sysds.api.mlcontext.ScriptFactory
-
Create a DML Script object based on a string path to a file.
- dmlFromInputStream(InputStream) - Static method in class org.apache.sysds.api.mlcontext.ScriptFactory
-
Create a DML Script object based on an input stream.
- dmlFromLocalFile(File) - Static method in class org.apache.sysds.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.sysds.api.mlcontext.ScriptFactory
-
Create a DML Script object based on a resource path.
- dmlFromString(String) - Static method in class org.apache.sysds.api.mlcontext.ScriptFactory
-
Create a DML Script object based on a string.
- dmlFromUrl(String) - Static method in class org.apache.sysds.api.mlcontext.ScriptFactory
-
Create a DML Script object based on a URL path.
- dmlFromUrl(URL) - Static method in class org.apache.sysds.api.mlcontext.ScriptFactory
-
Create a DML Script object based on a URL.
- DmlLexer - Class in org.apache.sysds.parser.dml
-
- DmlLexer(CharStream) - Constructor for class org.apache.sysds.parser.dml.DmlLexer
-
- DmlListener - Interface in org.apache.sysds.parser.dml
-
This interface defines a complete listener for a parse tree produced by
DmlParser
.
- DMLOptions - Class in org.apache.sysds.api
-
Set of DMLOptions that can be set through the command line
and
MLContext
The values have been initialized with the default values
Despite there being a DML and PyDML, this class is named DMLOptions
to keep it consistent with
DMLOptions
and
DMLOptions
- DMLOptions(Options) - Constructor for class org.apache.sysds.api.DMLOptions
-
- DmlParser - Class in org.apache.sysds.parser.dml
-
- DmlParser(TokenStream) - Constructor for class org.apache.sysds.parser.dml.DmlParser
-
- DmlParser.AccumulatorAssignmentStatementContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.AddSubExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.AssignmentStatementContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.AtomicExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.BooleanAndExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.BooleanNotExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.BooleanOrExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.BuiltinFunctionExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.CommandlineParamExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.CommandlinePositionExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.ConstDoubleIdExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.ConstFalseExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.ConstIntIdExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.ConstStringIdExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.ConstTrueExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.DataIdentifierContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.DataIdExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.DataTypeContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.ExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.ExternalFunctionDefExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.ForStatementContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.FunctionCallAssignmentStatementContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.FunctionCallMultiAssignmentStatementContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.FunctionStatementContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.IfdefAssignmentStatementContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.IfStatementContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.ImportStatementContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.IndexedExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.InternalFunctionDefExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.IterablePredicateColonExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.IterablePredicateContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.IterablePredicateSeqExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.MatrixDataTypeCheckContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.MatrixMulExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.Ml_typeContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.ModIntDivExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.MultDivExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.MultiIdExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.ParameterizedExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.ParForStatementContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.PathStatementContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.PowerExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.ProgramrootContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.RelationalExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.SimpleDataIdentifierExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.StatementContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.StrictParameterizedExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.StrictParameterizedKeyValueStringContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.TypedArgAssignContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.TypedArgNoAssignContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.UnaryExpressionContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.ValueTypeContext - Class in org.apache.sysds.parser.dml
-
- DmlParser.WhileStatementContext - Class in org.apache.sysds.parser.dml
-
- DMLParserWrapper - Class in org.apache.sysds.parser.dml
-
This is the main entry point for the Antlr4 parser.
- DMLParserWrapper() - Constructor for class org.apache.sysds.parser.dml.DMLParserWrapper
-
- DmlPreprocessor - Class in org.apache.sysds.parser.dml
-
Minimal pre-processing of user function definitions which take precedence over built-in
functions in cases where names conflict.
- DmlPreprocessor(CustomErrorListener) - Constructor for class org.apache.sysds.parser.dml.DmlPreprocessor
-
- DMLPrivacyException - Exception in org.apache.sysds.runtime.privacy
-
This exception should be thrown to flag DML runtime errors related to the violation of privacy constraints.
- DMLPrivacyException(String) - Constructor for exception org.apache.sysds.runtime.privacy.DMLPrivacyException
-
This is the only valid constructor for DMLPrivacyException.
- DMLProgram - Class in org.apache.sysds.parser
-
- DMLProgram() - Constructor for class org.apache.sysds.parser.DMLProgram
-
- DMLProgram(String) - Constructor for class org.apache.sysds.parser.DMLProgram
-
- DMLRuntimeException - Exception in org.apache.sysds.runtime
-
This exception should be thrown to flag runtime errors -- DML equivalent to java.lang.RuntimeException.
- DMLRuntimeException(String) - Constructor for exception org.apache.sysds.runtime.DMLRuntimeException
-
- DMLRuntimeException(Exception) - Constructor for exception org.apache.sysds.runtime.DMLRuntimeException
-
- DMLRuntimeException(String, Exception) - Constructor for exception org.apache.sysds.runtime.DMLRuntimeException
-
- DMLScript - Class in org.apache.sysds.api
-
- DMLScript() - Constructor for class org.apache.sysds.api.DMLScript
-
- DMLScriptException - Exception in org.apache.sysds.runtime
-
This exception should be thrown to flag DML Script errors.
- DMLScriptException(String) - Constructor for exception org.apache.sysds.runtime.DMLScriptException
-
This is the only valid constructor for DMLScriptException.
- DmlSyntacticValidator - Class in org.apache.sysds.parser.dml
-
- DmlSyntacticValidator(CustomErrorListener, Map<String, String>, String, Set<String>) - Constructor for class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- DmlSyntacticValidator.ConvertedDMLSyntax - Class in org.apache.sysds.parser.dml
-
Information about built in functions converted to a common format between
PyDML and DML for the runtime.
- DMLTranslator - Class in org.apache.sysds.parser
-
- DMLTranslator(DMLProgram) - Constructor for class org.apache.sysds.parser.DMLTranslator
-
- dmmdd(double[], double[], double[], int, int, int, int) - Static method in class org.apache.sysds.utils.NativeHelper
-
- DnnCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- DnnCPInstruction(CPOperand, CPOperand, CPOperand, CPOperand, ArrayList<CPOperand>, ArrayList<CPOperand>, ArrayList<CPOperand>, ArrayList<CPOperand>, int, double, String, String) - Constructor for class org.apache.sysds.runtime.instructions.cp.DnnCPInstruction
-
- DnnCPInstruction(CPOperand, CPOperand, CPOperand, String, String, int, double) - Constructor for class org.apache.sysds.runtime.instructions.cp.DnnCPInstruction
-
- DnnCPInstruction(CPOperand, CPOperand, CPOperand, String, String, ArrayList<CPOperand>, ArrayList<CPOperand>, ArrayList<CPOperand>, ArrayList<CPOperand>, int, double) - Constructor for class org.apache.sysds.runtime.instructions.cp.DnnCPInstruction
-
- DnnCPInstruction(CPOperand, CPOperand, CPOperand, CPOperand, String, String, ArrayList<CPOperand>, ArrayList<CPOperand>, ArrayList<CPOperand>, ArrayList<CPOperand>, int, double) - Constructor for class org.apache.sysds.runtime.instructions.cp.DnnCPInstruction
-
- DnnCPInstruction(CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, String, String, double) - Constructor for class org.apache.sysds.runtime.instructions.cp.DnnCPInstruction
-
- DnnGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
- DnnGPUInstruction(CPOperand, CPOperand, CPOperand, String, String, double) - Constructor for class org.apache.sysds.runtime.instructions.gpu.DnnGPUInstruction
-
- DnnGPUInstruction(CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, String, String, double) - Constructor for class org.apache.sysds.runtime.instructions.gpu.DnnGPUInstruction
-
- DnnGPUInstruction(CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, String, String, double) - Constructor for class org.apache.sysds.runtime.instructions.gpu.DnnGPUInstruction
-
- DnnGPUInstruction(CPOperand, CPOperand, CPOperand, CPOperand, String, String, double) - Constructor for class org.apache.sysds.runtime.instructions.gpu.DnnGPUInstruction
-
- DnnGPUInstruction(CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, String, String, double) - Constructor for class org.apache.sysds.runtime.instructions.gpu.DnnGPUInstruction
-
- DnnGPUInstruction(CPOperand, CPOperand, CPOperand, CPOperand, String, String, ArrayList<CPOperand>, ArrayList<CPOperand>, ArrayList<CPOperand>, ArrayList<CPOperand>, double) - Constructor for class org.apache.sysds.runtime.instructions.gpu.DnnGPUInstruction
-
- DnnGPUInstruction(CPOperand, CPOperand, CPOperand, String, String, ArrayList<CPOperand>, ArrayList<CPOperand>, ArrayList<CPOperand>, ArrayList<CPOperand>, double) - Constructor for class org.apache.sysds.runtime.instructions.gpu.DnnGPUInstruction
-
- DnnGPUInstruction(CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, String, String, double) - Constructor for class org.apache.sysds.runtime.instructions.gpu.DnnGPUInstruction
-
- DnnOp - Class in org.apache.sysds.hops
-
- DnnOp(String, Types.DataType, Types.ValueType, Types.OpOpDnn, ArrayList<Hop>) - Constructor for class org.apache.sysds.hops.DnnOp
-
Create a hop from the builtin expression
- DnnParameters - Class in org.apache.sysds.runtime.matrix.data
-
This class is container that stores parameters required for executing following operations:
conv2d, conv2d_backward_data, conv2d_backward_filter, maxpooling, maxpooling_backward
- DnnParameters(long, long, long, long, long, long, long, long, long, long, long, int) - Constructor for class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- DnnParameters(int, int, int, int, int, int, int, int, int, int, int, int) - Constructor for class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- DnnSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- DnnTransform - Class in org.apache.sysds.lops
-
- DnnTransform(Lop, Types.OpOpDnn, Types.DataType, Types.ValueType, LopProperties.ExecType, int, double) - Constructor for class org.apache.sysds.lops.DnnTransform
-
Constructor when we have one input.
- DnnTransform(Lop, Lop, Types.OpOpDnn, Types.DataType, Types.ValueType, LopProperties.ExecType, int) - Constructor for class org.apache.sysds.lops.DnnTransform
-
- DnnTransform(Lop, Lop, Lop, Types.OpOpDnn, Types.DataType, Types.ValueType, LopProperties.ExecType, int) - Constructor for class org.apache.sysds.lops.DnnTransform
-
- DnnUtils - Class in org.apache.sysds.runtime.util
-
- DnnUtils() - Constructor for class org.apache.sysds.runtime.util.DnnUtils
-
- doesDataFrameLookLikeMatrix(Dataset<Row>) - Static method in class org.apache.sysds.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.sysds.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.sysds.api.mlcontext.MLContextUtil
-
Determine if the symbol table contains a MatrixObject with the given
variable name.
- doParse(String, String, String, Map<String, String>) - Method in class org.apache.sysds.parser.dml.DMLParserWrapper
-
This function is supposed to be called directly only from DmlSyntacticValidator when it encounters 'import'
- doPartitioning(int, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionLocalScheme
-
- doPartitioning(int, int, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionSparkScheme
-
- doPartitioning(int, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DCLocalScheme
-
- doPartitioning(int, int, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DCSparkScheme
-
- doPartitioning(int, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DRLocalScheme
-
- doPartitioning(int, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DRRLocalScheme
-
- doPartitioning(int, int, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DRRSparkScheme
-
- doPartitioning(int, int, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DRSparkScheme
-
- doPartitioning(int, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.LocalDataPartitioner
-
- doPartitioning(int, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.ORLocalScheme
-
- doPartitioning(int, int, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.ORSparkScheme
-
- doPartitioning(int, MatrixBlock, MatrixBlock, long) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.SparkDataPartitioner
-
- doPartitionOnSpark(SparkExecutionContext, MatrixObject, MatrixObject, Statement.PSScheme, int) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
- dotProduct(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- dotProduct(double[], double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- dotProduct(double[], double[], int) - Static method in class org.apache.sysds.runtime.compress.utils.LinearAlgebraUtils
-
- dotProduct(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.compress.utils.LinearAlgebraUtils
-
- dotProduct(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- dotProduct(double[], double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- DOUBLE - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- DOUBLE() - Method in class org.apache.sysds.parser.dml.DmlParser.ConstDoubleIdExpressionContext
-
- DOUBLE - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- double2float(GPUContext, Pointer, Pointer, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
- DOUBLE_EPS - Static variable in class org.apache.sysds.runtime.util.UtilFunctions
-
- DOUBLE_SIZE - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
- DOUBLE_VALUE_TYPE - Static variable in class org.apache.sysds.parser.Statement
-
- doubleArrayCost(long) - Static method in class org.apache.sysds.utils.MemoryEstimates
-
- DoubleIdentifier - Class in org.apache.sysds.parser
-
- DoubleIdentifier(double) - Constructor for class org.apache.sysds.parser.DoubleIdentifier
-
- DoubleIdentifier(double, ParseInfo) - Constructor for class org.apache.sysds.parser.DoubleIdentifier
-
- DoubleIdentifier(DoubleIdentifier, ParseInfo) - Constructor for class org.apache.sysds.parser.DoubleIdentifier
-
- DoubleIdentifier(ParserRuleContext, double, String) - Constructor for class org.apache.sysds.parser.DoubleIdentifier
-
- DoubleIntListHashMap - Class in org.apache.sysds.runtime.compress.utils
-
This class provides a memory-efficient replacement for HashMap<Double,IntArrayList>
for restricted use cases.
- DoubleIntListHashMap() - Constructor for class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap
-
- DoubleIntListHashMap(int) - Constructor for class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap
-
- DoubleIntListHashMap.DIListEntry - Class in org.apache.sysds.runtime.compress.utils
-
- doubleMatrixToMatrixObject(String, double[][]) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a two-dimensional double array to a MatrixObject
.
- doubleMatrixToMatrixObject(String, double[][], MatrixMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a two-dimensional double array to a MatrixObject
.
- DoubleObject - Class in org.apache.sysds.runtime.instructions.cp
-
- DoubleObject(double) - Constructor for class org.apache.sysds.runtime.instructions.cp.DoubleObject
-
- DoublePrecisionCudaSupportFunctions - Class in org.apache.sysds.runtime.matrix.data
-
- DoublePrecisionCudaSupportFunctions() - Constructor for class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
-
- doubleToObject(Types.ValueType, double) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- doubleToObject(Types.ValueType, double, boolean) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- DRLocalScheme - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
-
Data partitioner Disjoint_Random:
for each worker, use a permutation multiply P[beg:end,] %*% X,
where P is constructed for example with P=table(seq(1,nrow(X)),sample(nrow(X), nrow(X))),
i.e., sampling without replacement to ensure disjointness.
- DRLocalScheme() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.DRLocalScheme
-
- dropAlternativePlan(CPlanMemoTable, CPlanMemoTable.MemoTableEntry, CPlanMemoTable.MemoTableEntry) - Static method in class org.apache.sysds.hops.codegen.template.TemplateOuterProduct
-
- dropInvalidType(FrameBlock) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Drop the cell value which does not confirms to the data type of its column
- dropLastRowsOrColumns(Types.CorrectionLocationType) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- DRRLocalScheme - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
-
Disjoint_Round_Robin data partitioner:
for each worker, use a permutation multiply
or simpler a removeEmpty such as removeEmpty
(target=X, margin=rows, select=(seq(1,nrow(X))%%k)==id)
- DRRLocalScheme() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.DRRLocalScheme
-
- DRRSparkScheme - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
-
Spark Disjoint_Round_Robin data partitioner:
- DRSparkScheme - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
-
Spark data partitioner Disjoint_Random:
For the current row block, find all the shifted place for each row (WorkerID => (row block ID, matrix)
- dxDesc - Variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNPoolingDescriptors
-
- dyDesc - Variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNPoolingDescriptors
-
- EAGER_CUDA_FREE - Static variable in class org.apache.sysds.api.DMLScript
-
- EAGER_CUDA_FREE - Static variable in class org.apache.sysds.conf.DMLConfig
-
- EC_BEGIN - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- EC_END - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- ELEMENT_DELIM - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- ELEMENT_DELIM2 - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- eliminateCommonSubexpressions(CNodeTpl) - Method in class org.apache.sysds.hops.codegen.template.CPlanCSERewriter
-
- elseBody - Variable in class org.apache.sysds.parser.dml.DmlParser.IfStatementContext
-
- EMPTY - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- EMPTY_TEXT_LINE - Static variable in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- enableCaching() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- enableCleanup(boolean) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
Enables or disables the cleanup of the associated
data object on clearData().
- enableColocatedPartitionedMatrix(String) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- enableFunctionRecompile(String, String...) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Enables function recompilation, selectively for the given functions.
- enableNative - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- encode(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.Encoder
-
Block encode: build and apply (transform encode).
- encode(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderBin
-
- encode(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderComposite
-
- encode(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderDummycode
-
- encode(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderFeatureHash
-
- encode(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
-
- encode(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
-
- encode(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderPassThrough
-
- encode(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderRecode
-
- encodeFederatedFrames(FederationMap, Encoder, MatrixObject) - Static method in class org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction
-
- Encoder - Class in org.apache.sysds.runtime.transform.encode
-
Base class for all transform encoders providing both a row and block
interface for decoding frames to matrices.
- EncoderBin - Class in org.apache.sysds.runtime.transform.encode
-
- EncoderBin(JSONObject, String[], int, int, int) - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderBin
-
- EncoderBin() - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderBin
-
- EncoderComposite - Class in org.apache.sysds.runtime.transform.encode
-
Simple composite encoder that applies a list of encoders
in specified order.
- EncoderComposite(List<Encoder>) - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderComposite
-
- EncoderDummycode - Class in org.apache.sysds.runtime.transform.encode
-
- EncoderDummycode(JSONObject, String[], int, int, int) - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderDummycode
-
- EncoderDummycode() - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderDummycode
-
- EncoderDummycode(int[], int, int[], long) - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderDummycode
-
- EncoderFactory - Class in org.apache.sysds.runtime.transform.encode
-
- EncoderFactory() - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderFactory
-
- EncoderFeatureHash - Class in org.apache.sysds.runtime.transform.encode
-
Class used for feature hashing transformation of frames.
- EncoderFeatureHash(JSONObject, String[], int, int, int) - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderFeatureHash
-
- EncoderFeatureHash(int[], int, long) - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderFeatureHash
-
- EncoderFeatureHash() - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderFeatureHash
-
- EncoderMVImpute - Class in org.apache.sysds.runtime.transform.encode
-
- EncoderMVImpute(JSONObject, String[], int, int, int) - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
-
- EncoderMVImpute() - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
-
- EncoderMVImpute(int[], EncoderMVImpute.MVMethod[], String[], KahanObject[], long[], List<Integer>, int) - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
-
- EncoderMVImpute.MVMethod - Enum in org.apache.sysds.runtime.transform.encode
-
- EncoderOmit - Class in org.apache.sysds.runtime.transform.encode
-
- EncoderOmit(JSONObject, String[], int, int, int) - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderOmit
-
- EncoderOmit() - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderOmit
-
- EncoderOmit(boolean) - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderOmit
-
- EncoderPassThrough - Class in org.apache.sysds.runtime.transform.encode
-
Simple composite encoder that applies a list of encoders
in specified order.
- EncoderPassThrough() - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderPassThrough
-
- EncoderRecode - Class in org.apache.sysds.runtime.transform.encode
-
- EncoderRecode(JSONObject, String[], int, int, int) - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderRecode
-
- EncoderRecode() - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderRecode
-
- end_indexes_h - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- end_indexes_w - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- enqueueTask(T) - Method in class org.apache.sysds.runtime.controlprogram.parfor.LocalTaskQueue
-
Synchronized insert of a new task to the end of the FIFO queue.
- ensureAllocatedColumns(int) - Method in class org.apache.sysds.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.sysds.runtime.matrix.data.FrameBlock
-
Checks for matching column sizes in case of existing columns.
- ensureComputeCapability() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Makes sure that GPU that SystemDS is trying to use has the minimum compute capability needed.
- enterAccumulatorAssignmentStatement(DmlParser.AccumulatorAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
Enter a parse tree produced by the
AccumulatorAssignmentStatement
labeled alternative in
DmlParser.statement()
.
- enterAccumulatorAssignmentStatement(DmlParser.AccumulatorAssignmentStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
Enter a parse tree produced by the
AccumulatorAssignmentStatement
labeled alternative in
DmlParser.statement()
.
- enterAccumulatorAssignmentStatement(DmlParser.AccumulatorAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterAccumulatorAssignmentStatement(DmlParser.AccumulatorAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterAddSubExpression(DmlParser.AddSubExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterAddSubExpression(DmlParser.AddSubExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterAddSubExpression(DmlParser.AddSubExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterAddSubExpression(DmlParser.AddSubExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterAssignmentStatement(DmlParser.AssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterAssignmentStatement(DmlParser.AssignmentStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterAssignmentStatement(DmlParser.AssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterAssignmentStatement(DmlParser.AssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterAtomicExpression(DmlParser.AtomicExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterAtomicExpression(DmlParser.AtomicExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterAtomicExpression(DmlParser.AtomicExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterAtomicExpression(DmlParser.AtomicExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterBooleanAndExpression(DmlParser.BooleanAndExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterBooleanAndExpression(DmlParser.BooleanAndExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterBooleanAndExpression(DmlParser.BooleanAndExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterBooleanAndExpression(DmlParser.BooleanAndExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterBooleanNotExpression(DmlParser.BooleanNotExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterBooleanNotExpression(DmlParser.BooleanNotExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterBooleanNotExpression(DmlParser.BooleanNotExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterBooleanNotExpression(DmlParser.BooleanNotExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterBooleanOrExpression(DmlParser.BooleanOrExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterBooleanOrExpression(DmlParser.BooleanOrExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterBooleanOrExpression(DmlParser.BooleanOrExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterBooleanOrExpression(DmlParser.BooleanOrExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterBuiltinFunctionExpression(DmlParser.BuiltinFunctionExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterBuiltinFunctionExpression(DmlParser.BuiltinFunctionExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterBuiltinFunctionExpression(DmlParser.BuiltinFunctionExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterBuiltinFunctionExpression(DmlParser.BuiltinFunctionExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterCommandlineParamExpression(DmlParser.CommandlineParamExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterCommandlineParamExpression(DmlParser.CommandlineParamExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterCommandlineParamExpression(DmlParser.CommandlineParamExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterCommandlineParamExpression(DmlParser.CommandlineParamExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterCommandlinePositionExpression(DmlParser.CommandlinePositionExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterCommandlinePositionExpression(DmlParser.CommandlinePositionExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterCommandlinePositionExpression(DmlParser.CommandlinePositionExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterCommandlinePositionExpression(DmlParser.CommandlinePositionExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterConstDoubleIdExpression(DmlParser.ConstDoubleIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterConstDoubleIdExpression(DmlParser.ConstDoubleIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterConstDoubleIdExpression(DmlParser.ConstDoubleIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterConstDoubleIdExpression(DmlParser.ConstDoubleIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterConstFalseExpression(DmlParser.ConstFalseExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterConstFalseExpression(DmlParser.ConstFalseExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterConstFalseExpression(DmlParser.ConstFalseExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterConstFalseExpression(DmlParser.ConstFalseExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterConstIntIdExpression(DmlParser.ConstIntIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterConstIntIdExpression(DmlParser.ConstIntIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterConstIntIdExpression(DmlParser.ConstIntIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterConstIntIdExpression(DmlParser.ConstIntIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterConstStringIdExpression(DmlParser.ConstStringIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterConstStringIdExpression(DmlParser.ConstStringIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterConstStringIdExpression(DmlParser.ConstStringIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterConstStringIdExpression(DmlParser.ConstStringIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterConstTrueExpression(DmlParser.ConstTrueExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterConstTrueExpression(DmlParser.ConstTrueExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterConstTrueExpression(DmlParser.ConstTrueExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterConstTrueExpression(DmlParser.ConstTrueExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterDataIdExpression(DmlParser.DataIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterDataIdExpression(DmlParser.DataIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterDataIdExpression(DmlParser.DataIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterDataIdExpression(DmlParser.DataIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterEveryRule(ParserRuleContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
- enterEveryRule(ParserRuleContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterEveryRule(ParserRuleContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterExternalFunctionDefExpression(DmlParser.ExternalFunctionDefExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterExternalFunctionDefExpression(DmlParser.ExternalFunctionDefExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterExternalFunctionDefExpression(DmlParser.ExternalFunctionDefExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterExternalFunctionDefExpression(DmlParser.ExternalFunctionDefExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterForStatement(DmlParser.ForStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterForStatement(DmlParser.ForStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterForStatement(DmlParser.ForStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterForStatement(DmlParser.ForStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterFunctionCallAssignmentStatement(DmlParser.FunctionCallAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
Enter a parse tree produced by the
FunctionCallAssignmentStatement
labeled alternative in
DmlParser.statement()
.
- enterFunctionCallAssignmentStatement(DmlParser.FunctionCallAssignmentStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
Enter a parse tree produced by the
FunctionCallAssignmentStatement
labeled alternative in
DmlParser.statement()
.
- enterFunctionCallAssignmentStatement(DmlParser.FunctionCallAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterFunctionCallAssignmentStatement(DmlParser.FunctionCallAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterFunctionCallMultiAssignmentStatement(DmlParser.FunctionCallMultiAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
Enter a parse tree produced by the
FunctionCallMultiAssignmentStatement
labeled alternative in
DmlParser.statement()
.
- enterFunctionCallMultiAssignmentStatement(DmlParser.FunctionCallMultiAssignmentStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
Enter a parse tree produced by the
FunctionCallMultiAssignmentStatement
labeled alternative in
DmlParser.statement()
.
- enterFunctionCallMultiAssignmentStatement(DmlParser.FunctionCallMultiAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterFunctionCallMultiAssignmentStatement(DmlParser.FunctionCallMultiAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterIfdefAssignmentStatement(DmlParser.IfdefAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
Enter a parse tree produced by the
IfdefAssignmentStatement
labeled alternative in
DmlParser.statement()
.
- enterIfdefAssignmentStatement(DmlParser.IfdefAssignmentStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
Enter a parse tree produced by the
IfdefAssignmentStatement
labeled alternative in
DmlParser.statement()
.
- enterIfdefAssignmentStatement(DmlParser.IfdefAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterIfdefAssignmentStatement(DmlParser.IfdefAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterIfStatement(DmlParser.IfStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterIfStatement(DmlParser.IfStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterIfStatement(DmlParser.IfStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterIfStatement(DmlParser.IfStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterImportStatement(DmlParser.ImportStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterImportStatement(DmlParser.ImportStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterImportStatement(DmlParser.ImportStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterImportStatement(DmlParser.ImportStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterIndexedExpression(DmlParser.IndexedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterIndexedExpression(DmlParser.IndexedExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterIndexedExpression(DmlParser.IndexedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterIndexedExpression(DmlParser.IndexedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterInternalFunctionDefExpression(DmlParser.InternalFunctionDefExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterInternalFunctionDefExpression(DmlParser.InternalFunctionDefExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterInternalFunctionDefExpression(DmlParser.InternalFunctionDefExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterInternalFunctionDefExpression(DmlParser.InternalFunctionDefExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterIterablePredicateColonExpression(DmlParser.IterablePredicateColonExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterIterablePredicateColonExpression(DmlParser.IterablePredicateColonExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterIterablePredicateColonExpression(DmlParser.IterablePredicateColonExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterIterablePredicateColonExpression(DmlParser.IterablePredicateColonExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterIterablePredicateSeqExpression(DmlParser.IterablePredicateSeqExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterIterablePredicateSeqExpression(DmlParser.IterablePredicateSeqExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterIterablePredicateSeqExpression(DmlParser.IterablePredicateSeqExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterIterablePredicateSeqExpression(DmlParser.IterablePredicateSeqExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterMatrixDataTypeCheck(DmlParser.MatrixDataTypeCheckContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterMatrixDataTypeCheck(DmlParser.MatrixDataTypeCheckContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterMatrixDataTypeCheck(DmlParser.MatrixDataTypeCheckContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterMatrixDataTypeCheck(DmlParser.MatrixDataTypeCheckContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterMatrixMulExpression(DmlParser.MatrixMulExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterMatrixMulExpression(DmlParser.MatrixMulExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterMatrixMulExpression(DmlParser.MatrixMulExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterMatrixMulExpression(DmlParser.MatrixMulExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterMl_type(DmlParser.Ml_typeContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterMl_type(DmlParser.Ml_typeContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterMl_type(DmlParser.Ml_typeContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterMl_type(DmlParser.Ml_typeContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterModIntDivExpression(DmlParser.ModIntDivExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterModIntDivExpression(DmlParser.ModIntDivExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterModIntDivExpression(DmlParser.ModIntDivExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterModIntDivExpression(DmlParser.ModIntDivExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterMultDivExpression(DmlParser.MultDivExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterMultDivExpression(DmlParser.MultDivExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterMultDivExpression(DmlParser.MultDivExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterMultDivExpression(DmlParser.MultDivExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterMultiIdExpression(DmlParser.MultiIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterMultiIdExpression(DmlParser.MultiIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterMultiIdExpression(DmlParser.MultiIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterMultiIdExpression(DmlParser.MultiIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterParameterizedExpression(DmlParser.ParameterizedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterParameterizedExpression(DmlParser.ParameterizedExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterParameterizedExpression(DmlParser.ParameterizedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterParameterizedExpression(DmlParser.ParameterizedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterParForStatement(DmlParser.ParForStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterParForStatement(DmlParser.ParForStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterParForStatement(DmlParser.ParForStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterParForStatement(DmlParser.ParForStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterPathStatement(DmlParser.PathStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterPathStatement(DmlParser.PathStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterPathStatement(DmlParser.PathStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterPathStatement(DmlParser.PathStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterPowerExpression(DmlParser.PowerExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterPowerExpression(DmlParser.PowerExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterPowerExpression(DmlParser.PowerExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterPowerExpression(DmlParser.PowerExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterProgramroot(DmlParser.ProgramrootContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterProgramroot(DmlParser.ProgramrootContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterProgramroot(DmlParser.ProgramrootContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterProgramroot(DmlParser.ProgramrootContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterRelationalExpression(DmlParser.RelationalExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterRelationalExpression(DmlParser.RelationalExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterRelationalExpression(DmlParser.RelationalExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterRelationalExpression(DmlParser.RelationalExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.AccumulatorAssignmentStatementContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.AddSubExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.AssignmentStatementContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.AtomicExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.BooleanAndExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.BooleanNotExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.BooleanOrExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.BuiltinFunctionExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.CommandlineParamExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.CommandlinePositionExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ConstDoubleIdExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ConstFalseExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ConstIntIdExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ConstStringIdExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ConstTrueExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.DataIdExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ExternalFunctionDefExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionCallAssignmentStatementContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionCallMultiAssignmentStatementContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.IfdefAssignmentStatementContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.IfStatementContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ImportStatementContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.IndexedExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateColonExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateSeqExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.MatrixDataTypeCheckContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.MatrixMulExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.Ml_typeContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ModIntDivExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.MultDivExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.MultiIdExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ParameterizedExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.PathStatementContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.PowerExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ProgramrootContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.RelationalExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.SimpleDataIdentifierExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.StrictParameterizedExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.StrictParameterizedKeyValueStringContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.TypedArgAssignContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.TypedArgNoAssignContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.UnaryExpressionContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ValueTypeContext
-
- enterRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.WhileStatementContext
-
- enterSimpleDataIdentifierExpression(DmlParser.SimpleDataIdentifierExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterSimpleDataIdentifierExpression(DmlParser.SimpleDataIdentifierExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterSimpleDataIdentifierExpression(DmlParser.SimpleDataIdentifierExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterSimpleDataIdentifierExpression(DmlParser.SimpleDataIdentifierExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterStrictParameterizedExpression(DmlParser.StrictParameterizedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterStrictParameterizedExpression(DmlParser.StrictParameterizedExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterStrictParameterizedExpression(DmlParser.StrictParameterizedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterStrictParameterizedExpression(DmlParser.StrictParameterizedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterStrictParameterizedKeyValueString(DmlParser.StrictParameterizedKeyValueStringContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterStrictParameterizedKeyValueString(DmlParser.StrictParameterizedKeyValueStringContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterStrictParameterizedKeyValueString(DmlParser.StrictParameterizedKeyValueStringContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterStrictParameterizedKeyValueString(DmlParser.StrictParameterizedKeyValueStringContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterTypedArgAssign(DmlParser.TypedArgAssignContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterTypedArgAssign(DmlParser.TypedArgAssignContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterTypedArgAssign(DmlParser.TypedArgAssignContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterTypedArgAssign(DmlParser.TypedArgAssignContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterTypedArgNoAssign(DmlParser.TypedArgNoAssignContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterTypedArgNoAssign(DmlParser.TypedArgNoAssignContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterTypedArgNoAssign(DmlParser.TypedArgNoAssignContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterTypedArgNoAssign(DmlParser.TypedArgNoAssignContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterUnaryExpression(DmlParser.UnaryExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterUnaryExpression(DmlParser.UnaryExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterUnaryExpression(DmlParser.UnaryExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterUnaryExpression(DmlParser.UnaryExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterValueType(DmlParser.ValueTypeContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterValueType(DmlParser.ValueTypeContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterValueType(DmlParser.ValueTypeContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterValueType(DmlParser.ValueTypeContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- enterWhileStatement(DmlParser.WhileStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- enterWhileStatement(DmlParser.WhileStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- enterWhileStatement(DmlParser.WhileStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- enterWhileStatement(DmlParser.WhileStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- entrySet() - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
-
- EnvironmentHelper - Class in org.apache.sysds.utils
-
This class is useful in setting environment variable for loading MKL library (done by Native Helper)
- EnvironmentHelper() - Constructor for class org.apache.sysds.utils.EnvironmentHelper
-
- EOF() - Method in class org.apache.sysds.parser.dml.DmlParser.ProgramrootContext
-
- equalPlanRefs(CPlanMemoTable.MemoTableEntry) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- equals(Object) - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- equals(Object) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeBinary
-
- equals(Object) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- equals(Object) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeData
-
- equals(Object) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
-
- equals(Object) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeNary
-
- equals(Object) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeOuterProduct
-
- equals(Object) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
-
- equals(Object) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTernary
-
- equals(Object) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
-
- equals(Object) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeUnary
-
- equals(Object) - Method in class org.apache.sysds.hops.codegen.opt.InterestingPoint
-
- equals(Object) - Method in class org.apache.sysds.hops.codegen.opt.PlanSelection.VisitMarkCost
-
- equals(Object) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- equals(Object) - Method in class org.apache.sysds.hops.codegen.template.TemplateBase
-
- equals(Object) - Method in class org.apache.sysds.hops.ipa.FunctionCallSizeInfo
-
- equals(Object) - Method in class org.apache.sysds.parser.DataIdentifier
-
- equals(Object) - Method in class org.apache.sysds.parser.Expression
-
- equals(Object) - Method in class org.apache.sysds.parser.ParForStatementBlock.ResultVar
-
- equals(Object) - Method in class org.apache.sysds.runtime.compress.cocode.PlanningCoCodingGroup.ColIndexes
-
- equals(Object) - Method in class org.apache.sysds.runtime.compress.cocode.PlanningCoCodingGroup
-
- equals(Object) - Method in class org.apache.sysds.runtime.compress.utils.DblArray
-
- equals(Object) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeTaggedMatrixIndexes
-
- equals(Object) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
-
- equals(Object) - Method in class org.apache.sysds.runtime.data.TensorIndexes
-
- Equals - Class in org.apache.sysds.runtime.functionobjects
-
- equals(Object) - Method in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
- equals(Object) - Method in class org.apache.sysds.runtime.instructions.cp.KahanObject
-
- equals(Object) - Method in class org.apache.sysds.runtime.instructions.spark.data.BlockPartitioner
-
- equals(Object) - Method in class org.apache.sysds.runtime.lineage.LineageItem
-
- equals(Object) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- equals(Object) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- equals(Object) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- equals(Object) - Method in class org.apache.sysds.runtime.matrix.data.MatrixIndexes
-
- equals(Object) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue.CellIndex
-
- equals(Object) - Method in class org.apache.sysds.runtime.matrix.data.TripleIndexes
-
- equals(Object) - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
-
- equals(Object) - Method in class org.apache.sysds.runtime.matrix.data.WeightedPair
-
- equals(Object) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- equals(Object) - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- equals(Object) - Method in class org.apache.sysds.runtime.meta.MetaData
-
- equals(Object) - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- equals(Object) - Method in class org.apache.sysds.runtime.privacy.finegrained.DataRange
-
- equals(Object) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyList
-
- equals(List<T>, List<T>) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
-
- ERROR_MSG_DELIMITER - Static variable in exception org.apache.sysds.api.DMLException
-
- errorPrint(Exception) - Static method in class org.apache.sysds.api.DMLScript
-
Print the error in a user friendly manner.
- estim(MMNode) - Method in class org.apache.sysds.hops.estim.EstimatorBasicAvg
-
- estim(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorBasicAvg
-
- estim(MatrixBlock, MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorBasicAvg
-
- estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorBasicAvg
-
- estim(MMNode) - Method in class org.apache.sysds.hops.estim.EstimatorBasicWorst
-
- estim(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorBasicWorst
-
- estim(MatrixBlock, MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorBasicWorst
-
- estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorBasicWorst
-
- estim(MMNode) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM
-
- estim(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM
-
- estim(MatrixBlock, MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM
-
- estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM
-
- estim(MMNode) - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap
-
- estim(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap
-
- estim(MatrixBlock, MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap
-
- estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap
-
- estim(MMNode) - Method in class org.apache.sysds.hops.estim.EstimatorLayeredGraph
-
- estim(MatrixBlock, MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorLayeredGraph
-
- estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorLayeredGraph
-
- estim(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorLayeredGraph
-
- estim(MMNode) - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram
-
- estim(MMNode, boolean) - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram
-
- estim(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram
-
- estim(MatrixBlock, MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram
-
- estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram
-
- estim(MMNode) - Method in class org.apache.sysds.hops.estim.EstimatorSample
-
- estim(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorSample
-
- estim(MatrixBlock, MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorSample
-
- estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorSample
-
- estim(MMNode) - Method in class org.apache.sysds.hops.estim.EstimatorSampleRa
-
- estim(MatrixBlock, MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorSampleRa
-
- estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorSampleRa
-
- estim(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorSampleRa
-
- estim(MMNode) - Method in class org.apache.sysds.hops.estim.SparsityEstimator
-
Estimates the output sparsity of a DAG of matrix multiplications
for the given operator graph of a single root node.
- estim(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.hops.estim.SparsityEstimator
-
Estimates the output sparsity for a single matrix multiplication.
- estim(MatrixBlock, MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.SparsityEstimator
-
Estimates the output sparsity for a given binary operation.
- estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.SparsityEstimator
-
Estimates the output sparsity for a given unary operation.
- estimateCompressedColGroupSize() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeEstimator
-
Method used for compressing into one type of colGroup
- estimateCompressedColGroupSize(int[]) - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeEstimator
-
Abstract method for extracting Compressed Size Info of specified columns, together in a single ColGroup
- estimateCompressedColGroupSize(ABitmap) - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeEstimator
-
Method used to extract the CompressedSizeEstimationFactors from an constructed UncompressedBitmap.
- estimateCompressedColGroupSize(int[]) - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeEstimatorExact
-
- estimateCompressedColGroupSize(int[]) - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeEstimatorSample
-
- estimateCompressedSizeInMemory() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
Obtain an upper bound on the memory used to store the compressed block.
- estimateDistinctValues(MatrixBlock, CountDistinctOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCountDistinct
-
Public method to count the number of distinct values inside a matrix.
- estimatedNonZeros - Variable in class org.apache.sysds.runtime.matrix.data.MatrixBlock.SparsityEstimate
-
- estimatedSizeColGroups - Variable in class org.apache.sysds.runtime.compress.CompressionStatistics
-
- estimatedSizeCols - Variable in class org.apache.sysds.runtime.compress.CompressionStatistics
-
- estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Note: Must be overridden by child classes to account for additional data and metadata
- estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC1
-
- estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC2
-
- estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOffset
-
- estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
- estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- estimateInMemorySizeDDC(int, int, boolean) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
-
- estimateInMemorySizeDDC1(int, int, int, boolean) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
-
- estimateInMemorySizeDDC2(int, int, int, boolean) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
-
- estimateInMemorySizeGroup(int) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
-
- estimateInMemorySizeGroupValue(int, int, boolean) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
-
- estimateInMemorySizeOffset(int, int, int, int, boolean) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
-
- estimateInMemorySizeOLE(int, int, int, int, boolean) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
-
- estimateInMemorySizeRLE(int, int, int, int, boolean) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
-
- estimateInMemorySizeUncompressed(int, int, double) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
-
- estimateMemory(long, long, double) - Static method in class org.apache.sysds.runtime.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.sysds.runtime.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.sysds.runtime.data.SparseBlockMCSR
-
Get the estimated in-memory size of the sparse block in MCSR
with the given dimensions w/o accounting for overallocation.
- estimateNnz() - Method in class org.apache.sysds.hops.estim.EstimatorLayeredGraph.LayeredGraph
-
- estimateNnzBasedOnFileSize(Path, long, long, int, double) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- estimateOriginalSizeInMemory(int, int, double) - Static method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- estimatePartitionedSizeExactSparsity(DataCharacteristics) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Estimates the footprint (in bytes) for a partitioned in-memory representation of a
matrix with the given matrix characteristics
- estimatePartitionedSizeExactSparsity(long, long, long, long) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Estimates the footprint (in bytes) for a partitioned in-memory representation of a
matrix with dimensions=(nrows,ncols) and number of non-zeros nnz.
- estimatePartitionedSizeExactSparsity(long, long, long, double) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Estimates the footprint (in bytes) for a partitioned in-memory representation of a
matrix with dimensions=(nrows,ncols) and sparsity=sp.
- estimateSize(DataCharacteristics) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- estimateSize(long, long) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Similar to estimate() except that it provides worst-case estimates
when the optimization type is ROBUST.
- estimateSize(long, long) - Static method in class org.apache.sysds.runtime.instructions.gpu.context.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.sysds.runtime.matrix.data.MatrixBlock
-
- estimateSizeEmptyBlock(long, long) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- estimateSizeExactSparsity(DataCharacteristics) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- estimateSizeExactSparsity(long, long, long) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Estimates the footprint (in bytes) for an in-memory representation of a
matrix with dimensions=(nrows,ncols) and and number of non-zeros nnz.
- estimateSizeExactSparsity(long, long, double) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Estimates the footprint (in bytes) for an in-memory representation of a
matrix with dimensions=(nrows,ncols) and sparsity=sp.
- estimateSizeInMemory() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- estimateSizeInMemory(long, long, double) - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- estimateSizeOnDisk() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- estimateSizeOnDisk(long, long, long) - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- estimateSizeSparseInMemory(SparseBlock.Type, long, long, double) - Static method in class org.apache.sysds.runtime.data.SparseBlockFactory
-
- estimateSizeSparseInMemory(long, long, double) - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- estimateSizeSparseInMemory(long, long, double, SparseBlock.Type) - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- estimateSizeTextOutput(long, long, long, Types.FileFormat) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- estimateSizeTextOutput(int[], long, Types.FileFormat) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- estimateSparsityOnAggBinary(MatrixBlock, MatrixBlock, AggregateBinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- EstimationFactors - Class in org.apache.sysds.runtime.compress.estim
-
Compressed Size Estimation factors.
- EstimationUtils - Class in org.apache.sysds.hops.estim
-
- EstimationUtils() - Constructor for class org.apache.sysds.hops.estim.EstimationUtils
-
- EstimatorBasicAvg - Class in org.apache.sysds.hops.estim
-
Basic average case estimator for matrix sparsity:
sp = 1 - Math.pow(1-sp1*sp2, k)
- EstimatorBasicAvg() - Constructor for class org.apache.sysds.hops.estim.EstimatorBasicAvg
-
- EstimatorBasicWorst - Class in org.apache.sysds.hops.estim
-
Basic average case estimator for matrix sparsity:
sp = Math.min(1, sp1 * k) * Math.min(1, sp2 * k).
- EstimatorBasicWorst() - Constructor for class org.apache.sysds.hops.estim.EstimatorBasicWorst
-
- EstimatorBitsetMM - Class in org.apache.sysds.hops.estim
-
This estimator implements a naive but rather common approach of boolean matrix
multiplies which allows to infer the exact non-zero structure and thus is
also useful for sparse result preallocation.
- EstimatorBitsetMM() - Constructor for class org.apache.sysds.hops.estim.EstimatorBitsetMM
-
- EstimatorBitsetMM.BitsetMatrix - Class in org.apache.sysds.hops.estim
-
- EstimatorBitsetMM.BitsetMatrix1 - Class in org.apache.sysds.hops.estim
-
This class represents a boolean matrix and provides key operations.
- EstimatorBitsetMM.BitsetMatrix2 - Class in org.apache.sysds.hops.estim
-
- EstimatorDensityMap - Class in org.apache.sysds.hops.estim
-
This estimator implements an approach called density maps, as introduced in
David Kernert, Frank Köhler, Wolfgang Lehner: SpMacho - Optimizing Sparse
Linear Algebra Expressions with Probabilistic Density Estimation.
- EstimatorDensityMap() - Constructor for class org.apache.sysds.hops.estim.EstimatorDensityMap
-
- EstimatorDensityMap(int) - Constructor for class org.apache.sysds.hops.estim.EstimatorDensityMap
-
- EstimatorDensityMap.DensityMap - Class in org.apache.sysds.hops.estim
-
- EstimatorLayeredGraph - Class in org.apache.sysds.hops.estim
-
This estimator implements an approach based on a so-called layered graph,
introduced in
Edith Cohen.
- EstimatorLayeredGraph() - Constructor for class org.apache.sysds.hops.estim.EstimatorLayeredGraph
-
- EstimatorLayeredGraph(int) - Constructor for class org.apache.sysds.hops.estim.EstimatorLayeredGraph
-
- EstimatorLayeredGraph.LayeredGraph - Class in org.apache.sysds.hops.estim
-
- EstimatorMatrixHistogram - Class in org.apache.sysds.hops.estim
-
This estimator implements a remarkably simple yet effective
approach for incorporating structural properties into sparsity
estimation.
- EstimatorMatrixHistogram() - Constructor for class org.apache.sysds.hops.estim.EstimatorMatrixHistogram
-
- EstimatorMatrixHistogram(boolean) - Constructor for class org.apache.sysds.hops.estim.EstimatorMatrixHistogram
-
- EstimatorMatrixHistogram.MatrixHistogram - Class in org.apache.sysds.hops.estim
-
- EstimatorSample - Class in org.apache.sysds.hops.estim
-
This estimator implements an approach based on row/column sampling
Yongyang Yu, MingJie Tang, Walid G.
- EstimatorSample() - Constructor for class org.apache.sysds.hops.estim.EstimatorSample
-
- EstimatorSample(double) - Constructor for class org.apache.sysds.hops.estim.EstimatorSample
-
- EstimatorSample(double, boolean) - Constructor for class org.apache.sysds.hops.estim.EstimatorSample
-
- EstimatorSampleRa - Class in org.apache.sysds.hops.estim
-
This estimator implements an approach based on row/column sampling
Rasmus Resen Amossen, Andrea Campagna, Rasmus Pagh:
Better Size Estimation for Sparse Matrix Products.
- EstimatorSampleRa() - Constructor for class org.apache.sysds.hops.estim.EstimatorSampleRa
-
- EstimatorSampleRa(double) - Constructor for class org.apache.sysds.hops.estim.EstimatorSampleRa
-
- EstimatorSampleRa(int, double, double, double, int) - Constructor for class org.apache.sysds.hops.estim.EstimatorSampleRa
-
- estimIntern(EstimatorDensityMap.DensityMap, EstimatorDensityMap.DensityMap, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap
-
Computes the output density map given the density maps of the input operands.
- estimIntern(EstimatorMatrixHistogram.MatrixHistogram, EstimatorMatrixHistogram.MatrixHistogram, SparsityEstimator.OpCode, long[]) - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram
-
- EvalNaryCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
Eval built-in function instruction
Note: it supports only single matrix[double] output
- EvalNaryCPInstruction(Operator, String, String, CPOperand, CPOperand...) - Constructor for class org.apache.sysds.runtime.instructions.cp.EvalNaryCPInstruction
-
- evalSparseFormatInMemory() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Evaluates if this matrix block should be in sparse format in
memory.
- evalSparseFormatInMemory(DataCharacteristics) - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- evalSparseFormatInMemory(long, long, long) - Static method in class org.apache.sysds.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.sysds.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.sysds.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).
- evictBuffer(String) - Method in class org.apache.sysds.runtime.controlprogram.caching.ByteBuffer
-
- EVICTION_SHADOW_BUFFER_CURR_BYTES - Static variable in class org.apache.sysds.api.DMLScript
-
- EVICTION_SHADOW_BUFFER_MAX_BYTES - Static variable in class org.apache.sysds.api.DMLScript
-
- EVICTION_SHADOW_BUFFERSIZE - Static variable in class org.apache.sysds.conf.DMLConfig
-
- EvictionPolicyBasedComparator(long) - Constructor for class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryManager.EvictionPolicyBasedComparator
-
- examSparsity() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- examSparsity(boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Evaluates if this matrix block should be in sparse format in
memory.
- examSparsityTime - Static variable in class org.apache.sysds.utils.Statistics
-
- exceedsCachingThreshold(long, double) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Indicates if the given matrix characteristics exceed the threshold for
caching, i.e., the matrix should be cached.
- except(List<T>, List<T>) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
-
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedWorkerHandler
-
- exchangeChild(OptNode, OptNode) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- EXEC_MODE - Static variable in class org.apache.sysds.parser.ParForStatementBlock
-
- EXEC_TIME_THRESHOLD - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerHeuristic
-
- execCleanup(long, long...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- execMode - Variable in class org.apache.sysds.api.DMLOptions
-
- execute(Script) - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Execute a DML or PYDML Script.
- execute(Script, ScriptExecutor) - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Execute a DML or PYDML Script object using a ScriptExecutor.
- execute() - Method in class org.apache.sysds.api.mlcontext.Script
-
Execute the script and return the results as an MLResults object.
- execute(Script) - Method in class org.apache.sysds.api.mlcontext.ScriptExecutor
-
Execute a DML or PYDML script.
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, int) - Method in class org.apache.sysds.runtime.codegen.SpoofCellwise
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, int, long) - Method in class org.apache.sysds.runtime.codegen.SpoofCellwise
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock) - Method in class org.apache.sysds.runtime.codegen.SpoofCellwise
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock, int) - Method in class org.apache.sysds.runtime.codegen.SpoofCellwise
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock, int, long) - Method in class org.apache.sysds.runtime.codegen.SpoofCellwise
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock) - Method in class org.apache.sysds.runtime.codegen.SpoofMultiAggregate
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock, int) - Method in class org.apache.sysds.runtime.codegen.SpoofMultiAggregate
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock, int, long) - Method in class org.apache.sysds.runtime.codegen.SpoofMultiAggregate
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock) - Method in class org.apache.sysds.runtime.codegen.SpoofOperator
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock, int) - Method in class org.apache.sysds.runtime.codegen.SpoofOperator
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>) - Method in class org.apache.sysds.runtime.codegen.SpoofOperator
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, int) - Method in class org.apache.sysds.runtime.codegen.SpoofOperator
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>) - Method in class org.apache.sysds.runtime.codegen.SpoofOuterProduct
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, int) - Method in class org.apache.sysds.runtime.codegen.SpoofOuterProduct
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock) - Method in class org.apache.sysds.runtime.codegen.SpoofOuterProduct
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock, int) - Method in class org.apache.sysds.runtime.codegen.SpoofOuterProduct
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, int) - Method in class org.apache.sysds.runtime.codegen.SpoofRowwise
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock) - Method in class org.apache.sysds.runtime.codegen.SpoofRowwise
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock, boolean, boolean, long) - Method in class org.apache.sysds.runtime.codegen.SpoofRowwise
-
- execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock, int) - Method in class org.apache.sysds.runtime.codegen.SpoofRowwise
-
- execute(ExecutionContext) - Method in class org.apache.sysds.runtime.controlprogram.BasicProgramBlock
-
- execute(ExecutionContext, Data...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedUDF
-
Execute the user-defined function on a set of data objects
(e.g., matrix objects, frame objects, or scalars), which are
looked up by specified input IDs and passed in the same order.
- execute(long, FederatedRequest...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- execute(long, boolean, FederatedRequest...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- execute(long, FederatedRequest[], FederatedRequest...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- execute(long, boolean, FederatedRequest[], FederatedRequest...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- execute(ExecutionContext) - Method in class org.apache.sysds.runtime.controlprogram.ForProgramBlock
-
- execute(ExecutionContext) - Method in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
-
- execute(ExecutionContext) - Method in class org.apache.sysds.runtime.controlprogram.IfProgramBlock
-
- execute(ExecutionContext) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- execute(ExecutionContext) - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- execute(ExecutionContext) - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
Executes this program block (incl recompilation if required).
- execute(ExecutionContext) - Method in class org.apache.sysds.runtime.controlprogram.WhileProgramBlock
-
- execute(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.And
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.And
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.BitwAnd
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.BitwAnd
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.BitwOr
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.BitwOr
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.BitwShiftL
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.BitwShiftL
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.BitwShiftR
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.BitwShiftR
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.BitwXor
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.BitwXor
-
- execute(double) - Method in class org.apache.sysds.runtime.functionobjects.Builtin
-
- execute(long) - Method in class org.apache.sysds.runtime.functionobjects.Builtin
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Builtin
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Builtin
-
- execute(String) - Method in class org.apache.sysds.runtime.functionobjects.Builtin
-
- execute(Data, double) - Method in class org.apache.sysds.runtime.functionobjects.CM
-
Special case for weights w2==1
- execute(Data, double, double) - Method in class org.apache.sysds.runtime.functionobjects.CM
-
General case for arbitrary weights w2
- execute(Data, Data) - Method in class org.apache.sysds.runtime.functionobjects.CM
-
Combining stats from two partitions of the data.
- execute(Data, double, double, double) - Method in class org.apache.sysds.runtime.functionobjects.COV
-
General case for arbitrary weights w2
- execute(Data, double, double) - Method in class org.apache.sysds.runtime.functionobjects.COV
-
Special case for weights w2==1
- execute(Data, Data) - Method in class org.apache.sysds.runtime.functionobjects.COV
-
- execute(double, double, double, boolean, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.functionobjects.CTable
-
- execute(double, double, double, boolean, CTableMap) - Method in class org.apache.sysds.runtime.functionobjects.CTable
-
- execute(double, double, double, boolean, MatrixBlock) - Method in class org.apache.sysds.runtime.functionobjects.CTable
-
- execute(int, double, double, int, MatrixBlock) - Method in class org.apache.sysds.runtime.functionobjects.CTable
-
- execute(long, double, double) - Method in class org.apache.sysds.runtime.functionobjects.CTable
-
- execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.DiagIndex
-
- execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.DiagIndex
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Divide
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Divide
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Equals
-
execute() method that returns double is required since current map-reduce
runtime can only produce matrices of doubles.
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
-
- execute(double) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
-
- execute(long) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
-
- execute(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
-
- execute(boolean) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
-
- execute(HashMap<String, String>) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
-
- execute(Data, double) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
-
- execute(Data, double, double) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
-
- execute(Data, Data) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
-
- execute(String) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
-
- execute(String, String) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThan
-
execute() method that returns double is required since current map-reduce
runtime can only produce matrices of doubles.
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThanEquals
-
execute() method that returns double is required since current map-reduce
runtime can only produce matrices of doubles.
- execute(double, double, double) - Method in class org.apache.sysds.runtime.functionobjects.IfElse
-
- execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.IndexFunction
-
- execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.IndexFunction
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.IntegerDivide
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.IntegerDivide
-
- execute(Data, double) - Method in class org.apache.sysds.runtime.functionobjects.KahanPlus
-
- execute(Data, double, double) - Method in class org.apache.sysds.runtime.functionobjects.KahanPlus
-
- execute(Data, double) - Method in class org.apache.sysds.runtime.functionobjects.KahanPlusSq
-
Square the given term, then add to the existing sum using
the Kahan summation algorithm.
- execute(Data, double, double) - Method in class org.apache.sysds.runtime.functionobjects.KahanPlusSq
-
Add the given sum and correction factor to the existing
sum in the KahanObject using the Kahan summation algorithm.
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.LessThan
-
execute() method that returns double is required since current map-reduce
runtime can only produce matrices of doubles.
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.LessThanEquals
-
execute() method that returns double is required since current map-reduce
runtime can only produce matrices of doubles.
- execute(Data, double, double) - Method in class org.apache.sysds.runtime.functionobjects.Mean
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Minus
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Minus
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Minus1Multiply
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Minus1Multiply
-
- execute(double, double, double) - Method in class org.apache.sysds.runtime.functionobjects.MinusMultiply
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.MinusMultiply
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.MinusNz
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.MinusNz
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Modulus
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Modulus
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Multiply
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Multiply
-
- execute(double) - Method in class org.apache.sysds.runtime.functionobjects.Multiply2
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Multiply2
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Multiply2
-
- execute(boolean) - Method in class org.apache.sysds.runtime.functionobjects.Not
-
- execute(double) - Method in class org.apache.sysds.runtime.functionobjects.Not
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.NotEquals
-
execute() method that returns double is required since current map-reduce
runtime can only produce matrices of doubles.
- execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.OffsetColumnIndex
-
- execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.OffsetColumnIndex
-
- execute(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.Or
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Or
-
- execute(HashMap<String, String>) - Method in class org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Plus
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Plus
-
- execute(String, String) - Method in class org.apache.sysds.runtime.functionobjects.Plus
-
- execute(double, double, double) - Method in class org.apache.sysds.runtime.functionobjects.PlusMultiply
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.PlusMultiply
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Power
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Power
-
- execute(double) - Method in class org.apache.sysds.runtime.functionobjects.Power2
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Power2
-
- execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Power2
-
- execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.ReduceAll
-
- execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.ReduceAll
-
- execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.ReduceCol
-
- execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.ReduceCol
-
- execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.ReduceDiag
-
- execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.ReduceDiag
-
- execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.ReduceRow
-
- execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.ReduceRow
-
- execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.RevIndex
-
- execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.RevIndex
-
- execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.SortIndex
-
- execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.SortIndex
-
- execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.SwapIndex
-
- execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.SwapIndex
-
- execute(double, double, double) - Method in class org.apache.sysds.runtime.functionobjects.TernaryValueFunction
-
- execute(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.Xor
-
- execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Xor
-
- execute(ExecutionContext, Data...) - Method in class org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction.CreateFrameEncoder
-
- execute(ExecutionContext, Data...) - Method in class org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction.ExecuteFrameEncoder
-
- execute(ExecutionContext, Data...) - Method in class org.apache.sysds.runtime.instructions.fed.ParameterizedBuiltinFEDInstruction.DecodeMatrix
-
- execute(int, int) - Method in interface org.apache.sysds.runtime.matrix.data.LibMatrixDNNRotate180.Rotate180Worker
-
- execute(Runnable) - Method in class org.apache.sysds.runtime.util.CommonThreadPool
-
- execute2(KahanObject, double) - Method in class org.apache.sysds.runtime.functionobjects.KahanFunction
-
Add the given term to the existing sum with a function applied
using the Kahan summation algorithm.
- execute2(KahanObject, double) - Method in class org.apache.sysds.runtime.functionobjects.KahanPlus
-
Simplified version of execute(Data in1, double in2)
without exception handling and casts.
- execute2(KahanObject, double) - Method in class org.apache.sysds.runtime.functionobjects.KahanPlusSq
-
- execute2(KahanObject, double, double) - Method in class org.apache.sysds.runtime.functionobjects.Mean
-
Simplified version of execute(Data in1, double in2)
without exception handling and casts.
- execute3(KahanObject, double, int) - Method in class org.apache.sysds.runtime.functionobjects.KahanFunction
-
- execute3(KahanObject, double, int) - Method in class org.apache.sysds.runtime.functionobjects.KahanPlus
-
- execute3(KahanObject, double, int) - Method in class org.apache.sysds.runtime.functionobjects.KahanPlusSq
-
- executeFederatedOperation(FederatedRequest...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
-
- executeFederatedOperation(InetSocketAddress, FederatedRequest...) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
-
Executes an federated operation on a federated worker.
- executeFederatedOperation(FederatedRequest...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedLocalData
-
- ExecuteFrameEncoder(long, long, Encoder) - Constructor for class org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction.ExecuteFrameEncoder
-
- executeInMemoryFrameReblock(ExecutionContext, String, String) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- executeInMemoryMatrixReblock(ExecutionContext, String, String) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- executeParallelMerge(int) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMerge
-
Merge all given input matrices in parallel into the given output matrix.
- executeParallelMerge(int) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeLocalAutomatic
-
- executeParallelMerge(int) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeLocalFile
-
- executeParallelMerge(int) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeLocalMemory
-
- executeParallelMerge(int) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeRemoteSpark
-
- executeParallelMerge(int) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeRemoteSparkWCompare
-
- executePredicate(ArrayList<Instruction>, Hop, boolean, Types.ValueType, ExecutionContext) - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
Executes given predicate instructions (incl recompilation if required)
- executeRewrites(Instruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageRewriteReuse
-
- executeRuntimeProgram(ScriptExecutor, int) - Static method in class org.apache.sysds.api.ScriptExecutorUtils
-
Execute the runtime program.
- executeRuntimeProgram(Program, ExecutionContext, DMLConfig, int, Set<String>) - Static method in class org.apache.sysds.api.ScriptExecutorUtils
-
Execute the runtime program.
- executeScalar(double) - Method in class org.apache.sysds.runtime.matrix.operators.LeftScalarOperator
-
- executeScalar(double) - Method in class org.apache.sysds.runtime.matrix.operators.RightScalarOperator
-
- executeScalar(double) - Method in class org.apache.sysds.runtime.matrix.operators.ScalarOperator
-
Apply the scalar operator over a given input value.
- executeScript(Configuration, String[]) - Static method in class org.apache.sysds.api.DMLScript
-
Single entry point for all public invocation alternatives (e.g.,
main, executeScript, JaqlUdf etc)
- executeScript() - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Executes the prepared script over the bound inputs, creating the
result variables according to bound and registered outputs.
- executeSerialMerge() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMerge
-
Merge all given input matrices sequentially into the given output matrix.
- executeSerialMerge() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeLocalAutomatic
-
- executeSerialMerge() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeLocalFile
-
- executeSerialMerge() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeLocalMemory
-
- executeSerialMerge() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeRemoteSpark
-
- executeSerialMerge() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeRemoteSparkWCompare
-
- ExecutionConfig - Class in org.apache.sysds.runtime.instructions.gpu.context
-
Java Wrapper to specify CUDA execution configuration for launching custom kernels
- ExecutionConfig(int, int, int) - Constructor for class org.apache.sysds.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.sysds.runtime.instructions.gpu.context.ExecutionConfig
-
Convenience constructor for setting the number of blocks, number of threads and the
shared memory size
- ExecutionConfig(int, int, int, int) - Constructor for class org.apache.sysds.runtime.instructions.gpu.context.ExecutionConfig
-
Convenience constructor for setting the number of blocks, number of threads and the
shared memory size
- ExecutionConfig(int, int, int, int, int) - Constructor for class org.apache.sysds.runtime.instructions.gpu.context.ExecutionConfig
-
Convenience constructor for setting the number of blocks, number of threads and the
shared memory size
- ExecutionContext - Class in org.apache.sysds.runtime.controlprogram.context
-
- ExecutionContext(LocalVariableMap) - Constructor for class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- ExecutionContextFactory - Class in org.apache.sysds.runtime.controlprogram.context
-
- ExecutionContextFactory() - Constructor for class org.apache.sysds.runtime.controlprogram.context.ExecutionContextFactory
-
- ExecutionContextMap - Class in org.apache.sysds.runtime.controlprogram.federated
-
- ExecutionContextMap() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.ExecutionContextMap
-
- existsCorrection() - Method in class org.apache.sysds.runtime.matrix.operators.AggregateOperator
-
- existsFileOnHDFS(String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- exitAccumulatorAssignmentStatement(DmlParser.AccumulatorAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
Exit a parse tree produced by the
AccumulatorAssignmentStatement
labeled alternative in
DmlParser.statement()
.
- exitAccumulatorAssignmentStatement(DmlParser.AccumulatorAssignmentStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
Exit a parse tree produced by the
AccumulatorAssignmentStatement
labeled alternative in
DmlParser.statement()
.
- exitAccumulatorAssignmentStatement(DmlParser.AccumulatorAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitAccumulatorAssignmentStatement(DmlParser.AccumulatorAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitAddSubExpression(DmlParser.AddSubExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitAddSubExpression(DmlParser.AddSubExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitAddSubExpression(DmlParser.AddSubExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitAddSubExpression(DmlParser.AddSubExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitAssignmentStatement(DmlParser.AssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitAssignmentStatement(DmlParser.AssignmentStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitAssignmentStatement(DmlParser.AssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitAssignmentStatement(DmlParser.AssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitAtomicExpression(DmlParser.AtomicExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitAtomicExpression(DmlParser.AtomicExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitAtomicExpression(DmlParser.AtomicExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitAtomicExpression(DmlParser.AtomicExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitBooleanAndExpression(DmlParser.BooleanAndExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitBooleanAndExpression(DmlParser.BooleanAndExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitBooleanAndExpression(DmlParser.BooleanAndExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitBooleanAndExpression(DmlParser.BooleanAndExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitBooleanNotExpression(DmlParser.BooleanNotExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitBooleanNotExpression(DmlParser.BooleanNotExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitBooleanNotExpression(DmlParser.BooleanNotExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitBooleanNotExpression(DmlParser.BooleanNotExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitBooleanOrExpression(DmlParser.BooleanOrExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitBooleanOrExpression(DmlParser.BooleanOrExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitBooleanOrExpression(DmlParser.BooleanOrExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitBooleanOrExpression(DmlParser.BooleanOrExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitBuiltinFunctionExpression(DmlParser.BuiltinFunctionExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitBuiltinFunctionExpression(DmlParser.BuiltinFunctionExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitBuiltinFunctionExpression(DmlParser.BuiltinFunctionExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitBuiltinFunctionExpression(DmlParser.BuiltinFunctionExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitCommandlineParamExpression(DmlParser.CommandlineParamExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitCommandlineParamExpression(DmlParser.CommandlineParamExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitCommandlineParamExpression(DmlParser.CommandlineParamExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitCommandlineParamExpression(DmlParser.CommandlineParamExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitCommandlinePositionExpression(DmlParser.CommandlinePositionExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitCommandlinePositionExpression(DmlParser.CommandlinePositionExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitCommandlinePositionExpression(DmlParser.CommandlinePositionExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitCommandlinePositionExpression(DmlParser.CommandlinePositionExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitConstDoubleIdExpression(DmlParser.ConstDoubleIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitConstDoubleIdExpression(DmlParser.ConstDoubleIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitConstDoubleIdExpression(DmlParser.ConstDoubleIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitConstDoubleIdExpression(DmlParser.ConstDoubleIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitConstFalseExpression(DmlParser.ConstFalseExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitConstFalseExpression(DmlParser.ConstFalseExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitConstFalseExpression(DmlParser.ConstFalseExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitConstFalseExpression(DmlParser.ConstFalseExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitConstIntIdExpression(DmlParser.ConstIntIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitConstIntIdExpression(DmlParser.ConstIntIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitConstIntIdExpression(DmlParser.ConstIntIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitConstIntIdExpression(DmlParser.ConstIntIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitConstStringIdExpression(DmlParser.ConstStringIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitConstStringIdExpression(DmlParser.ConstStringIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitConstStringIdExpression(DmlParser.ConstStringIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitConstStringIdExpression(DmlParser.ConstStringIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitConstTrueExpression(DmlParser.ConstTrueExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitConstTrueExpression(DmlParser.ConstTrueExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitConstTrueExpression(DmlParser.ConstTrueExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitConstTrueExpression(DmlParser.ConstTrueExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitDataIdExpression(DmlParser.DataIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitDataIdExpression(DmlParser.DataIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitDataIdExpression(DmlParser.DataIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitDataIdExpression(DmlParser.DataIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitEveryRule(ParserRuleContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
- exitEveryRule(ParserRuleContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitEveryRule(ParserRuleContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitExternalFunctionDefExpression(DmlParser.ExternalFunctionDefExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitExternalFunctionDefExpression(DmlParser.ExternalFunctionDefExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitExternalFunctionDefExpression(DmlParser.ExternalFunctionDefExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitExternalFunctionDefExpression(DmlParser.ExternalFunctionDefExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitForStatement(DmlParser.ForStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitForStatement(DmlParser.ForStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitForStatement(DmlParser.ForStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitForStatement(DmlParser.ForStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitFunctionCallAssignmentStatement(DmlParser.FunctionCallAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
Exit a parse tree produced by the
FunctionCallAssignmentStatement
labeled alternative in
DmlParser.statement()
.
- exitFunctionCallAssignmentStatement(DmlParser.FunctionCallAssignmentStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
Exit a parse tree produced by the
FunctionCallAssignmentStatement
labeled alternative in
DmlParser.statement()
.
- exitFunctionCallAssignmentStatement(DmlParser.FunctionCallAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitFunctionCallAssignmentStatement(DmlParser.FunctionCallAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitFunctionCallMultiAssignmentStatement(DmlParser.FunctionCallMultiAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
Exit a parse tree produced by the
FunctionCallMultiAssignmentStatement
labeled alternative in
DmlParser.statement()
.
- exitFunctionCallMultiAssignmentStatement(DmlParser.FunctionCallMultiAssignmentStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
Exit a parse tree produced by the
FunctionCallMultiAssignmentStatement
labeled alternative in
DmlParser.statement()
.
- exitFunctionCallMultiAssignmentStatement(DmlParser.FunctionCallMultiAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitFunctionCallMultiAssignmentStatement(DmlParser.FunctionCallMultiAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitIfdefAssignmentStatement(DmlParser.IfdefAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitIfdefAssignmentStatement(DmlParser.IfdefAssignmentStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitIfdefAssignmentStatement(DmlParser.IfdefAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitIfdefAssignmentStatement(DmlParser.IfdefAssignmentStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitIfStatement(DmlParser.IfStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitIfStatement(DmlParser.IfStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitIfStatement(DmlParser.IfStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitIfStatement(DmlParser.IfStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitImportStatement(DmlParser.ImportStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitImportStatement(DmlParser.ImportStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitImportStatement(DmlParser.ImportStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitImportStatement(DmlParser.ImportStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitIndexedExpression(DmlParser.IndexedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitIndexedExpression(DmlParser.IndexedExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitIndexedExpression(DmlParser.IndexedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitIndexedExpression(DmlParser.IndexedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
DML uses 1-based indexing.;
- exitInternalFunctionDefExpression(DmlParser.InternalFunctionDefExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitInternalFunctionDefExpression(DmlParser.InternalFunctionDefExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitInternalFunctionDefExpression(DmlParser.InternalFunctionDefExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitInternalFunctionDefExpression(DmlParser.InternalFunctionDefExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitIterablePredicateColonExpression(DmlParser.IterablePredicateColonExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitIterablePredicateColonExpression(DmlParser.IterablePredicateColonExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitIterablePredicateColonExpression(DmlParser.IterablePredicateColonExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitIterablePredicateColonExpression(DmlParser.IterablePredicateColonExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitIterablePredicateSeqExpression(DmlParser.IterablePredicateSeqExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitIterablePredicateSeqExpression(DmlParser.IterablePredicateSeqExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitIterablePredicateSeqExpression(DmlParser.IterablePredicateSeqExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitIterablePredicateSeqExpression(DmlParser.IterablePredicateSeqExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitMatrixDataTypeCheck(DmlParser.MatrixDataTypeCheckContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitMatrixDataTypeCheck(DmlParser.MatrixDataTypeCheckContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitMatrixDataTypeCheck(DmlParser.MatrixDataTypeCheckContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitMatrixDataTypeCheck(DmlParser.MatrixDataTypeCheckContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitMatrixMulExpression(DmlParser.MatrixMulExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitMatrixMulExpression(DmlParser.MatrixMulExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitMatrixMulExpression(DmlParser.MatrixMulExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitMatrixMulExpression(DmlParser.MatrixMulExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitMl_type(DmlParser.Ml_typeContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitMl_type(DmlParser.Ml_typeContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitMl_type(DmlParser.Ml_typeContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitMl_type(DmlParser.Ml_typeContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitModIntDivExpression(DmlParser.ModIntDivExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitModIntDivExpression(DmlParser.ModIntDivExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitModIntDivExpression(DmlParser.ModIntDivExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitModIntDivExpression(DmlParser.ModIntDivExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitMultDivExpression(DmlParser.MultDivExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitMultDivExpression(DmlParser.MultDivExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitMultDivExpression(DmlParser.MultDivExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitMultDivExpression(DmlParser.MultDivExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitMultiIdExpression(DmlParser.MultiIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitMultiIdExpression(DmlParser.MultiIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitMultiIdExpression(DmlParser.MultiIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitMultiIdExpression(DmlParser.MultiIdExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitParameterizedExpression(DmlParser.ParameterizedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitParameterizedExpression(DmlParser.ParameterizedExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitParameterizedExpression(DmlParser.ParameterizedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitParameterizedExpression(DmlParser.ParameterizedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitParForStatement(DmlParser.ParForStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitParForStatement(DmlParser.ParForStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitParForStatement(DmlParser.ParForStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitParForStatement(DmlParser.ParForStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitPathStatement(DmlParser.PathStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitPathStatement(DmlParser.PathStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitPathStatement(DmlParser.PathStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitPathStatement(DmlParser.PathStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitPowerExpression(DmlParser.PowerExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitPowerExpression(DmlParser.PowerExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitPowerExpression(DmlParser.PowerExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitPowerExpression(DmlParser.PowerExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitProgramroot(DmlParser.ProgramrootContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitProgramroot(DmlParser.ProgramrootContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitProgramroot(DmlParser.ProgramrootContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitProgramroot(DmlParser.ProgramrootContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitRelationalExpression(DmlParser.RelationalExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitRelationalExpression(DmlParser.RelationalExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitRelationalExpression(DmlParser.RelationalExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitRelationalExpression(DmlParser.RelationalExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.AccumulatorAssignmentStatementContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.AddSubExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.AssignmentStatementContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.AtomicExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.BooleanAndExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.BooleanNotExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.BooleanOrExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.BuiltinFunctionExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.CommandlineParamExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.CommandlinePositionExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ConstDoubleIdExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ConstFalseExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ConstIntIdExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ConstStringIdExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ConstTrueExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.DataIdExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ExternalFunctionDefExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionCallAssignmentStatementContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionCallMultiAssignmentStatementContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.IfdefAssignmentStatementContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.IfStatementContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ImportStatementContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.IndexedExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateColonExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateSeqExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.MatrixDataTypeCheckContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.MatrixMulExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.Ml_typeContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ModIntDivExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.MultDivExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.MultiIdExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ParameterizedExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.PathStatementContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.PowerExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ProgramrootContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.RelationalExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.SimpleDataIdentifierExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.StrictParameterizedExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.StrictParameterizedKeyValueStringContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.TypedArgAssignContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.TypedArgNoAssignContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.UnaryExpressionContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.ValueTypeContext
-
- exitRule(ParseTreeListener) - Method in class org.apache.sysds.parser.dml.DmlParser.WhileStatementContext
-
- exitSimpleDataIdentifierExpression(DmlParser.SimpleDataIdentifierExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitSimpleDataIdentifierExpression(DmlParser.SimpleDataIdentifierExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitSimpleDataIdentifierExpression(DmlParser.SimpleDataIdentifierExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitSimpleDataIdentifierExpression(DmlParser.SimpleDataIdentifierExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitStrictParameterizedExpression(DmlParser.StrictParameterizedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitStrictParameterizedExpression(DmlParser.StrictParameterizedExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitStrictParameterizedExpression(DmlParser.StrictParameterizedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitStrictParameterizedExpression(DmlParser.StrictParameterizedExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitStrictParameterizedKeyValueString(DmlParser.StrictParameterizedKeyValueStringContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitStrictParameterizedKeyValueString(DmlParser.StrictParameterizedKeyValueStringContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitStrictParameterizedKeyValueString(DmlParser.StrictParameterizedKeyValueStringContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitStrictParameterizedKeyValueString(DmlParser.StrictParameterizedKeyValueStringContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitTypedArgAssign(DmlParser.TypedArgAssignContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitTypedArgAssign(DmlParser.TypedArgAssignContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitTypedArgAssign(DmlParser.TypedArgAssignContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitTypedArgAssign(DmlParser.TypedArgAssignContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitTypedArgNoAssign(DmlParser.TypedArgNoAssignContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitTypedArgNoAssign(DmlParser.TypedArgNoAssignContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitTypedArgNoAssign(DmlParser.TypedArgNoAssignContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitTypedArgNoAssign(DmlParser.TypedArgNoAssignContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitUnaryExpression(DmlParser.UnaryExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitUnaryExpression(DmlParser.UnaryExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitUnaryExpression(DmlParser.UnaryExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitUnaryExpression(DmlParser.UnaryExpressionContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitValueType(DmlParser.ValueTypeContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitValueType(DmlParser.ValueTypeContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitValueType(DmlParser.ValueTypeContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitValueType(DmlParser.ValueTypeContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exitWhileStatement(DmlParser.WhileStatementContext) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
-
- exitWhileStatement(DmlParser.WhileStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
-
- exitWhileStatement(DmlParser.WhileStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- exitWhileStatement(DmlParser.WhileStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- exp(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs an "exp" operation on a matrix on the GPU
- expectedNnz - Variable in class org.apache.sysds.runtime.io.ReadProperties
-
- expHash(int) - Static method in class org.apache.sysds.utils.Hash
-
Compute exponentially distributed hash values in range 0..a.length
eg: 50% == 0 , 25% == 1 12.5 % == 2 etc.
- EXPLAIN - Static variable in class org.apache.sysds.api.DMLScript
-
- explain() - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Explain the DML/PyDML program and view result as a string.
- explain(int, boolean) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
Explain tool: prints the hierarchical plan to stdout
.
- explain(boolean) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTree
-
Explain tool: prints the hierarchical plan (including all available
detail information, if necessary) to stdout
.
- Explain - Class in org.apache.sysds.utils
-
- Explain() - Constructor for class org.apache.sysds.utils.Explain
-
- explain(DMLProgram, Program, Explain.ExplainType) - Static method in class org.apache.sysds.utils.Explain
-
- explain(DMLProgram, Program, Explain.ExplainType, Explain.ExplainCounts) - Static method in class org.apache.sysds.utils.Explain
-
- explain(DMLProgram) - Static method in class org.apache.sysds.utils.Explain
-
- explain(Program) - Static method in class org.apache.sysds.utils.Explain
-
- explain(Program, Explain.ExplainCounts) - Static method in class org.apache.sysds.utils.Explain
-
- explain(ProgramBlock) - Static method in class org.apache.sysds.utils.Explain
-
- explain(ArrayList<Instruction>) - Static method in class org.apache.sysds.utils.Explain
-
- explain(ArrayList<Instruction>, int) - Static method in class org.apache.sysds.utils.Explain
-
- explain(Instruction) - Static method in class org.apache.sysds.utils.Explain
-
- explain(StatementBlock) - Static method in class org.apache.sysds.utils.Explain
-
- explain(Hop) - Static method in class org.apache.sysds.utils.Explain
-
- explain(Hop, int) - Static method in class org.apache.sysds.utils.Explain
-
- explain(LineageItem) - Static method in class org.apache.sysds.utils.Explain
-
- explain(CNode) - Static method in class org.apache.sysds.utils.Explain
-
- explain(CNode, int) - Static method in class org.apache.sysds.utils.Explain
-
- Explain.ExplainCounts - Class in org.apache.sysds.utils
-
- Explain.ExplainType - Enum in org.apache.sysds.utils
-
- ExplainCounts() - Constructor for class org.apache.sysds.utils.Explain.ExplainCounts
-
- explainCPlan(CNodeTpl) - Static method in class org.apache.sysds.utils.Explain
-
- explainDegreeOfParallelism() - Static method in class org.apache.sysds.utils.Explain
-
- explainDegreeOfParallelism(Explain.ExplainCounts) - Static method in class org.apache.sysds.utils.Explain
-
- explainHops(ArrayList<Hop>) - Static method in class org.apache.sysds.utils.Explain
-
- explainHops(ArrayList<Hop>, int) - Static method in class org.apache.sysds.utils.Explain
-
- explainLineageItems(LineageItem[]) - Static method in class org.apache.sysds.utils.Explain
-
- explainLineageItems(LineageItem[], int) - Static method in class org.apache.sysds.utils.Explain
-
- explainMemoryBudget() - Static method in class org.apache.sysds.utils.Explain
-
- explainMemoryBudget(Explain.ExplainCounts) - Static method in class org.apache.sysds.utils.Explain
-
- explainSingleLineageItem(LineageItem) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
-
- explainType - Variable in class org.apache.sysds.api.DMLOptions
-
- exportData() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- exportData(int) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
Writes, or flushes, the cache block data to HDFS.
- exportData(String, String) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- exportData(String, String, FileFormatProperties) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- exportData(String, String, int, FileFormatProperties) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- exportData(String, String, int, FileFormatProperties, String) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
Synchronized because there might be parallel threads (parfor local) that
access the same object (in case it was created before the loop).
- exportLineageItems(long, LocalVariableMap, ArrayList<ParForStatementBlock.ResultVar>, Lineage) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForUtils
-
Export lineage for remote Spark parfor workers.
- exportResultVariables(long, LocalVariableMap, ArrayList<ParForStatementBlock.ResultVar>, OutputCollector<Writable, Writable>) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForUtils
-
- exportResultVariables(long, LocalVariableMap, ArrayList<ParForStatementBlock.ResultVar>, HashMap<String, String>, OutputCollector<Writable, Writable>) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForUtils
-
For remote MR parfor workers.
- exportResultVariables(long, LocalVariableMap, ArrayList<ParForStatementBlock.ResultVar>) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForUtils
-
For remote Spark parfor workers.
- expr - Variable in class org.apache.sysds.parser.dml.ExpressionInfo
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.AccumulatorAssignmentStatementContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.AddSubExpressionContext
-
- expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.AddSubExpressionContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.AssignmentStatementContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.AtomicExpressionContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.BooleanAndExpressionContext
-
- expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.BooleanAndExpressionContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.BooleanNotExpressionContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.BooleanOrExpressionContext
-
- expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.BooleanOrExpressionContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.IfdefAssignmentStatementContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.IfStatementContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.IndexedExpressionContext
-
- expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.IndexedExpressionContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateColonExpressionContext
-
- expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateColonExpressionContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateSeqExpressionContext
-
- expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateSeqExpressionContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.MatrixMulExpressionContext
-
- expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.MatrixMulExpressionContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.ModIntDivExpressionContext
-
- expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.ModIntDivExpressionContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.MultDivExpressionContext
-
- expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.MultDivExpressionContext
-
- expression - Variable in class org.apache.sysds.parser.dml.DmlParser.MultiIdExpressionContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.MultiIdExpressionContext
-
- expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.MultiIdExpressionContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.ParameterizedExpressionContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.PowerExpressionContext
-
- expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.PowerExpressionContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.RelationalExpressionContext
-
- expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.RelationalExpressionContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.StrictParameterizedExpressionContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.TypedArgAssignContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.UnaryExpressionContext
-
- expression() - Method in class org.apache.sysds.parser.dml.DmlParser.WhileStatementContext
-
- Expression - Class in org.apache.sysds.parser
-
- Expression() - Constructor for class org.apache.sysds.parser.Expression
-
- Expression.BinaryOp - Enum in org.apache.sysds.parser
-
Binary operators.
- Expression.BooleanOp - Enum in org.apache.sysds.parser
-
Boolean operators.
- Expression.DataOp - Enum in org.apache.sysds.parser
-
Data operators.
- Expression.FunctCallOp - Enum in org.apache.sysds.parser
-
Function call operators.
- Expression.RelationalOp - Enum in org.apache.sysds.parser
-
Relational operators.
- ExpressionContext(ParserRuleContext, int) - Constructor for class org.apache.sysds.parser.dml.DmlParser.ExpressionContext
-
- ExpressionContext() - Constructor for class org.apache.sysds.parser.dml.DmlParser.ExpressionContext
-
- ExpressionInfo - Class in org.apache.sysds.parser.dml
-
This class exists solely to prevent compiler warnings.
- ExpressionInfo() - Constructor for class org.apache.sysds.parser.dml.ExpressionInfo
-
- ExpressionList - Class in org.apache.sysds.parser
-
- ExpressionList(ArrayList<Expression>) - Constructor for class org.apache.sysds.parser.ExpressionList
-
- ExternalFunctionDefExpressionContext(DmlParser.FunctionStatementContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.ExternalFunctionDefExpressionContext
-
- extract(ArrayList<Hop>, RecompileStatus) - Method in class org.apache.sysds.hops.MemoTable
-
- extractBitmap(int[], MatrixBlock, CompressionSettings) - Static method in class org.apache.sysds.runtime.compress.BitmapEncoder
-
Generate uncompressed bitmaps for a set of columns in an uncompressed matrix block.
- ExtractBlockForBinaryReblock - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- ExtractBlockForBinaryReblock(DataCharacteristics, DataCharacteristics) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.ExtractBlockForBinaryReblock
-
- extractDAGOutputStatistics(ArrayList<Hop>, LocalVariableMap) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- extractDAGOutputStatistics(ArrayList<Hop>, LocalVariableMap, boolean) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- extractDAGOutputStatistics(Hop, LocalVariableMap, boolean) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- ExtractGroup - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- ExtractGroup(long, long, Operator) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.ExtractGroup
-
- ExtractGroup.ExtractGroupBroadcast - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- ExtractGroup.ExtractGroupJoin - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- ExtractGroupBroadcast(PartitionedBroadcast<MatrixBlock>, long, long, Operator) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.ExtractGroup.ExtractGroupBroadcast
-
- ExtractGroupJoin(long, long, Operator) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.ExtractGroup.ExtractGroupJoin
-
- ExtractGroupNWeights - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- ExtractGroupNWeights() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.ExtractGroupNWeights
-
- extractIntID(String) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.util.IDHandler
-
- extractIntIDFromLong(long, int) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.util.IDHandler
-
Extract int ID from long value
- extractMaxMemoryOpt(String) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
- extractTriangular(MatrixBlock, boolean, boolean, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- extractValues() - Method in class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap
-
- extractValues() - Method in class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap
-
- extractValues() - Method in class org.apache.sysds.runtime.compress.utils.IntArrayList
-
Returns the underlying array of offsets.
- extractValues(boolean) - Method in class org.apache.sysds.runtime.compress.utils.IntArrayList
-
- FACTOR_NUM_ITERATIONS - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator
-
- FAIR_SCHEDULER_MODE - Static variable in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- falseStringLiteral() - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- FastBufferedDataInputStream - Class in org.apache.sysds.runtime.util
-
- FastBufferedDataInputStream(InputStream) - Constructor for class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- FastBufferedDataInputStream(InputStream, int) - Constructor for class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- FastBufferedDataOutputStream - Class in org.apache.sysds.runtime.util
-
This buffered output stream is essentially a merged version of
BufferedOutputStream and DataOutputStream, wrt SystemDS requirements.
- FastBufferedDataOutputStream(OutputStream) - Constructor for class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
-
- FastBufferedDataOutputStream(OutputStream, int) - Constructor for class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
-
- FastStringTokenizer - Class in org.apache.sysds.runtime.util
-
This string tokenizer is essentially a simplified StringTokenizer.
- FastStringTokenizer(char) - Constructor for class org.apache.sysds.runtime.util.FastStringTokenizer
-
Constructs a new StringTokenizer for string using the specified
delimiter
- FED_ADDRESSES - Static variable in class org.apache.sysds.parser.DataExpression
-
- FED_FRAME_IDENTIFIER - Static variable in class org.apache.sysds.runtime.instructions.fed.InitFEDInstruction
-
- FED_MATRIX_IDENTIFIER - Static variable in class org.apache.sysds.runtime.instructions.fed.InitFEDInstruction
-
- FED_RANGES - Static variable in class org.apache.sysds.parser.DataExpression
-
- FED_TYPE - Static variable in class org.apache.sysds.parser.DataExpression
-
- Federated - Class in org.apache.sysds.lops
-
- Federated(HashMap<String, Lop>, Types.DataType, Types.ValueType) - Constructor for class org.apache.sysds.lops.Federated
-
- FEDERATED_INST_PREFIX - Static variable in class org.apache.sysds.runtime.instructions.Instruction
-
- FEDERATED_VALID_PARAM_NAMES - Static variable in class org.apache.sysds.parser.DataExpression
-
- FederatedData - Class in org.apache.sysds.runtime.controlprogram.federated
-
- FederatedData(Types.DataType, InetSocketAddress, String) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedData
-
- FederatedLocalData - Class in org.apache.sysds.runtime.controlprogram.federated
-
- FederatedLocalData(long, CacheableData<?>) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedLocalData
-
- FederatedRange - Class in org.apache.sysds.runtime.controlprogram.federated
-
- FederatedRange(long[], long[]) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
-
Create a range with the indexes of each dimension between their respective beginDims
and
endDims
values.
- FederatedRange(FederatedRange) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
-
Does a deep copy of another FederatedRange
object.
- FederatedRange(FederatedRange, long) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
-
- FederatedRequest - Class in org.apache.sysds.runtime.controlprogram.federated
-
- FederatedRequest(FederatedRequest.RequestType) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
-
- FederatedRequest(FederatedRequest.RequestType, long) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
-
- FederatedRequest(FederatedRequest.RequestType, long, Object...) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
-
- FederatedRequest(FederatedRequest.RequestType, long, List<Object>) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
-
- FederatedRequest.RequestType - Enum in org.apache.sysds.runtime.controlprogram.federated
-
- FederatedResponse - Class in org.apache.sysds.runtime.controlprogram.federated
-
- FederatedResponse(FederatedResponse.ResponseType) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedResponse
-
- FederatedResponse(FederatedResponse.ResponseType, Object[]) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedResponse
-
- FederatedResponse(FederatedResponse.ResponseType, Object) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedResponse
-
- FederatedResponse.ResponseType - Enum in org.apache.sysds.runtime.controlprogram.federated
-
- FederatedUDF - Class in org.apache.sysds.runtime.controlprogram.federated
-
- FederatedWorker - Class in org.apache.sysds.runtime.controlprogram.federated
-
- FederatedWorker(int) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedWorker
-
- FederatedWorkerHandler - Class in org.apache.sysds.runtime.controlprogram.federated
-
- FederatedWorkerHandler(ExecutionContextMap) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedWorkerHandler
-
- FederatedWorkerHandlerException - Exception in org.apache.sysds.runtime.controlprogram.federated
-
Exception to throw when an exception occurs in FederatedWorkerHandler during handling of FederatedRequest.
- FederatedWorkerHandlerException(String) - Constructor for exception org.apache.sysds.runtime.controlprogram.federated.FederatedWorkerHandlerException
-
Create new instance of FederatedWorkerHandlerException with a message.
- FederatedWorkerHandlerException(String, Throwable) - Constructor for exception org.apache.sysds.runtime.controlprogram.federated.FederatedWorkerHandlerException
-
- federateFrame(FrameObject, List<Pair<FederatedRange, FederatedData>>) - Method in class org.apache.sysds.runtime.instructions.fed.InitFEDInstruction
-
- federateLocalData(CacheableData<?>) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
-
- federateMatrix(MatrixObject, List<Pair<FederatedRange, FederatedData>>) - Method in class org.apache.sysds.runtime.instructions.fed.InitFEDInstruction
-
- FederationMap - Class in org.apache.sysds.runtime.controlprogram.federated
-
- FederationMap(Map<FederatedRange, FederatedData>) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- FederationMap(long, Map<FederatedRange, FederatedData>) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- FederationMap(long, Map<FederatedRange, FederatedData>, FederationMap.FType) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- FederationMap.FType - Enum in org.apache.sysds.runtime.controlprogram.federated
-
- FederationUtils - Class in org.apache.sysds.runtime.controlprogram.federated
-
- FederationUtils() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
-
- FEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
-
- FEDInstruction.FEDType - Enum in org.apache.sysds.runtime.instructions.fed
-
- FEDInstructionParser - Class in org.apache.sysds.runtime.instructions
-
- FEDInstructionParser() - Constructor for class org.apache.sysds.runtime.instructions.FEDInstructionParser
-
- FEDInstructionUtils - Class in org.apache.sysds.runtime.instructions.fed
-
- FEDInstructionUtils() - Constructor for class org.apache.sysds.runtime.instructions.fed.FEDInstructionUtils
-
- fedWorker - Variable in class org.apache.sysds.api.DMLOptions
-
- fedWorkerPort - Variable in class org.apache.sysds.api.DMLOptions
-
- FILE_SEPARATOR - Static variable in class org.apache.sysds.lops.Lop
-
- FileFormatProperties - Class in org.apache.sysds.runtime.io
-
- FileFormatProperties() - Constructor for class org.apache.sysds.runtime.io.FileFormatProperties
-
- FileFormatPropertiesCSV - Class in org.apache.sysds.runtime.io
-
- FileFormatPropertiesCSV() - Constructor for class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
-
- FileFormatPropertiesCSV(boolean, String, boolean, double, String) - Constructor for class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
-
- FileFormatPropertiesCSV(boolean, String, boolean) - Constructor for class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
-
- FileFormatPropertiesMM - Class in org.apache.sysds.runtime.io
-
- FileFormatPropertiesMM() - Constructor for class org.apache.sysds.runtime.io.FileFormatPropertiesMM
-
- FileFormatPropertiesMM(FileFormatPropertiesMM.MMFormat, FileFormatPropertiesMM.MMField, FileFormatPropertiesMM.MMSymmetry) - Constructor for class org.apache.sysds.runtime.io.FileFormatPropertiesMM
-
- FileFormatPropertiesMM.MMField - Enum in org.apache.sysds.runtime.io
-
- FileFormatPropertiesMM.MMFormat - Enum in org.apache.sysds.runtime.io
-
- FileFormatPropertiesMM.MMSymmetry - Enum in org.apache.sysds.runtime.io
-
- FileFunction - Class in org.apache.sysds.runtime.functionobjects
-
- FileFunction() - Constructor for class org.apache.sysds.runtime.functionobjects.FileFunction
-
- filePath - Variable in class org.apache.sysds.api.DMLOptions
-
- filePath - Variable in class org.apache.sysds.parser.dml.DmlParser.ImportStatementContext
-
- fillBias(MatrixBlock, double[], int, int, int, int, int) - Static method in class org.apache.sysds.runtime.util.DnnUtils
-
- FilterDiagMatrixBlocksFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- FilterDiagMatrixBlocksFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.FilterDiagMatrixBlocksFunction
-
- FilterNonEmptyBlocksFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- FilterNonEmptyBlocksFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.FilterNonEmptyBlocksFunction
-
- FilterNonEmptyBlocksFunction2 - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- FilterNonEmptyBlocksFunction2() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.FilterNonEmptyBlocksFunction2
-
- findClass(String) - Method in class org.apache.sysds.runtime.codegen.ByteClassLoader
-
- findCoCodesByPartitioning(CompressedSizeEstimator, CompressedSizeInfo, int, int, CompressionSettings) - Static method in class org.apache.sysds.runtime.compress.cocode.PlanningCoCoder
-
Main entry point of CoCode.
- findCtableOperationByInputDataTypes(Types.DataType, Types.DataType, Types.DataType) - Static method in class org.apache.sysds.lops.Ctable
-
- findRemovableConditionalPatternInOuterProduct(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- FINE_GRAINED_PRIVACY - Static variable in class org.apache.sysds.parser.DataExpression
-
- FineGrainedPrivacy - Interface in org.apache.sysds.runtime.privacy.finegrained
-
- FineGrainedPrivacyList - Class in org.apache.sysds.runtime.privacy.finegrained
-
Simple implementation of retrieving fine-grained privacy constraints
based on pairs in an ArrayList.
- FineGrainedPrivacyList() - Constructor for class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyList
-
- FineGrainedPrivacyMap - Class in org.apache.sysds.runtime.privacy.finegrained
-
Simple implementation of retrieving fine-grained privacy constraints based on
iterating a LinkedHashMap.
- FineGrainedPrivacyMap() - Constructor for class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyMap
-
- FLAG_DYN_RECOMPILE - Static variable in class org.apache.sysds.conf.CompilerConfig
-
- FLAG_PARREADWRITE_BINARY - Static variable in class org.apache.sysds.conf.CompilerConfig
-
- FLAG_PARREADWRITE_TEXT - Static variable in class org.apache.sysds.conf.CompilerConfig
-
- flip() - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix1
-
- flip() - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix2
-
- float2double(GPUContext, Pointer, Pointer, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
- FLOATING_POINT_PRECISION - Static variable in class org.apache.sysds.api.DMLScript
-
- FLOATING_POINT_PRECISION - Static variable in class org.apache.sysds.conf.DMLConfig
-
- floor(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs an "floor" operation on a matrix on the GPU
- flush() - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
-
- flushBufferToBinaryBlocks(ArrayList<Pair<Long, FrameBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.data.FrameReblockBuffer
-
- flushBufferToBinaryBlocks() - Method in class org.apache.sysds.runtime.instructions.spark.data.ReblockBuffer
-
- flushCellBufferToMatrixBlock(MatrixBlock) - Method in class org.apache.sysds.runtime.io.ReaderTextCellParallel.CellBuffer
-
- fmt - Variable in class org.apache.sysds.runtime.io.ReadProperties
-
- fn - Variable in class org.apache.sysds.runtime.matrix.operators.BinaryOperator
-
- fn - Variable in class org.apache.sysds.runtime.matrix.operators.CMOperator
-
- fn - Variable in class org.apache.sysds.runtime.matrix.operators.COVOperator
-
- fn - Variable in class org.apache.sysds.runtime.matrix.operators.QuaternaryOperator
-
- fn - Variable in class org.apache.sysds.runtime.matrix.operators.ReorgOperator
-
- fn - Variable in class org.apache.sysds.runtime.matrix.operators.ScalarOperator
-
- fn - Variable in class org.apache.sysds.runtime.matrix.operators.SimpleOperator
-
- fn - Variable in class org.apache.sysds.runtime.matrix.operators.TernaryOperator
-
- fn - Variable in class org.apache.sysds.runtime.matrix.operators.UnaryOperator
-
- footprintInMapper(long, long, long, long, long, long) - Static method in class org.apache.sysds.hops.BinaryOp
-
Estimates the memory footprint of MapMult operation depending on which input is put into distributed cache.
- FORCE_ACCELERATOR - Static variable in class org.apache.sysds.api.DMLScript
-
- FORCE_CP_ON_REMOTE_SPARK - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- FORCE_DIST_RM_EMPTY - Static variable in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- FORCE_DIST_SORT_INDEXES - Static variable in class org.apache.sysds.hops.ReorgOp
-
- FORCE_REPLICATION - Static variable in class org.apache.sysds.hops.QuaternaryOp
-
- FORCED_APPEND_METHOD - Static variable in class org.apache.sysds.hops.BinaryOp
-
- FORCED_BINARY_METHOD - Static variable in class org.apache.sysds.hops.BinaryOp
-
- FORCED_LEFT_INDEXING - Static variable in class org.apache.sysds.hops.LeftIndexingOp
-
- FORCED_MMULT_METHOD - Static variable in class org.apache.sysds.hops.AggBinaryOp
-
- forceEviction() - Static method in class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
-
Evicts all buffer pool entries.
- forceGPU - Variable in class org.apache.sysds.api.DMLOptions
-
- forEachParallel(BiFunction<FederatedRange, FederatedData, Void>) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
Execute a function for each FederatedRange
+ FederatedData
pair.
- FORMAT_TYPE - Static variable in class org.apache.sysds.parser.DataExpression
-
- formatMemorySize(long) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
Format a memory size with g/m/k quantifiers into its
number representation.
- formatProperties - Variable in class org.apache.sysds.runtime.io.ReadProperties
-
- ForProgramBlock - Class in org.apache.sysds.runtime.controlprogram
-
- ForProgramBlock(Program, String) - Constructor for class org.apache.sysds.runtime.controlprogram.ForProgramBlock
-
- ForStatement - Class in org.apache.sysds.parser
-
- ForStatement() - Constructor for class org.apache.sysds.parser.ForStatement
-
- ForStatementBlock - Class in org.apache.sysds.parser
-
- ForStatementBlock() - Constructor for class org.apache.sysds.parser.ForStatementBlock
-
- ForStatementContext(DmlParser.StatementContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
-
- Frame - Class in org.apache.sysds.api.mlcontext
-
Frame encapsulates a SystemDS frame.
- Frame(FrameObject, SparkExecutionContext) - Constructor for class org.apache.sysds.api.mlcontext.Frame
-
- Frame(Dataset<Row>, FrameMetadata) - Constructor for class org.apache.sysds.api.mlcontext.Frame
-
Convert a Spark DataFrame to a SystemDS binary-block representation.
- Frame(Dataset<Row>, long, long) - Constructor for class org.apache.sysds.api.mlcontext.Frame
-
Convert a Spark DataFrame to a SystemDS binary-block representation,
specifying the number of rows and columns.
- Frame(Dataset<Row>) - Constructor for class org.apache.sysds.api.mlcontext.Frame
-
Convert a Spark DataFrame to a SystemDS binary-block representation.
- Frame(JavaPairRDD<Long, FrameBlock>, FrameMetadata) - Constructor for class org.apache.sysds.api.mlcontext.Frame
-
Create a Frame, specifying the SystemDS binary-block frame and its
metadata.
- FRAME_DATA_TYPE - Static variable in class org.apache.sysds.parser.Statement
-
- FRAME_VAR_NAME_PREFIX - Static variable in class org.apache.sysds.lops.Lop
-
- FrameAppendCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- FrameAppendMSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- FrameAppendRSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- FrameBlock - Class in org.apache.sysds.runtime.matrix.data
-
- FrameBlock() - Constructor for class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- FrameBlock(FrameBlock) - Constructor for class org.apache.sysds.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, Types.ValueType) - Constructor for class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- FrameBlock(Types.ValueType[]) - Constructor for class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- FrameBlock(Types.ValueType[], String[]) - Constructor for class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- FrameBlock(Types.ValueType[], String[][]) - Constructor for class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- FrameBlock(Types.ValueType[], String[], String[][]) - Constructor for class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- FrameBlock.ColumnMetadata - Class in org.apache.sysds.runtime.matrix.data
-
- FrameBlock.FrameMapFunction - Class in org.apache.sysds.runtime.matrix.data
-
- frameBlockToFrameObject(String, FrameBlock, FrameMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a FrameBlock
to a FrameObject
.
- FrameFormat - Enum in org.apache.sysds.api.mlcontext
-
FrameFormat represents the different frame formats supported by the MLContext
API.
- FrameIndexingCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- FrameIndexingSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
This class implements the frame indexing functionality inside Spark.
- FrameMapFunction() - Constructor for class org.apache.sysds.runtime.matrix.data.FrameBlock.FrameMapFunction
-
- FrameMetadata - Class in org.apache.sysds.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.sysds.api.mlcontext.FrameMetadata
-
- FrameMetadata(String) - Constructor for class org.apache.sysds.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.sysds.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on frame format.
- FrameMetadata(FrameSchema) - Constructor for class org.apache.sysds.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on frame schema.
- FrameMetadata(FrameFormat, FrameSchema) - Constructor for class org.apache.sysds.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.sysds.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.sysds.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) - Constructor for class org.apache.sysds.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) - Constructor for class org.apache.sysds.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.sysds.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.sysds.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.sysds.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.sysds.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) - Constructor for class org.apache.sysds.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) - Constructor for class org.apache.sysds.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.sysds.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.sysds.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.sysds.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.sysds.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) - Constructor for class org.apache.sysds.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) - Constructor for class org.apache.sysds.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) - Constructor for class org.apache.sysds.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(DataCharacteristics) - Constructor for class org.apache.sysds.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on a
DataCharacteristics object.
- FrameMetadata(FrameSchema, MatrixCharacteristics) - Constructor for class org.apache.sysds.api.mlcontext.FrameMetadata
-
Constructor to create a FrameMetadata object based on the frame schema
and a DataCharacteristics object.
- FrameObject - Class in org.apache.sysds.runtime.controlprogram.caching
-
- FrameObject(String) - Constructor for class org.apache.sysds.runtime.controlprogram.caching.FrameObject
-
- FrameObject(String, MetaData) - Constructor for class org.apache.sysds.runtime.controlprogram.caching.FrameObject
-
- FrameObject(String, MetaData, Types.ValueType[]) - Constructor for class org.apache.sysds.runtime.controlprogram.caching.FrameObject
-
- FrameObject(FrameObject) - Constructor for class org.apache.sysds.runtime.controlprogram.caching.FrameObject
-
Copy constructor that copies meta data but NO data.
- frameObjectTo2DStringArray(FrameObject) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a two-dimensional string array.
- frameObjectToBinaryBlocks(FrameObject, SparkExecutionContext) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a JavaPairRDD<Long, FrameBlock>
.
- frameObjectToDataFrame(FrameObject, SparkExecutionContext) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a DataFrame
.
- frameObjectToJavaRDDStringCSV(FrameObject, String) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a JavaRDD<String>
in CSV format.
- frameObjectToJavaRDDStringIJV(FrameObject) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a JavaRDD<String>
in IJV format.
- frameObjectToListStringCSV(FrameObject, String) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a List<String>
in CSV format.
- frameObjectToListStringIJV(FrameObject) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a List<String>
in IJV format.
- frameObjectToRDDStringCSV(FrameObject, String) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a RDD<String>
in CSV format.
- frameObjectToRDDStringIJV(FrameObject) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a FrameObject
to a RDD<String>
in IJV format.
- FrameRDDAggregateUtils - Class in org.apache.sysds.runtime.instructions.spark.utils
-
- FrameRDDAggregateUtils() - Constructor for class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDAggregateUtils
-
- FrameRDDConverterUtils - Class in org.apache.sysds.runtime.instructions.spark.utils
-
- FrameRDDConverterUtils() - Constructor for class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- FrameRDDConverterUtils.LongFrameToLongWritableFrameFunction - Class in org.apache.sysds.runtime.instructions.spark.utils
-
- FrameRDDConverterUtils.LongWritableFrameToLongFrameFunction - Class in org.apache.sysds.runtime.instructions.spark.utils
-
- FrameRDDConverterUtils.LongWritableTextToLongTextFunction - Class in org.apache.sysds.runtime.instructions.spark.utils
-
- FrameRDDConverterUtils.LongWritableToSerFunction - Class in org.apache.sysds.runtime.instructions.spark.utils
-
- FrameReader - Class in org.apache.sysds.runtime.io
-
Base class for all format-specific frame readers.
- FrameReader() - Constructor for class org.apache.sysds.runtime.io.FrameReader
-
- FrameReaderBinaryBlock - Class in org.apache.sysds.runtime.io
-
Single-threaded frame binary block reader.
- FrameReaderBinaryBlock() - Constructor for class org.apache.sysds.runtime.io.FrameReaderBinaryBlock
-
- FrameReaderBinaryBlockParallel - Class in org.apache.sysds.runtime.io
-
Multi-threaded frame binary block reader.
- FrameReaderBinaryBlockParallel() - Constructor for class org.apache.sysds.runtime.io.FrameReaderBinaryBlockParallel
-
- FrameReaderFactory - Class in org.apache.sysds.runtime.io
-
- FrameReaderFactory() - Constructor for class org.apache.sysds.runtime.io.FrameReaderFactory
-
- FrameReaderJSONL - Class in org.apache.sysds.runtime.io
-
- FrameReaderJSONL() - Constructor for class org.apache.sysds.runtime.io.FrameReaderJSONL
-
- FrameReaderJSONLParallel - Class in org.apache.sysds.runtime.io
-
- FrameReaderJSONLParallel() - Constructor for class org.apache.sysds.runtime.io.FrameReaderJSONLParallel
-
- FrameReaderProto - Class in org.apache.sysds.runtime.io
-
- FrameReaderProto() - Constructor for class org.apache.sysds.runtime.io.FrameReaderProto
-
- FrameReaderTextCell - Class in org.apache.sysds.runtime.io
-
Single-threaded frame textcell reader.
- FrameReaderTextCell() - Constructor for class org.apache.sysds.runtime.io.FrameReaderTextCell
-
- FrameReaderTextCellParallel - Class in org.apache.sysds.runtime.io
-
Multi-threaded frame textcell reader.
- FrameReaderTextCellParallel() - Constructor for class org.apache.sysds.runtime.io.FrameReaderTextCellParallel
-
- FrameReaderTextCellParallel.ReadTask - Class in org.apache.sysds.runtime.io
-
- FrameReaderTextCSV - Class in org.apache.sysds.runtime.io
-
Single-threaded frame text csv reader.
- FrameReaderTextCSV(FileFormatPropertiesCSV) - Constructor for class org.apache.sysds.runtime.io.FrameReaderTextCSV
-
- FrameReaderTextCSVParallel - Class in org.apache.sysds.runtime.io
-
Multi-threaded frame text csv reader.
- FrameReaderTextCSVParallel(FileFormatPropertiesCSV) - Constructor for class org.apache.sysds.runtime.io.FrameReaderTextCSVParallel
-
- FrameReblockBuffer - Class in org.apache.sysds.runtime.instructions.spark.data
-
- FrameReblockBuffer(int, long, long, Types.ValueType[]) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.FrameReblockBuffer
-
- FrameSchema - Class in org.apache.sysds.api.mlcontext
-
The frame schema, stored as a list of ValueType
values.
- FrameSchema() - Constructor for class org.apache.sysds.api.mlcontext.FrameSchema
-
- FrameSchema(List<Types.ValueType>) - Constructor for class org.apache.sysds.api.mlcontext.FrameSchema
-
Constructor that specifies the schema as a list of ValueType
values.
- FrameSchema(String) - Constructor for class org.apache.sysds.api.mlcontext.FrameSchema
-
Constructor that specifies the schema as a comma-separated string.
- FrameWriter - Class in org.apache.sysds.runtime.io
-
Base class for all format-specific frame writers.
- FrameWriter() - Constructor for class org.apache.sysds.runtime.io.FrameWriter
-
- FrameWriterBinaryBlock - Class in org.apache.sysds.runtime.io
-
Single-threaded frame binary block writer.
- FrameWriterBinaryBlock() - Constructor for class org.apache.sysds.runtime.io.FrameWriterBinaryBlock
-
- FrameWriterBinaryBlockParallel - Class in org.apache.sysds.runtime.io
-
Multi-threaded frame binary block writer.
- FrameWriterBinaryBlockParallel() - Constructor for class org.apache.sysds.runtime.io.FrameWriterBinaryBlockParallel
-
- FrameWriterFactory - Class in org.apache.sysds.runtime.io
-
- FrameWriterFactory() - Constructor for class org.apache.sysds.runtime.io.FrameWriterFactory
-
- FrameWriterJSONL - Class in org.apache.sysds.runtime.io
-
- FrameWriterJSONL() - Constructor for class org.apache.sysds.runtime.io.FrameWriterJSONL
-
- FrameWriterJSONLParallel - Class in org.apache.sysds.runtime.io
-
- FrameWriterJSONLParallel() - Constructor for class org.apache.sysds.runtime.io.FrameWriterJSONLParallel
-
- FrameWriterProto - Class in org.apache.sysds.runtime.io
-
- FrameWriterProto() - Constructor for class org.apache.sysds.runtime.io.FrameWriterProto
-
- FrameWriterTextCell - Class in org.apache.sysds.runtime.io
-
Single-threaded frame text cell writer.
- FrameWriterTextCell() - Constructor for class org.apache.sysds.runtime.io.FrameWriterTextCell
-
- FrameWriterTextCellParallel - Class in org.apache.sysds.runtime.io
-
Multi-threaded frame text cell writer.
- FrameWriterTextCellParallel() - Constructor for class org.apache.sysds.runtime.io.FrameWriterTextCellParallel
-
- FrameWriterTextCSV - Class in org.apache.sysds.runtime.io
-
Single-threaded frame text csv writer.
- FrameWriterTextCSV(FileFormatPropertiesCSV) - Constructor for class org.apache.sysds.runtime.io.FrameWriterTextCSV
-
- FrameWriterTextCSVParallel - Class in org.apache.sysds.runtime.io
-
Single-threaded frame text csv writer.
- FrameWriterTextCSVParallel(FileFormatPropertiesCSV) - Constructor for class org.apache.sysds.runtime.io.FrameWriterTextCSVParallel
-
- free(Pointer) - Method in class org.apache.sysds.runtime.instructions.gpu.context.CudaMemoryAllocator
-
Frees memory on the device
- free(Pointer) - Method in interface org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryAllocator
-
Frees memory on the device
- free(String, Pointer, boolean) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryManager
-
Deallocate the pointer
- free(Pointer) - Method in class org.apache.sysds.runtime.instructions.gpu.context.UnifiedMemoryAllocator
-
Frees memory on the device
- freeAllGPUContexts() - Static method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContextPool
-
Unreserves all GPUContexts
- freeEvictedBlob() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
Low-level cache I/O method that deletes the file containing the
evicted data blob, without reading it.
- freeMat - Variable in class org.apache.sysds.hops.codegen.opt.ReachabilityGraph.SubProblem
-
- freeMemory() - Method in class org.apache.sysds.runtime.controlprogram.caching.ByteBuffer
-
- freePos - Variable in class org.apache.sysds.hops.codegen.opt.ReachabilityGraph.SubProblem
-
- frequency(Types.ValueType[], Types.ValueType) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- FrequencyCount - Class in org.apache.sysds.runtime.compress.estim.sample
-
- FrequencyCount() - Constructor for class org.apache.sysds.runtime.compress.estim.sample.FrequencyCount
-
- from - Variable in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateColonExpressionContext
-
- from - Variable in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateSeqExpressionContext
-
- from - Variable in class org.apache.sysds.parser.dml.ExpressionInfo
-
- fromExternalString(String) - Static method in enum org.apache.sysds.common.Types.ValueType
-
- fromFloatBuffer(FloatBuffer, double[]) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixNative
-
- fromIndexedFrameBlock(Pair<Long, FrameBlock>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- fromIndexedFrameBlock(List<Pair<Long, FrameBlock>>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- fromIndexedMatrixBlock(IndexedMatrixValue) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- fromIndexedMatrixBlock(List<IndexedMatrixValue>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- fromIndexedMatrixBlockToPair(IndexedMatrixValue) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- fromIndexedMatrixBlockToPair(List<IndexedMatrixValue>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- FS_DEFAULTFS - Static variable in class org.apache.sysds.runtime.util.HDFSTool
-
- FSREAD_DENSE - Static variable in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- FSREAD_SPARSE - Static variable in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- FSWRITE_DENSE - Static variable in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- FSWRITE_SPARSE - Static variable in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- FUNCTION_UNFOLD_NAMEPREFIX - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerRuleBased
-
- functionBlocks - Variable in class org.apache.sysds.parser.dml.DmlParser.ProgramrootContext
-
- FunctionCallAssignmentStatementContext(DmlParser.StatementContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.FunctionCallAssignmentStatementContext
-
- FunctionCallCP - Class in org.apache.sysds.lops
-
- FunctionCallCP(ArrayList<Lop>, String, String, String[], String[], ArrayList<Hop>, boolean, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.FunctionCallCP
-
- FunctionCallCP(ArrayList<Lop>, String, String, String[], String[], LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.FunctionCallCP
-
- FunctionCallCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- FunctionCallCPInstruction(String, String, boolean, CPOperand[], List<String>, List<String>, String) - Constructor for class org.apache.sysds.runtime.instructions.cp.FunctionCallCPInstruction
-
- FunctionCallGraph - Class in org.apache.sysds.hops.ipa
-
- FunctionCallGraph(DMLProgram) - Constructor for class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Constructs the function call graph for all functions
reachable from the main program.
- FunctionCallGraph(StatementBlock) - Constructor for class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Constructs the function call graph for all functions
reachable from the given statement block.
- FunctionCallIdentifier - Class in org.apache.sysds.parser
-
- FunctionCallIdentifier() - Constructor for class org.apache.sysds.parser.FunctionCallIdentifier
-
- FunctionCallIdentifier(ArrayList<ParameterExpression>) - Constructor for class org.apache.sysds.parser.FunctionCallIdentifier
-
- FunctionCallMultiAssignmentStatementContext(DmlParser.StatementContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.FunctionCallMultiAssignmentStatementContext
-
- FunctionCallSizeInfo - Class in org.apache.sysds.hops.ipa
-
Auxiliary data structure to hold function call summaries in terms
of information about number of function calls, consistent dimensions,
consistent sparsity, and dimension-preserving functions.
- FunctionCallSizeInfo(FunctionCallGraph) - Constructor for class org.apache.sysds.hops.ipa.FunctionCallSizeInfo
-
Constructs the function call summary for all functions
reachable from the main program.
- FunctionCallSizeInfo(FunctionCallGraph, boolean) - Constructor for class org.apache.sysds.hops.ipa.FunctionCallSizeInfo
-
Constructs the function call summary for all functions
reachable from the main program.
- FunctionDictionary<T extends Types.FunctionBlock> - Class in org.apache.sysds.parser
-
Dictionary of all functions of a namespace, represented as a simple
key-value map of function names and function statement blocks.
- FunctionDictionary() - Constructor for class org.apache.sysds.parser.FunctionDictionary
-
- functionName - Variable in class org.apache.sysds.parser.dml.DmlSyntacticValidator.ConvertedDMLSyntax
-
- functionName - Variable in class org.apache.sysds.parser.dml.StatementInfo
-
- FunctionObject - Class in org.apache.sysds.runtime.functionobjects
-
- FunctionObject() - Constructor for class org.apache.sysds.runtime.functionobjects.FunctionObject
-
- FunctionOp - Class in org.apache.sysds.hops
-
This FunctionOp represents the call to a DML-bodied or external function.
- FunctionOp(FunctionOp.FunctionType, String, String, String[], List<Hop>, String[], ArrayList<Hop>) - Constructor for class org.apache.sysds.hops.FunctionOp
-
- FunctionOp(FunctionOp.FunctionType, String, String, String[], List<Hop>, String[], boolean) - Constructor for class org.apache.sysds.hops.FunctionOp
-
- FunctionOp.FunctionType - Enum in org.apache.sysds.hops
-
- FunctionProgramBlock - Class in org.apache.sysds.runtime.controlprogram
-
- FunctionProgramBlock(Program, List<DataIdentifier>, List<DataIdentifier>) - Constructor for class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
-
- functionStatement() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- functionStatement - Variable in class org.apache.sysds.parser.dml.DmlParser.ProgramrootContext
-
- functionStatement() - Method in class org.apache.sysds.parser.dml.DmlParser.ProgramrootContext
-
- functionStatement(int) - Method in class org.apache.sysds.parser.dml.DmlParser.ProgramrootContext
-
- FunctionStatement - Class in org.apache.sysds.parser
-
- FunctionStatement() - Constructor for class org.apache.sysds.parser.FunctionStatement
-
- FunctionStatementBlock - Class in org.apache.sysds.parser
-
- FunctionStatementBlock() - Constructor for class org.apache.sysds.parser.FunctionStatementBlock
-
- FunctionStatementContext(ParserRuleContext, int) - Constructor for class org.apache.sysds.parser.dml.DmlParser.FunctionStatementContext
-
- FunctionStatementContext() - Constructor for class org.apache.sysds.parser.dml.DmlParser.FunctionStatementContext
-
- fuse(Hop, Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateBase
-
Indicates if the template can be expanded to the given hop
starting from an open template at the input.
- fuse(Hop, Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateCell
-
- fuse(Hop, Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateMultiAgg
-
- fuse(Hop, Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateOuterProduct
-
- fuse(Hop, Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateRow
-
- GAGG_FN - Static variable in class org.apache.sysds.parser.Statement
-
- GAGG_FN_CM - Static variable in class org.apache.sysds.parser.Statement
-
- GAGG_FN_CM_ORDER - Static variable in class org.apache.sysds.parser.Statement
-
- GAGG_FN_COUNT - Static variable in class org.apache.sysds.parser.Statement
-
- GAGG_FN_MEAN - Static variable in class org.apache.sysds.parser.Statement
-
- GAGG_FN_SUM - Static variable in class org.apache.sysds.parser.Statement
-
- GAGG_FN_VARIANCE - Static variable in class org.apache.sysds.parser.Statement
-
- GAGG_GROUPS - Static variable in class org.apache.sysds.parser.Statement
-
- GAGG_NUM_GROUPS - Static variable in class org.apache.sysds.parser.Statement
-
- GAGG_TARGET - Static variable in class org.apache.sysds.parser.Statement
-
- GAGG_WEIGHTS - Static variable in class org.apache.sysds.parser.Statement
-
- gatherMemStats(boolean) - Method in class org.apache.sysds.api.jmlc.Connection
-
Sets a boolean flag indicating if memory profiling statistics should be
gathered.
- generateCode(DMLProgram) - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
-
- generateCode(Program) - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
-
- generateCodeFromHopDAGs(ArrayList<Hop>) - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
-
- generateCodeFromHopDAGsToInst(StatementBlock, ArrayList<Hop>) - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
-
- generateCodeFromHopDAGsToInst(Hop) - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
-
- generateCodeFromProgramBlock(ProgramBlock) - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
-
- generateCodeFromStatementBlock(StatementBlock) - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
-
- generateParseIssuesMessage(String, List<CustomErrorListener.ParseIssue>) - Static method in class org.apache.sysds.parser.dml.CustomErrorListener
-
Generate a message displaying information about the parse issues that
occurred.
- generatePartitialRuntimeProgram(Program, ArrayList<StatementBlock>) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.ProgramRecompiler
-
- generatePermutation(int, long) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
Generate the permutation
- generateRandomMatrix(MatrixBlock, RandomMatrixGenerator, Well1024a, long) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDatagen
-
Function to generate a matrix of random numbers.
- generateRandomMatrix(MatrixBlock, RandomMatrixGenerator, Well1024a, long, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDatagen
-
Function to generate a matrix of random numbers.
- generateRandomSeed() - Static method in class org.apache.sysds.hops.DataGenOp
-
- generateSample(MatrixBlock, long, int, boolean, long) - Static method in class org.apache.sysds.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.sysds.runtime.matrix.data.LibMatrixDatagen
-
Method to generate a sequence according to the given parameters.
- generateUniqueSeedPath(String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDatagen
-
- genOffsetBitmap(int[], int) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
Encodes the bitmap in blocks of offsets.
- genRLEBitmap(int[], int) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
-
Encodes the bitmap as a series of run lengths and offsets.
- get(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain a serializable object as output
- get(String) - Static method in enum org.apache.sysds.common.Builtins
-
- get(String, boolean) - Static method in enum org.apache.sysds.common.Builtins
-
- get(boolean, boolean) - Static method in enum org.apache.sysds.hops.codegen.SpoofCompiler.PlanCachePolicy
-
- get(long) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- get(long, TemplateBase.TemplateType) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- get(int, int) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix
-
- get(int, int) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix1
-
- get(int, int) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix2
-
- get(int, int) - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap.DensityMap
-
- get() - Method in enum org.apache.sysds.parser.BuiltinConstant
-
- get(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Get the value at a global row/column position.
- get(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
-
- get(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOffset
-
- get(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- get(Bitmap, int, int) - Static method in class org.apache.sysds.runtime.compress.estim.sample.ShlosserEstimator
-
Peter J.
- get(Bitmap, int, int) - Static method in class org.apache.sysds.runtime.compress.estim.sample.SmoothedJackknifeEstimator
-
Peter J.
- get(DblArray) - Method in class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap
-
- get(double) - Method in class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap
-
- get(long) - Method in class org.apache.sysds.runtime.controlprogram.federated.ExecutionContextMap
-
- get(String) - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
-
Retrieves the data object given its name.
- get(int[]) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- get(int[]) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Get the value for a given row and column.
- get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Get the value of a given cell
- get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
-
- get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
-
- get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
-
- get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
-
- get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
-
- get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
-
- get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Get value of matrix cell (r,c).
- get(int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Get values of row r in the format of a sparse row.
- get(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- get(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- get(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- get(int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- get(int) - Method in class org.apache.sysds.runtime.data.SparseRow
-
Gets the value of a specified column.
- get(int) - Method in class org.apache.sysds.runtime.data.SparseRowScalar
-
- get(int) - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- get(int[]) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- get(int, int) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- get(Types.DataType, Types.FileFormat) - Static method in class org.apache.sysds.runtime.io.InputOutputInfo
-
- get(Future<T>) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- get(String) - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- get(CPOperand) - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- get(String) - Method in class org.apache.sysds.runtime.lineage.LineageMap
-
- get(CPOperand) - Method in class org.apache.sysds.runtime.lineage.LineageMap
-
- get(int, int) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Gets a boxed object of the value in position (r,c).
- get(int) - Static method in class org.apache.sysds.runtime.util.CommonThreadPool
-
- get(JSONObject, String) - Static method in class org.apache.sysds.utils.JSONHelper
-
- getAbstractPlanMapping() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
-
- getAcquireMTime() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- getAcquireRTime() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- getActiveMap() - Method in class org.apache.sysds.runtime.lineage.LineageDedupBlock
-
- getActiveMLContext() - Static method in class org.apache.sysds.api.mlcontext.MLContext
-
Retrieve the currently active MLContext.
- getActiveMLContext() - Static method in class org.apache.sysds.utils.MLContextProxy
-
- getActiveMLContextForAPI() - Static method in class org.apache.sysds.utils.MLContextProxy
-
- getAddress() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
-
- getAggDirection(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- getAggFunctions(SpoofCellwise.AggOp[]) - Static method in class org.apache.sysds.runtime.codegen.SpoofMultiAggregate
-
- getAggOp() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- getAggOp(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- getAggOp() - Method in class org.apache.sysds.runtime.codegen.SpoofCellwise
-
- getAggOp(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- getAggOps() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
-
- getAggOps() - Method in class org.apache.sysds.runtime.codegen.SpoofMultiAggregate
-
- getAggOpType() - Method in class org.apache.sysds.runtime.functionobjects.CM
-
- getAggOpType() - Method in class org.apache.sysds.runtime.matrix.operators.CMOperator
-
- getAggOpType(String, String) - Static method in class org.apache.sysds.runtime.matrix.operators.CMOperator
-
- getAggregateOperator(SpoofCellwise.AggOp) - Static method in class org.apache.sysds.runtime.instructions.spark.SpoofSPInstruction
-
- getAlias() - Method in enum org.apache.sysds.common.Builtins
-
- getAlignedBlockSizes(int, int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- getAllCompressionSizes() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
-
- getAllConstraints() - Method in interface org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacy
-
Get all fine-grained constraints as a map from privacy level to
an array of data ranges represented as two-dimensional long arrays.
- getAllConstraints() - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyList
-
- getAllConstraints() - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyMap
-
- getAllConstraintsList() - Method in interface org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacy
-
Return all fine-grained privacy constraints as an arraylist.
- getAllConstraintsList() - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyList
-
- getAllConstraintsList() - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyMap
-
- getAllExpr() - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- getAllInputStats(ArrayList<Hop>) - Method in class org.apache.sysds.hops.MemoTable
-
- getAllInputStats(Hop) - Method in class org.apache.sysds.hops.MemoTable
-
- getAllParents(CNode) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- getAllParents(CNode, Map<Long, Set<Long>>) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- getAllPointers() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
- getAllRefs(long) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- getAndFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.And
-
- getArity() - Method in class org.apache.sysds.runtime.instructions.gpu.BuiltinUnaryGPUInstruction
-
- getATN() - Method in class org.apache.sysds.parser.dml.DmlLexer
-
- getATN() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- getAUType() - Method in class org.apache.sysds.runtime.instructions.cp.AggregateUnaryCPInstruction
-
- getAvailableCount() - Static method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContextPool
-
Get the number of free GPUContexts
- getAvailableMemory() - Method in class org.apache.sysds.runtime.instructions.gpu.context.CudaMemoryAllocator
-
Gets the available memory on GPU that SystemDS can use.
- getAvailableMemory() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Gets the available memory on GPU that SystemDS can use.
- getAvailableMemory() - Method in interface org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryAllocator
-
Gets the available memory on GPU that SystemDS can use.
- getAvailableMemory() - Method in class org.apache.sysds.runtime.instructions.gpu.context.UnifiedMemoryAllocator
-
Gets the available memory on GPU that SystemDS can use.
- getBalancedBlockSizesDefault(int, int, boolean) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- getBasic1NSequenceMax(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getBasicTensor() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- getBasicTypeString(Object) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Obtain the SystemDS scalar value type string equivalent of an accepted
basic type (Integer, Boolean, Double, String)
- getBeginColumn() - Method in class org.apache.sysds.hops.Hop
-
- getBeginColumn() - Method in class org.apache.sysds.lops.Lop
-
- getBeginColumn() - Method in class org.apache.sysds.parser.ConditionalPredicate
-
- getBeginColumn() - Method in class org.apache.sysds.parser.Expression
-
- getBeginColumn() - Method in interface org.apache.sysds.parser.ParseInfo
-
- getBeginColumn() - Method in class org.apache.sysds.parser.Statement
-
- getBeginColumn() - Method in class org.apache.sysds.parser.StatementBlock
-
- getBeginColumn() - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- getBeginColumn() - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- getBeginDims() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
-
- getBeginDims() - Method in class org.apache.sysds.runtime.privacy.finegrained.DataRange
-
- getBeginDimsInt() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
-
- getBeginLine() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
-
- getBeginLine() - Method in class org.apache.sysds.hops.Hop
-
- getBeginLine() - Method in class org.apache.sysds.lops.Lop
-
- getBeginLine() - Method in class org.apache.sysds.parser.ConditionalPredicate
-
- getBeginLine() - Method in class org.apache.sysds.parser.Expression
-
- getBeginLine() - Method in interface org.apache.sysds.parser.ParseInfo
-
- getBeginLine() - Method in class org.apache.sysds.parser.Statement
-
- getBeginLine() - Method in class org.apache.sysds.parser.StatementBlock
-
- getBeginLine() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- getBeginLine() - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- getBeginLine() - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- getBest(long) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- getBest(long, TemplateBase.TemplateType) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- getBest(long, TemplateBase.TemplateType, TemplateBase.TemplateType) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- getBestCompressionType() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
-
- getBinaryAccessType(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixBincell
-
- getBinaryMatrixBlockRDDHandleForVariable(String) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
Spark instructions should call this for all matrix inputs except broadcast
variables.
- getBinaryMatrixBlockRDDHandleForVariable(String, int, boolean) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- getBinaryMatrixCharacteristics(Expression, Expression) - Static method in class org.apache.sysds.parser.Expression
-
Returns the matrix characteristics for scalar-scalar, scalar-matrix, matrix-scalar, matrix-matrix
operations.
- getBinaryOp(String) - Static method in class org.apache.sysds.parser.Expression
-
Convert string value to binary operator.
- getBinaryOperatorOpOp2() - Method in class org.apache.sysds.runtime.matrix.operators.BinaryOperator
-
Method for getting the hop binary operator type for a given function object.
- getBinaryOpSparsity(double, double, Types.OpOp2, boolean) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Estimates the result sparsity for matrix-matrix binary operations (A op B)
- getBinaryOpSparsityConditionalSparseSafe(double, Types.OpOp2, LiteralOp) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getBinaryTensorBlockRDDHandleForVariable(String) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
Spark instructions should call this for all tensor inputs except broadcast
variables.
- getBinaryTensorBlockRDDHandleForVariable(String, int, boolean) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- getBitmapOffsets() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOffset
-
- getBitmaps() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOffset
-
- getBitwAndFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.BitwAnd
-
- getBitwOrFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.BitwOr
-
- getBitwShiftLFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.BitwShiftL
-
- getBitwShiftRFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.BitwShiftR
-
- getBitwXorFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.BitwXor
-
- getBlock(int, int) - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- getBlock(int[]) - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- getBlock(int, int) - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBroadcast
-
- getBlock(int[]) - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBroadcast
-
- getBlockBounds(TensorIndexes, long[], int, int[], int[]) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- getBlocksize() - Method in class org.apache.sysds.api.mlcontext.Metadata
-
Obtain the number of rows/cols per block
- getBlocksize() - Static method in class org.apache.sysds.conf.ConfigurationManager
-
- getBlocksize() - Method in class org.apache.sysds.hops.Hop
-
- getBlocksize() - Method in class org.apache.sysds.hops.rewrite.ProgramRewriteStatus
-
- getBlocksize() - Method in class org.apache.sysds.lops.OutputParameters
-
- getBlocksize() - Method in class org.apache.sysds.parser.Identifier
-
- getBlocksize() - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
- getBlocksize() - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- getBlocksize() - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- getBlocksize() - Method in class org.apache.sysds.runtime.instructions.spark.RandSPInstruction
-
- getBlocksize() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- getBody() - Method in class org.apache.sysds.parser.ForStatement
-
- getBody() - Method in class org.apache.sysds.parser.FunctionStatement
-
- getBody() - Method in class org.apache.sysds.parser.WhileStatement
-
- getBool(CompilerConfig.ConfigType) - Method in class org.apache.sysds.conf.CompilerConfig
-
- getBoolean(String) - Method in class org.apache.sysds.api.jmlc.ResultVariables
-
Obtain the boolean value represented by the given output variable.
- getBoolean(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain a boolean
output
- getBooleanOp(String) - Static method in class org.apache.sysds.parser.Expression
-
Convert string value to boolean operator.
- getBooleanValue(String) - Method in class org.apache.sysds.conf.DMLConfig
-
- getBooleanValue() - Method in class org.apache.sysds.hops.LiteralOp
-
- getBooleanValue(LiteralOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getBooleanValue() - Method in class org.apache.sysds.lops.Data
-
- getBooleanValue() - Method in class org.apache.sysds.runtime.instructions.cp.BooleanObject
-
- getBooleanValue() - Method in class org.apache.sysds.runtime.instructions.cp.DoubleObject
-
- getBooleanValue() - Method in class org.apache.sysds.runtime.instructions.cp.IntObject
-
- getBooleanValue() - Method in class org.apache.sysds.runtime.instructions.cp.ScalarObject
-
- getBooleanValue() - Method in class org.apache.sysds.runtime.instructions.cp.StringObject
-
- getBooleanValueSafe(LiteralOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getBoundOutputParamNames() - Method in class org.apache.sysds.runtime.instructions.cp.FunctionCallCPInstruction
-
- getBroadcastForFrameVariable(String) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- getBroadcastForMatrixObject(MatrixObject) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- getBroadcastForTensorObject(TensorObject) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- getBroadcastForTensorVariable(String) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- getBroadcastForVariable(String) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- getBroadcastHandle() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- getBroadcastMemoryBudget() - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
Obtains the available memory budget for broadcast variables in bytes.
- getBroadcastMemoryBudget() - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext.SparkClusterConfig
-
- getBroadcasts() - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBroadcast
-
- getBroadcastSize() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- getBuiltinCode() - Method in class org.apache.sysds.runtime.functionobjects.Builtin
-
- getBuiltinFnObject(String) - Static method in class org.apache.sysds.runtime.functionobjects.Builtin
-
- getBuiltinFnObject(Builtin.BuiltinCode) - Static method in class org.apache.sysds.runtime.functionobjects.Builtin
-
- getBuiltinFunctionExpression(ParserRuleContext, String, ArrayList<ParameterExpression>, String) - Static method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- getBytes() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
-
- getBytes(ByteBuffer) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- getByteValues() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupValue
-
- getCacheableData(CPOperand) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getCacheableData(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getCacheBlockSize(CacheBlock) - Static method in class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
-
- getCachedItemHead() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- getCachedItemTail() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- getCachedJobConf() - Static method in class org.apache.sysds.conf.ConfigurationManager
-
Returns a cached JobConf object, intended for global use by all operations
with read-only access to job conf.
- getCacheLimit() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheEviction
-
- getCachePolicy() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- getCacheStatus() - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
-
- getCacheType() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- getCalledFunctions(String, String) - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Returns all functions called from the given function.
- getCalledFunctions(String) - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Returns all functions called from the given function.
- getCapacity() - Method in class org.apache.sysds.runtime.instructions.spark.data.FrameReblockBuffer
-
- getCapacity() - Method in class org.apache.sysds.runtime.instructions.spark.data.ReblockBuffer
-
- getCardinalityRatio() - Method in class org.apache.sysds.runtime.compress.cocode.PlanningCoCodingGroup
-
- getCellType() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- getCellType(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- getCellType() - Method in class org.apache.sysds.runtime.codegen.SpoofCellwise
-
- getChangeInSize() - Method in class org.apache.sysds.runtime.compress.cocode.PlanningCoCodingGroup
-
- getCharPositionInLine() - Method in class org.apache.sysds.parser.dml.CustomErrorListener.ParseIssue
-
Obtain character position of the parse issue.
- getCheckedConstraints() - Static method in class org.apache.sysds.runtime.privacy.CheckedConstraintsLog
-
- getCheckedConstraints() - Static method in class org.apache.sysds.runtime.privacy.PrivacyMonitor
-
- getChildBlocks() - Method in class org.apache.sysds.runtime.controlprogram.BasicProgramBlock
-
- getChildBlocks() - Method in class org.apache.sysds.runtime.controlprogram.ForProgramBlock
-
- getChildBlocks() - Method in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
-
- getChildBlocks() - Method in class org.apache.sysds.runtime.controlprogram.IfProgramBlock
-
- getChildBlocks() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ParForBody
-
- getChildBlocks() - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
Get the list of child program blocks if nested;
otherwise this method returns null.
- getChildBlocks() - Method in class org.apache.sysds.runtime.controlprogram.WhileProgramBlock
-
- getChildBlocksElseBody() - Method in class org.apache.sysds.runtime.controlprogram.IfProgramBlock
-
- getChildBlocksIfBody() - Method in class org.apache.sysds.runtime.controlprogram.IfProgramBlock
-
- getChildReferencePos(Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getChilds() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- getCK() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTree
-
- getCkMaxCP() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
Gets the maximum local parallelism constraint.
- getCkMaxMR() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
Gets the maximum remote parallelism constraint
- getClass(String) - Static method in class org.apache.sysds.runtime.codegen.CodegenUtils
-
- getClass(String, byte[]) - Static method in class org.apache.sysds.runtime.codegen.CodegenUtils
-
- getClassData(String) - Static method in class org.apache.sysds.runtime.codegen.CodegenUtils
-
- getClassname() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- getClassName() - Method in class org.apache.sysds.hops.codegen.SpoofFusedOp
-
- getClassSync(String, byte[]) - Static method in class org.apache.sysds.runtime.codegen.CodegenUtils
-
- getClosestK(int[], int) - Static method in class org.apache.sysds.runtime.compress.utils.LinearAlgebraUtils
-
Obtain the index of the closest element in a to the value x.
- getClusterUtilization(boolean) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
Gets the fraction of running map/reduce tasks to existing
map/reduce task slots.
- getCM() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTree
-
- getCM_N_COVObject() - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- getCMAggOpType(int) - Static method in class org.apache.sysds.runtime.matrix.operators.CMOperator
-
- getCMFnObject(CMOperator.AggregateOperationTypes) - Static method in class org.apache.sysds.runtime.functionobjects.CM
-
- getCmMax() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
Gets the maximum memory constraint [in bytes].
- getCode(CacheBlock) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheBlockFactory
-
- getCodegenClassCompile() - Static method in class org.apache.sysds.utils.Statistics
-
- getCodegenClassCompileTime() - Static method in class org.apache.sysds.utils.Statistics
-
- getCodegenCompileTime() - Static method in class org.apache.sysds.utils.Statistics
-
- getCodegenCPlanCompile() - Static method in class org.apache.sysds.utils.Statistics
-
- getCodegenDAGCompile() - Static method in class org.apache.sysds.utils.Statistics
-
- getCodegenEnumAll() - Static method in class org.apache.sysds.utils.Statistics
-
- getCodegenEnumAllP() - Static method in class org.apache.sysds.utils.Statistics
-
- getCodegenEnumEval() - Static method in class org.apache.sysds.utils.Statistics
-
- getCodegenEnumEvalP() - Static method in class org.apache.sysds.utils.Statistics
-
- getCodegenLTrace(String) - Static method in class org.apache.sysds.runtime.lineage.LineageCodegenItem
-
- getCodegenOpCacheHits() - Static method in class org.apache.sysds.utils.Statistics
-
- getCodegenOpCacheTotal() - Static method in class org.apache.sysds.utils.Statistics
-
- getCodegenPlanCacheHits() - Static method in class org.apache.sysds.utils.Statistics
-
- getCodegenPlanCacheTotal() - Static method in class org.apache.sysds.utils.Statistics
-
- getCol() - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.Cell
-
- getColBlockize(int) - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap.DensityMap
-
- getColCounts() - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram.MatrixHistogram
-
- getColGroups() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- getColGroups() - Method in class org.apache.sysds.runtime.compress.CompressionStatistics
-
- getColIndex(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Obtain a column index value.
- getColIndices() - Method in class org.apache.sysds.runtime.compress.cocode.PlanningCoCodingGroup
-
- getColIndices() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Obtain the offsets of the columns in the matrix block that make up the group
- getColList() - Method in class org.apache.sysds.runtime.transform.encode.Encoder
-
- getColLowerBound() - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- getColLowerEqualsUpper() - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- getColMapping(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.Encoder
-
Obtain the column mapping of encoded frames based on the passed
meta data frame.
- getColMapping(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderComposite
-
- getColMapping(FrameBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderDummycode
-
- getColnames() - Method in class org.apache.sysds.runtime.transform.decode.Decoder
-
- getColPrivacy(int, int) - Method in interface org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacy
-
- getColPrivacy(int, int) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyList
-
- getColPrivacy(int, int) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyMap
-
- getCols() - Method in class org.apache.sysds.hops.cost.VarStats
-
- getCols() - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram.MatrixHistogram
-
- getCols() - Method in class org.apache.sysds.hops.estim.MMNode
-
- getCols() - Method in class org.apache.sysds.runtime.functionobjects.SortIndex
-
- getCols() - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- getCols() - Method in class org.apache.sysds.runtime.instructions.cp.StringInitCPInstruction
-
- getCols() - Method in class org.apache.sysds.runtime.instructions.spark.RandSPInstruction
-
- getCols() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- getCols() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- getColumn(int) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- getColumnData(int) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- getColumnIndex() - Method in class org.apache.sysds.runtime.matrix.data.MatrixIndexes
-
- getColumnMetadata() - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- getColumnMetadata(int) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- getColumnName(int) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Returns the column name for the requested column.
- getColumnNameIDMap() - Method in class org.apache.sysds.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.sysds.runtime.matrix.data.FrameBlock
-
Returns the column names of the frame block.
- getColumnNames(boolean) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Returns the column names of the frame block.
- getColumnNamesAsFrame() - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- getColUpperBound() - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- getColValueType(int) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- getCOMFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.COV
-
- getCompAssRW() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- getCompiledFunction(String) - Static method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- getCompilerConfig() - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Get the compiler configuration object associated with
the prepared script instance.
- getCompilerConfig() - Static method in class org.apache.sysds.conf.ConfigurationManager
-
Gets the current thread-local compiler configuration.
- getCompilerConfigFlag(CompilerConfig.ConfigType) - Static method in class org.apache.sysds.conf.ConfigurationManager
-
Get a boolean compiler config in a robust manner,
returning false if config not existing.
- getCompileTime() - Static method in class org.apache.sysds.utils.Statistics
-
- getComplementPPredOperation() - Method in class org.apache.sysds.hops.BinaryOp
-
- getCompletePath() - Method in class org.apache.sysds.parser.ImportStatement
-
- getCompressionSize(ColGroup.CompressionType) - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
-
- getCompType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Obtain the compression type.
- getCompType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
-
- getCompType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
- getCompType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
-
- getCompType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- getConditionalPredicate() - Method in class org.apache.sysds.parser.IfStatement
-
- getConditionalPredicate() - Method in class org.apache.sysds.parser.WhileStatement
-
- getConfig() - Method in class org.apache.sysds.api.mlcontext.ScriptExecutor
-
Obtain the SystemDS configuration properties.
- getConfigForSimpleMatrixOperations(int, int) - Static method in class org.apache.sysds.runtime.instructions.gpu.context.ExecutionConfig
-
Use this for simple vector operations and use following in the kernel
int index = blockIdx.x * blockDim.x + threadIdx.x
- getConfigForSimpleVectorOperations(int) - Static method in class org.apache.sysds.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
- getConfigInfo() - Method in class org.apache.sysds.conf.DMLConfig
-
- getConnection() - Method in class org.apache.sysds.api.PythonDMLScript
-
- getConstant() - Method in class org.apache.sysds.runtime.matrix.operators.ScalarOperator
-
- getConstantValue() - Method in class org.apache.sysds.hops.DataGenOp
-
- getConstDim2() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
-
- getConstDim2() - Method in class org.apache.sysds.runtime.codegen.SpoofRowwise
-
- getConstIn() - Method in class org.apache.sysds.parser.StatementBlock
-
- getConstOut() - Method in class org.apache.sysds.parser.StatementBlock
-
- getConstrainedNumThreads(int) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getConv2dBackwardDataWorkers(DnnParameters) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNConv2d
-
Factory method that returns list of callable tasks for performing conv2d backward data
- getConv2dBackwardFilterWorkers(DnnParameters) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNConv2d
-
Factory method that returns list of callable tasks for performing conv2d backward filter
- getConv2dOutputMap(String, String, String, String) - Static method in class org.apache.sysds.runtime.util.DnnUtils
-
- getConv2dWorkers(DnnParameters) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNConv2d
-
Factory method that returns list of callable tasks for performing conv2d
- getCorrection() - Method in class org.apache.sysds.runtime.instructions.spark.data.CorrMatrixBlock
-
- getCorrectionLocation() - Method in class org.apache.sysds.lops.PartialAggregate
-
This method computes the location of "correction" terms in the output
produced by PartialAgg instruction.
- getCorrectionLocation(Types.AggOp, Types.Direction) - Static method in class org.apache.sysds.lops.PartialAggregate
-
- getCostModelType() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.Optimizer
-
- getCostModelType() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerHeuristic
-
- getCostModelType() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerRuleBased
-
- getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
-
- getCounts(int, int, int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
-
- getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
- getCounts(int, int, int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
- getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
-
- getCounts(int, int, int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
-
- getCounts() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupValue
-
Returns the counts of values inside the MatrixBlock returned in getValuesAsBlock Throws an exception if the
getIfCountsType is false.
- getCounts(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupValue
-
Returns the counts of values inside the MatrixBlock returned in getValuesAsBlock Throws an exception if the
getIfCountsType is false.
- getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupValue
-
- getCounts(int, int, int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupValue
-
- getCPHeavyHitterCode(Instruction) - Static method in class org.apache.sysds.utils.Statistics
-
- getCPHeavyHitterCount(String) - Static method in class org.apache.sysds.utils.Statistics
-
- getCPHeavyHitterOpCodes() - Static method in class org.apache.sysds.utils.Statistics
-
- getCPHeavyHittersMem(int) - Static method in class org.apache.sysds.utils.Statistics
-
- getCPInstructionType() - Method in class org.apache.sysds.runtime.instructions.cp.CPInstruction
-
- getCPRecodeMaps() - Method in class org.apache.sysds.runtime.transform.encode.EncoderRecode
-
- getCPRecodeMapsPartial() - Method in class org.apache.sysds.runtime.transform.encode.EncoderRecode
-
- getCPType(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- getCPTypeByOpcode(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- getCreateVarInstructions(String, String) - Method in class org.apache.sysds.lops.Data
-
- getCTableFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.CTable
-
- getCType() - Method in class org.apache.sysds.hops.codegen.template.TemplateBase
-
- getCublasHandle() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Returns cublasHandle for BLAS operations on the GPU.
- getCudaKernels(GPUContext) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
- getCudnnHandle() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Returns the cudnnHandle for Deep Neural Network operations on the GPU.
- getCumODims(int) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Get the ith cumulative dimensions size of the dense block, without row.
- getCurrentBLAS() - Static method in class org.apache.sysds.utils.NativeHelper
-
Called by Statistics to print the loaded BLAS.
- getCurrentFileName() - Method in class org.apache.sysds.parser.dml.CustomErrorListener
-
- getCurrentID() - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.IDSequence
-
- getCurrentRowIndex() - Method in class org.apache.sysds.runtime.compress.ReaderColumnSelection
-
- getCurrentRowIndex() - Method in class org.apache.sysds.runtime.compress.ReaderColumnSelectionDenseSample
-
- getCusolverDnHandle() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Returns cusolverDnHandle for invoking solve() function on dense matrices on the GPU.
- getCusparseHandle() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Returns cusparseHandle for certain sparse BLAS operations on the GPU.
- getCutSet(boolean[]) - Method in class org.apache.sysds.hops.codegen.opt.ReachabilityGraph
-
- getData(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a Data
object.
- getData() - Method in class org.apache.sysds.hops.estim.MMNode
-
- getData() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC1
-
Getter method to get the data, contained in The DDC ColGroup.
- getData() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC2
-
Getter method to get the data, contained in The DDC ColGroup.
- getData() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
Access for superclass
- getData() - Method in class org.apache.sysds.runtime.compress.utils.DblArray
-
- getData() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedResponse
-
- getData() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcCall
-
- getData() - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- getData() - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- getData() - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- getData() - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- getData() - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- getData() - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- getData(int) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- getData(String) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- getData() - Method in class org.apache.sysds.runtime.lineage.LineageItem
-
- getDataCharacteristics() - Method in class org.apache.sysds.hops.estim.MMNode
-
- getDataCharacteristics() - Method in class org.apache.sysds.hops.Hop
-
- getDataCharacteristics() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- getDataCharacteristics(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getDataCharacteristics() - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBroadcast
-
- getDataCharacteristics() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- getDataCharacteristics() - Method in class org.apache.sysds.runtime.meta.MetaData
-
- getDataExpression(ParserRuleContext, String, ArrayList<ParameterExpression>, String, CustomErrorListener) - Static method in class org.apache.sysds.parser.DataExpression
-
- getDataExpression(String, ArrayList<ParameterExpression>, ParseInfo, CustomErrorListener) - Static method in class org.apache.sysds.parser.DataExpression
-
- getDataFormat() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNodeStatistics
-
- getDataFrame(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a DataFrame
.
- getDataFrame(String, boolean) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a DataFrame
of doubles or vectors with an ID
column.
- getDataFrameDoubleNoIDColumn(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a DataFrame
of doubles with no ID column.
- getDataFrameDoubleWithIDColumn(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a DataFrame
of doubles with an ID column.
- getDataFrameVectorNoIDColumn(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a DataFrame
of vectors with no ID column.
- getDataFrameVectorWithIDColumn(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a DataFrame
of vectors with an ID column.
- getDataGenMethod() - Method in class org.apache.sysds.lops.DataGen
-
- getDataGenOpConstantValue(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getDataMemoryBudget(boolean, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
Obtain the available memory budget for data storage in bytes.
- getDataMemoryBudget(boolean, boolean) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext.SparkClusterConfig
-
- getDataRangesOfPrivacyLevel(PrivacyConstraint.PrivacyLevel) - Method in interface org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacy
-
Get all data ranges for the given privacy level.
- getDataRangesOfPrivacyLevel(PrivacyConstraint.PrivacyLevel) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyList
-
- getDataRangesOfPrivacyLevel(PrivacyConstraint.PrivacyLevel) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyMap
-
- getDataset() - Method in class org.apache.sysds.runtime.instructions.spark.data.DatasetObject
-
- getDataSize() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- getDataSize() - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- getDataTensor() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- getDataType() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- getDataType() - Method in class org.apache.sysds.hops.Hop
-
- getDataType() - Method in class org.apache.sysds.lops.Lop
-
get data type of the output that is produced by this lop
- getDataType() - Method in class org.apache.sysds.parser.Identifier
-
- getDataType() - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- getDataType() - Method in class org.apache.sysds.runtime.instructions.cp.Data
-
- getDebugName() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- getDebugName() - Method in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
- getDebugName() - Method in class org.apache.sysds.runtime.instructions.cp.Data
-
- getDebugName() - Method in class org.apache.sysds.runtime.instructions.cp.DoubleObject
-
- getDebugName() - Method in class org.apache.sysds.runtime.instructions.cp.KahanObject
-
- getDebugName() - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- getDebugName() - Method in class org.apache.sysds.runtime.instructions.cp.ScalarObject
-
- getDecreasing() - Method in class org.apache.sysds.runtime.functionobjects.SortIndex
-
- getDedupBlocks() - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- getDefaultCuSparseMatrixDescriptor() - Static method in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
- getDefaultExecutionMode() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getDefaultFrameSize() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getDefaultFunctionDictionary() - Method in class org.apache.sysds.parser.DMLProgram
-
- getDefaultLogLevel() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getDefaultParallelism(boolean) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
Obtain the default degree of parallelism (cores in the cluster).
- getDefaultParallelism(boolean) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext.SparkClusterConfig
-
- getDefaultSize() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getDefaultStorageLevelString() - Static method in class org.apache.sysds.lops.Checkpoint
-
- getDefaultTextValue(String) - Static method in class org.apache.sysds.conf.DMLConfig
-
- getDefColNames(long) - Method in class org.apache.sysds.runtime.io.FrameReader
-
- getDefSchema(long) - Method in class org.apache.sysds.runtime.io.FrameReader
-
- getDefWorkingFilePath(String) - Static method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- getDegreeOfParallelism() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- getDelim() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
-
- getDelim() - Method in class org.apache.sysds.runtime.transform.TfUtils
-
- getDelimString() - Method in class org.apache.sysds.runtime.transform.TfUtils
-
- getDenseBlock() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- getDenseBlock() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- getDenseBlockType(DenseBlock) - Static method in class org.apache.sysds.runtime.data.DenseBlockFactory
-
- getDenseBlockValues() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- getDenseMatrices(SpoofOperator.SideInput[]) - Static method in class org.apache.sysds.runtime.codegen.SpoofOperator
-
- getDenseMatrixOutputForGPUInstruction(String, long, long) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
Allocates a dense matrix on the GPU (for output)
- getDenseMatrixOutputForGPUInstruction(ExecutionContext, String, String, long, long) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Helper method to get the output block (allocated on the GPU)
Also records performance information into
Statistics
- getDensePointer() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Pointer to dense matrix
- getDensePointer(GPUContext, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Convenience method to get jcudaDenseMatrixPtr.
- getDensePointerForCuDNN(GPUContext, MatrixObject, String, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNN
-
Convenience method to get jcudaDenseMatrixPtr.
- getDenseRowIterator(int, int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- getDenseVector(MatrixBlock) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConverter
-
Extract the double array primitive from a Matrix Block that is an vector.
- getDescription() - Method in class org.apache.sysds.runtime.io.FileFormatProperties
-
- getDeserializer(Class) - Method in class org.apache.sysds.runtime.io.BinaryBlockSerialization
-
- getDeviceCount() - Static method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContextPool
-
Number of available devices on this machine
- getDeviceNum() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Returns which device is assigned to this GPUContext instance.
- getDiagIndexFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.DiagIndex
-
- getDiagIndexFnObject(boolean) - Static method in class org.apache.sysds.runtime.functionobjects.DiagIndex
-
- getDim(int) - Method in class org.apache.sysds.hops.Hop
-
- getDim(int) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- getDim(int) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- getDim(int) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Get the ith dimensions size of the dense block.
- getDim(int) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- getDim(int) - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- getDim(int) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- getDim(int) - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- getDim(int) - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- getDim1() - Method in class org.apache.sysds.hops.Hop
-
- getDim1() - Method in class org.apache.sysds.parser.Identifier
-
- getDim1() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNodeStatistics
-
- getDim2() - Method in class org.apache.sysds.hops.Hop
-
- getDim2() - Method in class org.apache.sysds.parser.Identifier
-
- getDim2() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNodeStatistics
-
- getDim3() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNodeStatistics
-
- getDim4() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNodeStatistics
-
- getDims() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- getDims() - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- getDims() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- getDims() - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- getDims() - Method in class org.apache.sysds.runtime.instructions.spark.RandSPInstruction
-
- getDims() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- getDimsPreservingFunctions() - Method in class org.apache.sysds.hops.ipa.FunctionCallSizeInfo
-
Gets the set of dimension-preserving functions, i.e.,
functions with one matrix input and output of equal
dimension sizes.
- getDirection() - Method in class org.apache.sysds.hops.AggUnaryOp
-
- getDirectoryListing(String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- getDistinct(long) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- getDistinctTemplates(long) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- getDistinctTemplateTypes(long, int) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- getDistinctTemplateTypes(long, int, boolean) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- getDivideFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.Divide
-
- getDMLConfig() - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Get the dml configuration object associated with
the prepared script instance.
- getDMLConfig() - Static method in class org.apache.sysds.conf.ConfigurationManager
-
Gets the current thread-local dml configuration.
- getDMLProg() - Method in class org.apache.sysds.parser.StatementBlock
-
- getDMLProg() - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- getDmlProgram() - Method in class org.apache.sysds.api.mlcontext.ScriptExecutor
-
Obtain the program
- getDmlTranslator() - Method in class org.apache.sysds.api.mlcontext.ScriptExecutor
-
Obtain the translator
- getDouble(String) - Method in class org.apache.sysds.api.jmlc.ResultVariables
-
Obtain the double value represented by the given output variable.
- getDouble(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain a double
output
- getDouble(Object) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- getDoubleValue(String) - Method in class org.apache.sysds.conf.DMLConfig
-
- getDoubleValue() - Method in class org.apache.sysds.hops.LiteralOp
-
- getDoubleValue(LiteralOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getDoubleValue() - Method in class org.apache.sysds.lops.Data
-
- getDoubleValue() - Method in class org.apache.sysds.runtime.instructions.cp.BooleanObject
-
- getDoubleValue() - Method in class org.apache.sysds.runtime.instructions.cp.DoubleObject
-
- getDoubleValue() - Method in class org.apache.sysds.runtime.instructions.cp.IntObject
-
- getDoubleValue() - Method in class org.apache.sysds.runtime.instructions.cp.ScalarObject
-
- getDoubleValue() - Method in class org.apache.sysds.runtime.instructions.cp.StringObject
-
- getDoubleValueSafe(LiteralOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getEc() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.SparkPSBody
-
- getEc() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ParForBody
-
- getEighthExpr() - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- getElseBody() - Method in class org.apache.sysds.parser.IfStatement
-
- getEmptyBlockRDD(JavaSparkContext, DataCharacteristics) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
Creates an RDD of empty blocks according to the given matrix characteristics.
- getEncoders() - Method in class org.apache.sysds.runtime.transform.encode.EncoderComposite
-
- getEndColumn() - Method in class org.apache.sysds.hops.Hop
-
- getEndColumn() - Method in class org.apache.sysds.lops.Lop
-
- getEndColumn() - Method in class org.apache.sysds.parser.ConditionalPredicate
-
- getEndColumn() - Method in class org.apache.sysds.parser.Expression
-
- getEndColumn() - Method in interface org.apache.sysds.parser.ParseInfo
-
- getEndColumn() - Method in class org.apache.sysds.parser.Statement
-
- getEndColumn() - Method in class org.apache.sysds.parser.StatementBlock
-
- getEndColumn() - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- getEndColumn() - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- getEndDims() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
-
- getEndDims() - Method in class org.apache.sysds.runtime.privacy.finegrained.DataRange
-
- getEndDimsInt() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
-
- getEndLine() - Method in class org.apache.sysds.hops.Hop
-
- getEndLine() - Method in class org.apache.sysds.lops.Lop
-
- getEndLine() - Method in class org.apache.sysds.parser.ConditionalPredicate
-
- getEndLine() - Method in class org.apache.sysds.parser.Expression
-
- getEndLine() - Method in interface org.apache.sysds.parser.ParseInfo
-
- getEndLine() - Method in class org.apache.sysds.parser.Statement
-
- getEndLine() - Method in class org.apache.sysds.parser.StatementBlock
-
- getEndLine() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- getEndLine() - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- getEndLine() - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- getEqualsFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.Equals
-
- getErrorMessage() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedResponse
-
- getErrorMessage() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcResponse
-
- getEstCard() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
-
Note cardinality is the same as number of distinct values.
- getEstimate(CostEstimator.TestMeasure, OptNode) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator
-
Main estimation method.
- getEstimate(CostEstimator.TestMeasure, OptNode, boolean) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator
-
- getEstimate(CostEstimator.TestMeasure, OptNode, boolean, Collection<String>, CostEstimator.ExcludeType) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator
-
- getEstimate(CostEstimator.TestMeasure, OptNode, LopProperties.ExecType) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator
-
Main estimation method.
- getEstNnz() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
-
Number of offsets, or number of non zero values.
- getEstSize() - Method in class org.apache.sysds.runtime.compress.cocode.PlanningCoCodingGroup
-
Obtain estimated compressed size of the grouped columns.
- getExactBlockDataSerializedSize(BasicTensorBlock) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
Get the exact serialized size of a BasicTensorBlock
if written by
TensorBlock.writeBlockData(DataOutput,BasicTensorBlock)
.
- getExactSerializedSize() - Method in interface org.apache.sysds.runtime.controlprogram.caching.CacheBlock
-
Get the exact serialized size in bytes of the cache block.
- getExactSerializedSize() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- getExactSerializedSize() - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- getExactSerializedSize() - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- getExactSerializedSize() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ADictionary
-
Calculate the space consumption if the dictionary is stored on disk.
- getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Returns the exact serialized size of column group.
- getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC1
-
- getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC2
-
- getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOffset
-
- getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
- getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupValue
-
- getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.Dictionary
-
- getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.QDictionary
-
- getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
NOTE: The used estimates must be kept consistent with the respective write functions.
- getExecMode() - Method in enum org.apache.sysds.api.mlcontext.MLContext.ExecutionType
-
- getExecMode() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- getExecType() - Method in class org.apache.sysds.hops.Hop
-
- getExecType() - Method in class org.apache.sysds.lops.Lop
-
Method to get the execution type (CP, CP_FILE, MR, SPARK, GPU, INVALID) of LOP
- getExecType() - Method in class org.apache.sysds.lops.LopProperties
-
- getExecType() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- getExecType(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- getExecutedIterations() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ParWorker
-
Returns a summary statistic of executed iterations and hence should only be called
after execution.
- getExecutedTasks() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ParWorker
-
Returns a summary statistic of executed tasks and hence should only be called
after execution.
- getExecutionContext() - Method in class org.apache.sysds.api.mlcontext.ScriptExecutor
-
Obtain the execution context
- getExecutionContext() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ParWorker
-
- getExecutionType() - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Obtain the current execution environment.
- getExecutionType() - Method in class org.apache.sysds.api.mlcontext.ScriptExecutor
-
Obtain the current execution environment.
- getExitInstruction() - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- getExplainType() - Method in enum org.apache.sysds.api.mlcontext.MLContext.ExplainLevel
-
- getExportTime() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- getExpr(int) - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- getExpr() - Method in class org.apache.sysds.parser.ParameterExpression
-
- getExpressions() - Method in class org.apache.sysds.parser.PrintStatement
-
- getExprParam(String) - Method in class org.apache.sysds.parser.OutputStatement
-
- getExtConsumed() - Method in class org.apache.sysds.hops.codegen.opt.PlanPartition
-
- getExtendedOpcode() - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- getFeatures() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.PSWorker
-
- getFederatedRanges() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- getFEDInstructionType() - Method in class org.apache.sysds.runtime.instructions.fed.FEDInstruction
-
- getFedMapping() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
Gets the mapping of indices ranges to federated objects.
- getFEDType(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- getField() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesMM
-
- getFifthExpr() - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- getFile_name() - Method in class org.apache.sysds.lops.OutputParameters
-
- getFileFormat() - Method in class org.apache.sysds.parser.Identifier
-
- getFileFormat() - Method in class org.apache.sysds.runtime.meta.MetaDataFormat
-
- getFileFormatProperties() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- getFileFormatType() - Method in class org.apache.sysds.lops.Data
-
method to get format type for input, output files.
- getFileName() - Method in class org.apache.sysds.hops.DataOp
-
- getFilename() - Method in class org.apache.sysds.hops.Hop
-
- getFilename() - Method in class org.apache.sysds.lops.Lop
-
- getFilename() - Method in class org.apache.sysds.parser.ConditionalPredicate
-
- getFileName() - Method in class org.apache.sysds.parser.dml.CustomErrorListener.ParseIssue
-
Obtain the filename of the script containing the parse issue, if
available.
- getFilename() - Method in class org.apache.sysds.parser.Expression
-
- getFilename() - Method in interface org.apache.sysds.parser.ParseInfo
-
- getFilename() - Method in class org.apache.sysds.parser.Statement
-
- getFilename() - Method in class org.apache.sysds.parser.StatementBlock
-
- getFileName() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- getFilename() - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- getFilename() - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- getFilePath(String) - Static method in enum org.apache.sysds.common.Builtins
-
- getFilePath() - Method in class org.apache.sysds.parser.ImportStatement
-
- getFilepath() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
-
- getFilesizeOnHDFS(Path) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
Returns the size of a file or directory on hdfs in bytes.
- getFileSystem(String) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- getFileSystem(Path) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- getFileSystem(Configuration) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- getFileSystem(Path, Configuration) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- getFillValue() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
-
- getFineGrainedPrivacy() - Method in class org.apache.sysds.runtime.privacy.PrivacyConstraint
-
Get fine-grained privacy instance.
- getFirst() - Method in class org.apache.sysds.runtime.util.RandNPair
-
- getFirstExpr() - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- getFirstIndex() - Method in class org.apache.sysds.runtime.matrix.data.TripleIndexes
-
- getFlipped() - Method in enum org.apache.sysds.lops.MapMult.CacheType
-
- getFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.IfElse
-
- getFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.IntegerDivide
-
- getFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.MinusMultiply
-
- getFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.Modulus
-
- getFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.PlusMultiply
-
- getForcedExecType() - Method in class org.apache.sysds.hops.Hop
-
- getFormat() - Method in class org.apache.sysds.lops.OutputParameters
-
- getFormat() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesMM
-
- getFormatProperties() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- getFormatProperties() - Method in class org.apache.sysds.runtime.instructions.spark.WriteSPInstruction
-
- getFourthExpr() - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- getFrame(String) - Method in class org.apache.sysds.api.jmlc.ResultVariables
-
Obtain the frame represented by the given output variable.
- getFrame(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a Frame
.
- getFrameAs2DStringArray(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a two-dimensional String
array.
- getFrameBinaryBlockRDDHandleForVariable(String) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
Spark instructions should call this for all frame inputs except broadcast
variables.
- getFrameBlock(String) - Method in class org.apache.sysds.api.jmlc.ResultVariables
-
Obtain the frame represented by the given output variable.
- getFrameBlockForReuse(FrameBlock[]) - Static method in class org.apache.sysds.runtime.io.FrameWriter
-
- getFrameFormat() - Method in class org.apache.sysds.api.mlcontext.FrameMetadata
-
Obtain the frame format
- getFrameInput(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
Pins a frame variable into memory and returns the internal frame block.
- getFrameMetadata() - Method in class org.apache.sysds.api.mlcontext.Frame
-
Obtain the frame metadata
- getFrameObject(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a FrameObject
- getFrameObject(CPOperand) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getFrameObject(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getFrameSchema() - Method in class org.apache.sysds.api.mlcontext.FrameMetadata
-
Obtain the frame schema
- getFrom() - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- getFromExpr() - Method in class org.apache.sysds.parser.IterablePredicate
-
- getFromHopID() - Method in class org.apache.sysds.hops.codegen.opt.InterestingPoint
-
- getFromHops() - Method in class org.apache.sysds.parser.ForStatementBlock
-
- getFromInstructions() - Method in class org.apache.sysds.runtime.controlprogram.ForProgramBlock
-
- getFromLops() - Method in class org.apache.sysds.parser.ForStatementBlock
-
- getFSBuffHits() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- getFSBuffWrites() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- getFSHits() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- getFSReadTime(long, long, double) - Static method in class org.apache.sysds.hops.cost.CostEstimatorStaticRuntime
-
Returns the estimated read time from local FS.
- getFSWrites() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- getFSWriteTime(long, long, double) - Static method in class org.apache.sysds.hops.cost.CostEstimatorStaticRuntime
-
- getFunction(String) - Method in class org.apache.sysds.parser.FunctionDictionary
-
- getFunction(String, boolean) - Method in class org.apache.sysds.parser.FunctionDictionary
-
- getFunctionCallCount(String) - Method in class org.apache.sysds.hops.ipa.FunctionCallSizeInfo
-
Gets the number of function calls to a given function.
- getFunctionCalls(String) - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Returns all function operators calling the given function.
- getFunctionCallsSB(String) - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Returns all statement blocks that contain a function operator
calling the given function.
- getFunctionDefs() - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- getFunctionKey() - Method in class org.apache.sysds.hops.FunctionOp
-
- getFunctionName() - Method in class org.apache.sysds.hops.FunctionOp
-
- getFunctionName() - Method in class org.apache.sysds.runtime.instructions.cp.FunctionCallCPInstruction
-
- getFunctionNames() - Method in class org.apache.sysds.runtime.controlprogram.parfor.LocalParWorker
-
- getFunctionNamespace() - Method in class org.apache.sysds.hops.FunctionOp
-
- getFunctionOpType() - Method in class org.apache.sysds.parser.FunctionStatementBlock
-
- getFunctionOutputs() - Method in class org.apache.sysds.lops.FunctionCallCP
-
- getFunctionProgramBlock(String, String) - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- getFunctionProgramBlock(String, boolean) - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- getFunctionProgramBlock(String, String, boolean) - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- getFunctionProgramBlocks() - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- getFunctionProgramBlocks(boolean) - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- getFunctions() - Method in class org.apache.sysds.parser.FunctionDictionary
-
- getFunctions(boolean) - Method in class org.apache.sysds.parser.FunctionDictionary
-
- getFunctionStatementBlock(String) - Method in class org.apache.sysds.parser.DMLProgram
-
- getFunctionStatementBlock(String, String) - Method in class org.apache.sysds.parser.DMLProgram
-
- getFunctionStatementBlocks(String) - Method in class org.apache.sysds.parser.DMLProgram
-
- getFunctionStatementBlocks() - Method in class org.apache.sysds.parser.DMLProgram
-
- getFunctionType() - Method in class org.apache.sysds.hops.FunctionOp
-
- getFunRecompiles() - Static method in class org.apache.sysds.utils.Statistics
-
- getFunRecompileTime() - Static method in class org.apache.sysds.utils.Statistics
-
- getGen() - Method in class org.apache.sysds.parser.LiveVariableAnalysis
-
- getGlobalExecMode() - Static method in class org.apache.sysds.api.DMLScript
-
- getGPUContext(int) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
Get the i-th GPUContext
- getGPUContexts() - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
Gets the list of GPUContexts
- getGPUInstructionType() - Method in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- getGPULazyCudaFreeMemoryManager() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryManager
-
- getGPUMatrixMemoryManager() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryManager
-
- getGPUObject(GPUContext) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- getGPUProperties() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Gets the device properties for the active GPU (set with cudaSetDevice()).
- getGPUType(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- getGrammarFileName() - Method in class org.apache.sysds.parser.dml.DmlLexer
-
- getGrammarFileName() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- getGraphString() - Method in class org.apache.sysds.runtime.instructions.cp.CPInstruction
-
- getGraphString() - Method in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- getGraphString() - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- getGraphString() - Method in class org.apache.sysds.runtime.instructions.spark.SPInstruction
-
- getGreaterThanEqualsFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.GreaterThanEquals
-
- getGreaterThanFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.GreaterThan
-
- getGroupInfo(int) - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfo
-
- getGroupsSizesString() - Method in class org.apache.sysds.runtime.compress.CompressionStatistics
-
- getGroupsTypesString() - Method in class org.apache.sysds.runtime.compress.CompressionStatistics
-
- getHDFSBlockSize() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
Gets the HDFS blocksize of the used cluster in bytes.
- getHDFSDataOutputStream(String, boolean) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- getHDFSFilename() - Method in class org.apache.sysds.runtime.instructions.spark.data.RDDObject
-
- getHDFSHits() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- getHDFSWrites() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- getHeader() - Method in class org.apache.sysds.runtime.transform.TfUtils
-
- getHeavyHitters(int) - Static method in class org.apache.sysds.utils.Statistics
-
Obtain a string tabular representation of the heavy hitter instructions
that displays the time, instruction count, and optionally GPU stats about
each instruction.
- getHistogram(int) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
-
Exposes the internal histogram after build.
- getHopID() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeData
-
- getHopID() - Method in class org.apache.sysds.hops.Hop
-
- getHopRecompiledPredDAGs() - Static method in class org.apache.sysds.utils.Statistics
-
- getHopRecompiledSBDAGs() - Static method in class org.apache.sysds.utils.Statistics
-
- getHopRecompileTime() - Static method in class org.apache.sysds.utils.Statistics
-
- getHopRefs() - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- getHops() - Method in class org.apache.sysds.parser.StatementBlock
-
- getI() - Method in class org.apache.sysds.runtime.matrix.data.IJV
-
- getID() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- getID() - Method in class org.apache.sysds.lops.Lop
-
Method to return the ID of LOP
- getID() - Method in class org.apache.sysds.lops.LopProperties
-
- getID() - Method in class org.apache.sysds.parser.ParForStatementBlock
-
- getID() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
-
- getID() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- getID() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- getID() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- getId() - Method in class org.apache.sysds.runtime.lineage.LineageItem
-
- getIdentation(int) - Static method in class org.apache.sysds.utils.Explain
-
- getIdentifier() - Method in class org.apache.sysds.parser.OutputStatement
-
- getIfBody() - Method in class org.apache.sysds.parser.IfStatement
-
- getIfCountsType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Returns true if in the getValuesAsBlock method returns values in groups (that needs to be counted) or
individually potentially repeated values
- getIfCountsType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- getIfCountsType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupValue
-
- getIncr() - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- getIncrementExpr() - Method in class org.apache.sysds.parser.IterablePredicate
-
- getIncrementHops() - Method in class org.apache.sysds.parser.ForStatementBlock
-
- getIncrementInstructions() - Method in class org.apache.sysds.runtime.controlprogram.ForProgramBlock
-
- getIncrementLops() - Method in class org.apache.sysds.parser.ForStatementBlock
-
- getIncrementValue() - Method in class org.apache.sysds.hops.DataGenOp
-
- getIndex(int) - Method in class org.apache.sysds.runtime.data.TensorIndexes
-
- getIndexes() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeTaggedMatrixIndexes
-
- getIndexes() - Method in class org.apache.sysds.runtime.data.IndexedTensorBlock
-
- getIndexes() - Method in class org.apache.sysds.runtime.data.TensorIndexes
-
- getIndexes() - Method in class org.apache.sysds.runtime.instructions.spark.data.IndexedMatrixValue
-
- getIndexReturn() - Method in class org.apache.sysds.runtime.functionobjects.SortIndex
-
- getInitialValue(SpoofCellwise.AggOp) - Static method in class org.apache.sysds.runtime.codegen.SpoofMultiAggregate
-
- getInjectedCheckpoints() - Method in class org.apache.sysds.hops.rewrite.ProgramRewriteStatus
-
- getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.ADictionary
-
Returns the memory usage of the dictionary.
- getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.Dictionary
-
- getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.QDictionary
-
- getInMemorySize(int) - Static method in class org.apache.sysds.runtime.compress.colgroup.QDictionary
-
- getInMemorySize() - Method in interface org.apache.sysds.runtime.controlprogram.caching.CacheBlock
-
Get the in-memory size in bytes of the cache block.
- getInMemorySize() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- getInMemorySize() - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- getInMemorySize() - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- getInMemorySize() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- getInput() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- getInput(String) - Method in class org.apache.sysds.hops.DataGenOp
-
- getInput() - Method in class org.apache.sysds.hops.Hop
-
- getInput(int) - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- getInput1() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- getInput1() - Method in class org.apache.sysds.runtime.instructions.spark.WriteSPInstruction
-
- getInput2() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- getInput2() - Method in class org.apache.sysds.runtime.instructions.spark.WriteSPInstruction
-
- getInput3() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- getInput4() - Method in class org.apache.sysds.runtime.instructions.cp.QuaternaryCPInstruction
-
- getInput4() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- getInputBlocksize() - Method in class org.apache.sysds.hops.DataOp
-
- getInputDefault(String) - Method in class org.apache.sysds.parser.FunctionStatement
-
- getInputDefaults() - Method in class org.apache.sysds.parser.FunctionStatement
-
- getInputFormatType() - Method in class org.apache.sysds.hops.DataOp
-
- getInputHopIDs(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
-
- getInputIDs() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedUDF
-
- getInputIndex(String) - Method in class org.apache.sysds.lops.ParameterizedBuiltin
-
- getInputMemEstimate() - Method in class org.apache.sysds.hops.Hop
-
- getInputMetadata() - Method in class org.apache.sysds.api.mlcontext.Script
-
Obtain an unmodifiable map of input matrix/frame metadata.
- getInputNames() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
-
- getInputOutputSize(Collection<String>) - Method in class org.apache.sysds.hops.Hop
-
- getInputParam(String) - Method in class org.apache.sysds.parser.FunctionStatement
-
- getInputParam(String) - Method in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
-
- getInputParameters() - Method in class org.apache.sysds.api.mlcontext.Script
-
Obtain an unmodifiable map of all input parameters ($).
- getInputParamNames() - Method in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
-
- getInputParams() - Method in class org.apache.sysds.lops.Data
-
method to get inputParams
- getInputParams() - Method in class org.apache.sysds.parser.FunctionStatement
-
- getInputParams() - Method in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
-
- getInputs() - Method in class org.apache.sysds.api.mlcontext.Script
-
Obtain an unmodifiable map of all inputs (parameters ($) and variables).
- getInputs() - Method in class org.apache.sysds.hops.codegen.opt.PlanPartition
-
- getInputs() - Method in class org.apache.sysds.lops.Lop
-
Method to get input of Lops
- getInputs() - Method in class org.apache.sysds.runtime.instructions.cp.BuiltinNaryCPInstruction
-
- getInputs() - Method in class org.apache.sysds.runtime.instructions.cp.ComputationCPInstruction
-
- getInputs() - Method in class org.apache.sysds.runtime.instructions.cp.FunctionCallCPInstruction
-
- getInputs() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- getInputs() - Method in class org.apache.sysds.runtime.lineage.LineageItem
-
- getInputstoSB() - Method in class org.apache.sysds.parser.ForStatementBlock
-
- getInputstoSB() - Method in class org.apache.sysds.parser.StatementBlock
-
- getInputstoSB() - Method in class org.apache.sysds.parser.WhileStatementBlock
-
- getInputVariableNames() - Method in class org.apache.sysds.hops.FunctionOp
-
- getInputVariables() - Method in class org.apache.sysds.api.mlcontext.Script
-
Obtain the input variable names as an unmodifiable set of strings.
- getInstHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- getInstID() - Method in class org.apache.sysds.runtime.instructions.Instruction
-
Getter for instruction unique identifier
- getInstruction(int) - Method in class org.apache.sysds.runtime.controlprogram.BasicProgramBlock
-
- getInstructionName() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- getInstructionParts(String) - Static method in class org.apache.sysds.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.sysds.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.
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.Append
-
- getInstructions(String, String, String, String, String) - Method in class org.apache.sysds.lops.AppendG
-
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.AppendGAlignedSP
-
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.AppendM
-
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.AppendR
-
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.Binary
-
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.BinaryM
-
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.BinaryScalar
-
- getInstructions(String, String) - Method in class org.apache.sysds.lops.BinaryUAggChain
-
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.CentralMoment
-
Function to generate CP centralMoment instruction for weighted operation.
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.CentralMoment
-
Function to generate CP centralMoment instruction for unweighted operation.
- getInstructions(String, String) - Method in class org.apache.sysds.lops.Checkpoint
-
- getInstructions(String, String) - Method in class org.apache.sysds.lops.Compression
-
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.CoVariance
-
Function two generate CP instruction to compute unweighted covariance.
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.CoVariance
-
Function two generate CP instruction to compute weighted covariance.
- getInstructions(String, String) - Method in class org.apache.sysds.lops.CSVReBlock
-
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.Ctable
-
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.CumulativeOffsetBinary
-
- getInstructions(String, String) - Method in class org.apache.sysds.lops.CumulativePartialAggregate
-
- getInstructions(String, String) - Method in class org.apache.sysds.lops.Data
-
Method to get CP instructions for reading/writing scalars and matrices from/to HDFS.
- getInstructions() - Method in class org.apache.sysds.lops.Data
-
Method to generate createvar instruction that updates symbol table with metadata, hdfsfile name, etc.
- getInstructions(String) - Method in class org.apache.sysds.lops.Data
-
- getInstructions(String) - Method in class org.apache.sysds.lops.DataGen
-
Function to generate CP/SP instructions for data generation via Rand and Seq.
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.DnnTransform
-
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.DnnTransform
-
- getInstructions(String, String, String, String, String) - Method in class org.apache.sysds.lops.DnnTransform
-
- getInstructions(String[], String) - Method in class org.apache.sysds.lops.DnnTransform
-
- getInstructions(String, String, String, String, String, String, String) - Method in class org.apache.sysds.lops.DnnTransform
-
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.Federated
-
- getInstructions(String[], String[]) - Method in class org.apache.sysds.lops.FunctionCallCP
-
Method to generate instructions for external functions as well as builtin functions with multiple returns.
- getInstructions(String) - Method in class org.apache.sysds.lops.GroupedAggregate
-
Function to generate CP Grouped Aggregate Instructions.
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.GroupedAggregateM
-
- getInstructions(String, String, String, String, String, String, String) - Method in class org.apache.sysds.lops.LeftIndex
-
- getInstructions(String) - Method in class org.apache.sysds.lops.Lop
-
Method should be overridden if needed
- getInstructions(String, String) - Method in class org.apache.sysds.lops.Lop
-
Method should be overridden if needed
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.Lop
-
Method should be overridden if needed
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.Lop
-
Method should be overridden if needed
- getInstructions(String, String, String, String, String) - Method in class org.apache.sysds.lops.Lop
-
Method should be overridden if needed
- getInstructions(String, String, String, String, String, String) - Method in class org.apache.sysds.lops.Lop
-
Method should be overridden if needed
- getInstructions(String, String, String, String, String, String, String) - Method in class org.apache.sysds.lops.Lop
-
Method should be overridden if needed
- getInstructions(String, String, String, String, String, String, String, String) - Method in class org.apache.sysds.lops.Lop
-
- getInstructions(String[], String) - Method in class org.apache.sysds.lops.Lop
-
- getInstructions(String[], String[]) - Method in class org.apache.sysds.lops.Lop
-
Method should be overridden if needed
- getInstructions() - Method in class org.apache.sysds.lops.Lop
-
Method should be overridden if needed
- getInstructions(int, int, int, int, int, int, int, int) - Method in class org.apache.sysds.lops.Lop
-
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.MapMult
-
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.MapMultChain
-
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.MapMultChain
-
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.MatMultCP
-
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.MMCJ
-
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.MMRJ
-
- getInstructions(String, String) - Method in class org.apache.sysds.lops.MMTSJ
-
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.MMZip
-
- getInstructions(String[], String) - Method in class org.apache.sysds.lops.Nary
-
Generate the complete instruction string for this Lop.
- getInstructions(String) - Method in class org.apache.sysds.lops.ParameterizedBuiltin
-
- getInstructions(String, String) - Method in class org.apache.sysds.lops.PartialAggregate
-
Instruction generation for for CP and Spark
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.PickByCount
-
- getInstructions(String, String) - Method in class org.apache.sysds.lops.PickByCount
-
This version of getInstructions() is called for IQM, executing in CP
Example instances:
iqm:::input:::output
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.PMapMult
-
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.PMMJ
-
- getInstructions(String, String) - Method in class org.apache.sysds.lops.ReBlock
-
- getInstructions(String, String, String, String, String, String, String, String) - Method in class org.apache.sysds.lops.RightIndex
-
- getInstructions(int, int, int, int, int, int, int, int) - Method in class org.apache.sysds.lops.RightIndex
-
- getInstructions(String, String) - Method in class org.apache.sysds.lops.SortKeys
-
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.SortKeys
-
- getInstructions(String, String) - Method in class org.apache.sysds.lops.SpoofFused
-
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.SpoofFused
-
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.SpoofFused
-
- getInstructions(String, String, String, String, String) - Method in class org.apache.sysds.lops.SpoofFused
-
- getInstructions(String, String, String, String, String, String) - Method in class org.apache.sysds.lops.SpoofFused
-
- getInstructions(String, String, String, String, String, String, String) - Method in class org.apache.sysds.lops.SpoofFused
-
- getInstructions(String, String, String, String, String, String, String, String) - Method in class org.apache.sysds.lops.SpoofFused
-
- getInstructions(String[], String) - Method in class org.apache.sysds.lops.SpoofFused
-
- getInstructions(String[], String[]) - Method in class org.apache.sysds.lops.SpoofFused
-
- getInstructions(String, String, String, String, String) - Method in class org.apache.sysds.lops.Sql
-
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.Ternary
-
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.TernaryAggregate
-
- getInstructions(String, String) - Method in class org.apache.sysds.lops.Transform
-
- getInstructions(String, String, String, String, String) - Method in class org.apache.sysds.lops.Transform
-
- getInstructions(String, String, String, String, String, String) - Method in class org.apache.sysds.lops.Transform
-
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.UAggOuterChain
-
- getInstructions(String, String) - Method in class org.apache.sysds.lops.Unary
-
- getInstructions(String, String, String) - Method in class org.apache.sysds.lops.Unary
-
- getInstructions(String, String) - Method in class org.apache.sysds.lops.UnaryCP
-
- getInstructions(String, String, String, String, String) - Method in class org.apache.sysds.lops.WeightedCrossEntropy
-
- getInstructions(String, String, String, String, String) - Method in class org.apache.sysds.lops.WeightedCrossEntropyR
-
- getInstructions(String, String, String, String, String) - Method in class org.apache.sysds.lops.WeightedDivMM
-
- getInstructions(String, String, String, String, String) - Method in class org.apache.sysds.lops.WeightedDivMMR
-
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.WeightedSigmoid
-
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.WeightedSigmoidR
-
- getInstructions(String, String, String, String, String) - Method in class org.apache.sysds.lops.WeightedSquaredLoss
-
- getInstructions(String, String, String, String, String) - Method in class org.apache.sysds.lops.WeightedSquaredLossR
-
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.WeightedUnaryMM
-
- getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.WeightedUnaryMMR
-
- getInstructions() - Method in class org.apache.sysds.runtime.controlprogram.BasicProgramBlock
-
- getInstructionString() - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- getInt(CompilerConfig.ConfigType) - Method in class org.apache.sysds.conf.CompilerConfig
-
- getIntDims() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- getIntDims() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- getIntDims() - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- getIntermediateMemEstimate() - Method in class org.apache.sysds.hops.Hop
-
- getInternalFName(String, Types.DataType) - Static method in enum org.apache.sysds.common.Builtins
-
- getInternalProxy() - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Used internally by MLContextProxy.
- getIntValue(String) - Method in class org.apache.sysds.conf.DMLConfig
-
- getIntValue(LiteralOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
Return the int value of a LiteralOp (as a long).
- getIntValueSafe(LiteralOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getInvalidFunctions() - Method in class org.apache.sysds.hops.ipa.FunctionCallSizeInfo
-
Gets the set of functions that are invalid for statistics
propagation.
- getIterablePredicate() - Method in class org.apache.sysds.parser.ForStatement
-
- getIterations() - Method in class org.apache.sysds.runtime.controlprogram.parfor.Task
-
- getIterator(int, int, boolean, boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Create a column group iterator for a row index range.
- getIterator(int, int, boolean, boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
-
- getIterator(int, int, boolean, boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOffset
-
- getIterator(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOffset
-
- getIterator(int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOffset
-
- getIterator(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
- getIterator(int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
- getIterator(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
-
- getIterator(int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
-
- getIterator(int, int, boolean, boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- getIterator(int, int, boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- getIterator(int, int, int, int, boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- getIterator() - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Get a non-zero iterator over the entire sparse block.
- getIterator(int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Get a non-zero iterator over the partial sparse block [0,ru).
- getIterator(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Get a non-zero iterator over the subblock [rl, ru).
- getIterator() - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- getIterator(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- getIterator(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- getIterator() - Method in class org.apache.sysds.runtime.matrix.data.CTableMap
-
- getIterator() - Method in class org.apache.sysds.runtime.util.LongLongDoubleHashMap
-
- getIterPredicate() - Method in class org.apache.sysds.parser.ForStatementBlock
-
- getIterVar() - Method in class org.apache.sysds.parser.IterablePredicate
-
- getIterVar() - Method in class org.apache.sysds.runtime.controlprogram.ForProgramBlock
-
- getJ() - Method in class org.apache.sysds.runtime.matrix.data.IJV
-
- getJavaRDDStringCSV(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a JavaRDD<String>
in CSV format.
- getJavaRDDStringIJV(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a JavaRDD<String>
in IJV format.
- getJavaSparkContext(MLContext) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Obtain the Java Spark Context
- getJavaSparkContextFromProxy() - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Obtain the Java Spark Context from the MLContextProxy
- getJcudaSparseMatrixPtr() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Pointer to sparse matrix
- getJITCompileTime() - Static method in class org.apache.sysds.utils.Statistics
-
Returns the total time of asynchronous JIT compilation in milliseconds.
- getJobs(StatementBlock, DMLConfig) - Method in class org.apache.sysds.lops.compile.Dag
-
Method to compile a dag generically
- getJVMgcCount() - Static method in class org.apache.sysds.utils.Statistics
-
- getJVMgcTime() - Static method in class org.apache.sysds.utils.Statistics
-
- getK() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- getKahanPlusFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.KahanPlus
-
- getKahanPlusSqFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.KahanPlusSq
-
Get the KahanPlusSq singleton object.
- getKernels() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Returns utility class used to launch custom CUDA kernel, specific to the active GPU for this GPUContext.
- getKey() - Method in class org.apache.sysds.runtime.matrix.data.Pair
-
- getKey1() - Method in class org.apache.sysds.runtime.util.LongLongDoubleHashMap.ADoubleEntry
-
- getKey2() - Method in class org.apache.sysds.runtime.util.LongLongDoubleHashMap.ADoubleEntry
-
- getKill() - Method in class org.apache.sysds.parser.LiveVariableAnalysis
-
- getLabel() - Method in class org.apache.sysds.lops.OutputParameters
-
- getLabels() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.PSWorker
-
- getLanguageSpecificStringValue() - Method in class org.apache.sysds.runtime.instructions.cp.BooleanObject
-
- getLanguageSpecificStringValue() - Method in class org.apache.sysds.runtime.instructions.cp.ScalarObject
-
- getLargestInput(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getLastTimePhase() - Method in class org.apache.sysds.runtime.compress.CompressionStatistics
-
- getLeafNodeEstimate(CostEstimator.TestMeasure, OptNode) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator
-
Main leaf node estimation method - to be overwritten by specific cost estimators
- getLeafNodeEstimate(CostEstimator.TestMeasure, OptNode, LopProperties.ExecType) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator
-
Main leaf node estimation method - to be overwritten by specific cost estimators
- getLeafNodeEstimate(CostEstimator.TestMeasure, OptNode) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimatorHops
-
- getLeafNodeEstimate(CostEstimator.TestMeasure, OptNode, LopProperties.ExecType) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimatorHops
-
- getLeafNodeEstimate(CostEstimator.TestMeasure, OptNode) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimatorRuntime
-
- getLeafNodeEstimate(CostEstimator.TestMeasure, OptNode, LopProperties.ExecType) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimatorRuntime
-
- getLeft() - Method in class org.apache.sysds.hops.estim.MMNode
-
- getLeft() - Method in class org.apache.sysds.parser.BinaryExpression
-
- getLeft() - Method in class org.apache.sysds.parser.BooleanExpression
-
- getLeft() - Method in class org.apache.sysds.parser.RelationalExpression
-
- getLeftGroup() - Method in class org.apache.sysds.runtime.compress.cocode.PlanningCoCodingGroup
-
- getLeftIndexingSparsity(long, long, long, long, long, long) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getLen() - Method in class org.apache.sysds.runtime.instructions.spark.data.RowMatrixBlock
-
- getLength() - Method in class org.apache.sysds.hops.Hop
-
- getLength() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- getLength() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- getLength() - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- getLength() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- getLength() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- getLength() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- getLength() - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- getLessThanEqualsFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.LessThanEquals
-
- getLessThanFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.LessThan
-
- getLevel() - Method in class org.apache.sysds.lops.Lop
-
- getLevel() - Method in class org.apache.sysds.lops.LopProperties
-
- getLinCacheMarking() - Method in class org.apache.sysds.lops.OutputParameters
-
- getLine() - Method in class org.apache.sysds.parser.dml.CustomErrorListener.ParseIssue
-
Obtain line number of the parse issue.
- getLineage() - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getLineage(ExecutionContext, CPOperand...) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
-
- getLineageChilds() - Method in class org.apache.sysds.runtime.instructions.spark.data.LineageObject
-
- getLineageItem(CPOperand) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.ComputationCPInstruction
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.CtableCPInstruction
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.ListIndexingCPInstruction
-
- getLineageItem(int) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.MatrixAppendCPInstruction
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.MatrixBuiltinNaryCPInstruction
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.MatrixIndexingCPInstruction
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.ParameterizedBuiltinCPInstruction
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.ReshapeCPInstruction
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.ScalarBuiltinNaryCPInstruction
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.SpoofCPInstruction
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.ComputationFEDInstruction
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.BuiltinNarySPInstruction
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.ComputationSPInstruction
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.MatrixIndexingSPInstruction
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.RandSPInstruction
-
- getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.WriteSPInstruction
-
- getLineageItem(ExecutionContext) - Method in interface org.apache.sysds.runtime.lineage.LineageTraceable
-
Obtain lineage trace of an instruction with a single output.
- getLineageItemInputstoSB(ArrayList<String>, ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
-
- getLineageItems() - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- getLineageItems(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.MultiReturnBuiltinCPInstruction
-
- getLineageItems(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.MultiReturnParameterizedBuiltinCPInstruction
-
- getLineageItems(ExecutionContext) - Method in interface org.apache.sysds.runtime.lineage.LineageTraceable
-
Obtain lineage trace of an instruction with multiple outputs.
- getLineageLiteral() - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- getLineageLiteral(ScalarObject) - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- getLineageMap() - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- getLineages() - Method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForJobReturn
-
- getLineages(LocalVariableMap[]) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForUtils
-
- getLineageTrace(String) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Capture lineage of the DML/PyDML program and view result as a string.
- getLineNum() - Method in class org.apache.sysds.runtime.instructions.Instruction
-
Getter for instruction line number
- getListObject(CPOperand) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getListObject(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getLiteral(CNode) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- getLiteral() - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- getLiterals() - Method in class org.apache.sysds.runtime.lineage.LineageMap
-
- getLoadedConstraints() - Static method in class org.apache.sysds.runtime.privacy.CheckedConstraintsLog
-
- getLocalMaxMemory() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
Gets the maximum memory [in bytes] of the current JVM.
- getLocalMaxMemoryFraction() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
- getLocalMemBudget() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Returns memory budget (according to util factor) in bytes
- getLocalParallelism() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
Gets the number of logical processors of the current node,
including hyper-threading if enabled.
- getLong(String) - Method in class org.apache.sysds.api.jmlc.ResultVariables
-
Obtain the long value represented by the given output variable.
- getLong(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain a long
output
- getLong(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Get the value of a given cell as long
- getLong(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- getLong(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- getLong(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- getLong(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- getLong(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- getLong(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
-
- getLong(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
-
- getLong(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
-
- getLong(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
-
- getLong(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
-
- getLong(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
-
- getLong(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- getLongDims() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- getLongDims() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- getLongDims() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- getLongDims() - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- getLongValue() - Method in class org.apache.sysds.hops.LiteralOp
-
- getLongValue() - Method in class org.apache.sysds.lops.Data
-
- getLongValue() - Method in class org.apache.sysds.parser.BooleanIdentifier
-
- getLongValue() - Method in class org.apache.sysds.parser.ConstIdentifier
-
- getLongValue() - Method in class org.apache.sysds.parser.DoubleIdentifier
-
- getLongValue() - Method in class org.apache.sysds.parser.IntIdentifier
-
- getLongValue() - Method in class org.apache.sysds.parser.StringIdentifier
-
- getLongValue() - Method in class org.apache.sysds.runtime.instructions.cp.BooleanObject
-
- getLongValue() - Method in class org.apache.sysds.runtime.instructions.cp.DoubleObject
-
- getLongValue() - Method in class org.apache.sysds.runtime.instructions.cp.IntObject
-
- getLongValue() - Method in class org.apache.sysds.runtime.instructions.cp.ScalarObject
-
- getLongValue() - Method in class org.apache.sysds.runtime.instructions.cp.StringObject
-
- getLops() - Method in class org.apache.sysds.hops.Hop
-
- getLops() - Method in class org.apache.sysds.parser.StatementBlock
-
- getMap() - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap.DensityMap
-
- getMap(Long) - Method in class org.apache.sysds.runtime.lineage.LineageDedupBlock
-
- getMapmmMemEstimate(long, long, long, long, long, long, long, long, int, boolean) - Static method in class org.apache.sysds.hops.AggBinaryOp
-
Estimates the memory footprint of MapMult operation depending on which input is put into distributed cache.
- getMappedHop(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingAbstract
-
- getMappedObject(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingRuntime
-
- getMappedParentID(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMapping
-
- getMappedProg(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingAbstract
-
- getMappedProgramBlock(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingAbstract
-
- getMatMultNnz(double, double, long, long, long, boolean) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getMatMultOperator(int) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- getMatMultSparsity(double, double, long, long, long, boolean) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Estimates the result sparsity for Matrix Multiplication A %*% B.
- getMatPoints() - Method in class org.apache.sysds.hops.codegen.opt.PlanPartition
-
- getMatPointsExt() - Method in class org.apache.sysds.hops.codegen.opt.PlanPartition
-
- getMatrix(String) - Method in class org.apache.sysds.api.jmlc.ResultVariables
-
Obtain the matrix represented by the given output variable.
- getMatrix(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a Matrix
.
- getMatrix(LineageItem) - Static method in class org.apache.sysds.runtime.lineage.LineageCache
-
- getMatrixAs2DDoubleArray(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a two-dimensional double
array.
- getMatrixBlock(String) - Method in class org.apache.sysds.api.jmlc.ResultVariables
-
Obtain the matrix represented by the given output variable.
- getMatrixBlockForReuse(MatrixBlock[], int, int, int) - Static method in class org.apache.sysds.runtime.io.MatrixWriter
-
- getMatrixFormat() - Method in class org.apache.sysds.api.mlcontext.MatrixMetadata
-
Obtain the matrix format
- getMatrixInput(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
Pins a matrix variable into memory and returns the internal matrix block.
- getMatrixInputForGPUInstruction(String, String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getMatrixInputs(CPOperand[]) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getMatrixInputs(CPOperand[], boolean) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getMatrixMetadata() - Method in class org.apache.sysds.api.mlcontext.Matrix
-
Obtain the matrix metadata
- getMatrixObject(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a MatrixObject
- getMatrixObject(CPOperand) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getMatrixObject(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getMaxBlocks() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Gets the maximum number of blocks supported by the active cuda device.
- getMaxC(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- getMaxColumn() - Method in class org.apache.sysds.runtime.matrix.data.CTableMap
-
- getMaxIndexInRange(int) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- getMaxInputDim(Hop, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getMaxInputDim(DataCharacteristics[], boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getMaxLiveVectorIntermediates(CNode, CNode, Map<Long, Set<Long>>, Set<Pair<Long, Long>>) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- getMaxNcolInput(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getMaxNrowInput(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getMaxNumThreads() - Method in class org.apache.sysds.hops.MultiThreadedHop
-
- getMaxNumThreads() - Static method in class org.apache.sysds.utils.NativeHelper
-
- getMaxProblemSize() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
Determines the maximum problem size, in terms of the maximum
total number of inner loop iterations, of the entire subtree.
- getMaxRow() - Method in class org.apache.sysds.runtime.matrix.data.CTableMap
-
- getMaxSharedMemory() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Gets the shared memory per block supported by the active cuda device.
- getMaxThreadsPerBlock() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Gets the maximum number of threads per block for "active" GPU.
- getMaxValue() - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- getMaxValue() - Method in class org.apache.sysds.runtime.instructions.spark.RandSPInstruction
-
- getMaxVectorIntermediates(CNode) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- getMBValue() - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
-
- getMeanFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.Mean
-
- getMeans() - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
-
- getMemDeletes() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- getMemEstimate() - Method in class org.apache.sysds.hops.Hop
-
NOTES:
* Purpose: Whenever the output dimensions / sparsity of a hop are unknown, this hop
should store its worst-case output statistics (if known) in that table.
- getMemHits() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- getMemoryManager() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
- getMergedIndexes(int[], int[]) - Static method in class org.apache.sysds.runtime.compress.cocode.PlanningCoCodingGroup
-
- getMessage() - Method in class org.apache.sysds.parser.dml.CustomErrorListener.ParseIssue
-
Obtain the message describing the parse issue.
- getMessage() - Method in exception org.apache.sysds.parser.ParseException
-
Obtain the exception message.
- getMetaData() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- getMetaData(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getMetaData() - Method in class org.apache.sysds.runtime.instructions.cp.Data
-
- getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.Encoder
-
Construct a frame block out of the transform meta data.
- getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderBin
-
- getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderComposite
-
- getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderDummycode
-
- getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderFeatureHash
-
- getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
-
- getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
-
- getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderPassThrough
-
- getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderRecode
-
- getMethod() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcCall
-
- getMethod(int) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
-
- GetMIMBFromRow - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- GetMIMBFromRow() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.GetMIMBFromRow
-
- getMinSize() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
-
- getMinus1MultiplyFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.Minus1Multiply
-
- getMinusFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.Minus
-
- getMinusNzFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.MinusNz
-
- getMinValue() - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- getMinValue() - Method in class org.apache.sysds.runtime.instructions.spark.RandSPInstruction
-
- getMisc() - Method in class org.apache.sysds.hops.estim.MMNode
-
- getMisc(int) - Method in class org.apache.sysds.hops.estim.MMNode
-
- getMMChainType() - Method in class org.apache.sysds.runtime.instructions.cp.MMChainCPInstruction
-
- getMMChainType() - Method in class org.apache.sysds.runtime.instructions.fed.MMChainFEDInstruction
-
- getMMTSJtype() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeOuterProduct
-
- getMMTSJType() - Method in class org.apache.sysds.runtime.instructions.cp.MMTSJCPInstruction
-
- getMMTSJType() - Method in class org.apache.sysds.runtime.instructions.gpu.MMTSJGPUInstruction
-
- getMMultMethod() - Method in class org.apache.sysds.hops.AggBinaryOp
-
- getModeNames() - Method in class org.apache.sysds.parser.dml.DmlLexer
-
- getMTDFileName(String) - Static method in class org.apache.sysds.parser.DataExpression
-
- getMultiLevelFnHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- getMultiLevelSBHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- getMultiply2FnObject() - Static method in class org.apache.sysds.runtime.functionobjects.Multiply2
-
- getMultiplyFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.Multiply
-
- getMvValue() - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock.ColumnMetadata
-
- getName() - Method in class org.apache.sysds.api.mlcontext.Script
-
Obtain the script name.
- getName() - Method in enum org.apache.sysds.common.Builtins
-
- getName() - Method in class org.apache.sysds.hops.Hop
-
- getName() - Method in class org.apache.sysds.parser.DataIdentifier
-
- getName() - Method in class org.apache.sysds.parser.ExpressionList
-
- getName() - Method in class org.apache.sysds.parser.FunctionStatement
-
- getName() - Method in class org.apache.sysds.parser.ParameterExpression
-
- getName() - Method in class org.apache.sysds.parser.StatementBlock
-
- getName() - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- getName(int) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- getNamedInput(String) - Method in class org.apache.sysds.lops.ParameterizedBuiltin
-
- getNamedInputLop(String) - Method in class org.apache.sysds.lops.Data
-
- getNamedInputLop(String, String) - Method in class org.apache.sysds.lops.Data
-
- getNamedNSFunctionStatementBlocks() - Method in class org.apache.sysds.parser.DMLProgram
-
- getNames() - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- getNamespace() - Method in class org.apache.sysds.parser.FunctionCallIdentifier
-
- getNamespace() - Method in class org.apache.sysds.parser.ImportStatement
-
- getNamespace() - Method in class org.apache.sysds.runtime.instructions.cp.FunctionCallCPInstruction
-
- getNamespaces() - Method in class org.apache.sysds.parser.DMLProgram
-
- getNamespaceSafe(Token) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- getNAStrings() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
-
- getNAStrings() - Method in class org.apache.sysds.runtime.transform.TfUtils
-
- getNextFedDataID() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
-
- getNextID() - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.IDSequence
-
Creates the next ID, if overflow a RuntimeException is thrown.
- getNextIndexes(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Calculates the next index array.
- getNextIndexes(int[], int[]) - Static method in class org.apache.sysds.runtime.data.TensorBlock
-
Calculates the next index array.
- getNextIndexes(int[]) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
Calculates the next index array.
- getNextUniqueFilename() - Method in class org.apache.sysds.lops.compile.Dag
-
- getNextUniqueFilenameSuffix() - Static method in class org.apache.sysds.lops.compile.Dag
-
- getNextUniqueVarname(Types.DataType) - Static method in class org.apache.sysds.lops.compile.Dag
-
- getNnz() - Method in class org.apache.sysds.hops.Hop
-
- getNnz(long, long, double) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getNnz() - Method in class org.apache.sysds.lops.OutputParameters
-
- getNnz() - Method in class org.apache.sysds.parser.Identifier
-
- getNnz() - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
- getNnz() - Method in class org.apache.sysds.runtime.controlprogram.caching.TensorObject
-
- getNnz(String, boolean) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Being allocated is a prerequisite for computing nnz.
- getNnz(GPUContext, String, MatrixObject, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Note: if the matrix is in dense format, it explicitly re-computes the number of nonzeros.
- getNodeList() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- getNodeList(OptNode.ExecType) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- getNodeType() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- getNonMVCount(int) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
-
- getNonPartitionedBroadcast() - Method in class org.apache.sysds.runtime.instructions.spark.data.BroadcastObject
-
- getNonPartitionedBroadcastSize() - Method in class org.apache.sysds.runtime.instructions.spark.data.BroadcastObject
-
- getNonZeros() - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix
-
- getNonZeros() - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap.DensityMap
-
- getNonZeros() - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram.MatrixHistogram
-
- getNonZeros() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- getNonZeros() - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- getNonZeros() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- getNonZeros(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- getNonZeros() - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- getNonZeros() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- getNonZeros() - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- getNonZeros() - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- getNonZeros() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- getNonZeros() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- getNonZeros() - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- getNonZeros() - Method in class org.apache.sysds.runtime.util.LongLongDoubleHashMap
-
- getNonZerosBound() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- getNonZerosBound() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- getNoOfCompiledSPInst() - Static method in class org.apache.sysds.utils.Statistics
-
- getNoOfExecutedGPUInst() - Static method in class org.apache.sysds.utils.GPUStatistics
-
- getNoOfExecutedSPInst() - Static method in class org.apache.sysds.utils.Statistics
-
- getNotEqualsFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.NotEquals
-
- getNotFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.Not
-
- getNthRow(int) - Method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNInputRowFetcher
-
Copy the nth row and return the dense pointer
- getNumberOfValues(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ADictionary
-
Get the number of values given that the column group has n columns
- getNumberOfValues(int) - Method in class org.apache.sysds.runtime.compress.colgroup.Dictionary
-
- getNumberOfValues(int) - Method in class org.apache.sysds.runtime.compress.colgroup.QDictionary
-
- getNumBlocks() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- getNumBlocks(int) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- getNumBlocks() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- getNumBlocks() - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- getNumBlocks(int) - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- getNumCacheableData() - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- getNumColBlocks() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- getNumColBlocks() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- getNumCols() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- getNumCols() - Method in class org.apache.sysds.lops.OutputParameters
-
- getNumCols() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Obtain the number of columns in this column group.
- getNumCols() - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- getNumCols() - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBroadcast
-
- getNumCols() - Method in class org.apache.sysds.runtime.transform.encode.Encoder
-
- getNumCols() - Method in class org.apache.sysds.runtime.transform.encode.EncoderComposite
-
- getNumCols() - Method in class org.apache.sysds.runtime.transform.encode.EncoderDummycode
-
- getNumCols() - Method in class org.apache.sysds.runtime.transform.TfUtils
-
- getNumColumnBlocks() - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- getNumColumnBlocks() - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBroadcast
-
- getNumColumns() - Method in class org.apache.sysds.api.mlcontext.Metadata
-
Obtain the number of columns
- getNumColumns() - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix
-
- getNumColumns() - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap.DensityMap
-
- getNumColumns() - Method in class org.apache.sysds.runtime.compress.utils.ABitmap
-
- getNumColumns() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- getNumColumns() - Method in interface org.apache.sysds.runtime.controlprogram.caching.CacheBlock
-
- getNumColumns() - Method in class org.apache.sysds.runtime.controlprogram.caching.FrameObject
-
- getNumColumns() - Method in class org.apache.sysds.runtime.controlprogram.caching.TensorObject
-
- getNumColumns(DataCharacteristics) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
-
- getNumColumns() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- getNumColumns() - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- getNumColumns() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- getNumColumns() - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- getNumColumns() - Method in class org.apache.sysds.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.sysds.runtime.matrix.data.MatrixBlock
-
- getNumColumns() - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- getNumColumns() - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- getNumColumnsOrig() - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap.DensityMap
-
- getNumDimBlocks(int) - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- getNumDims() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- getNumDims() - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- getNumDims() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- getNumDims() - Method in class org.apache.sysds.runtime.data.TensorIndexes
-
- getNumDims() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- getNumDims() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- getNumDims() - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- getNumDistinct() - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock.ColumnMetadata
-
- getNumEvaluatedPlans() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.Optimizer
-
- getNumExecutedIterations() - Method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForJobReturn
-
- getNumExecutedTasks() - Method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForJobReturn
-
- getNumExecutors() - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
Obtain the number of executors in the cluster (excluding the driver).
- getNumExecutors() - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext.SparkClusterConfig
-
- getNumGPUContexts() - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
Gets the number of GPUContexts
- getNumInstructions() - Method in class org.apache.sysds.runtime.controlprogram.BasicProgramBlock
-
- getNumIntermediates() - Method in class org.apache.sysds.runtime.codegen.SpoofRowwise
-
- getNumIterations(ForProgramBlock, long) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getNumIterations(ForProgramBlock, LocalVariableMap, long) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getNumIterations() - Method in class org.apache.sysds.runtime.controlprogram.parfor.TaskPartitioner
-
- getNumIterations() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- getNumMappers() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getNumNonZeros() - Method in class org.apache.sysds.api.mlcontext.Metadata
-
Obtain the number of non-zero values
- getNumOffsets() - Method in class org.apache.sysds.runtime.compress.utils.ABitmap
-
- getNumOffsets(int) - Method in class org.apache.sysds.runtime.compress.utils.ABitmap
-
- getNumOffsets() - Method in class org.apache.sysds.runtime.compress.utils.BitmapLossy
-
- getNumOffsets(int) - Method in class org.apache.sysds.runtime.compress.utils.BitmapLossy
-
- getNumOutputs() - Method in class org.apache.sysds.runtime.instructions.cp.MultiReturnBuiltinCPInstruction
-
- getNumParams() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
-
- getNumParts(DataCharacteristics) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
-
- getNumPinnedObjects() - Static method in class org.apache.sysds.utils.Statistics
-
- getNumPointers() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
Get total number of rmvared pointers
- getNumPreferredPartitions(DataCharacteristics, JavaPairRDD<?, ?>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- getNumPreferredPartitions(DataCharacteristics) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- getNumReducers(boolean) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Returns the number of reducers that potentially run in parallel.
- getNumReferences() - Method in class org.apache.sysds.runtime.instructions.spark.data.LineageObject
-
- getNumRemovedRows(boolean[]) - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
-
- getNumRemovedRows() - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
-
- getNumRemovedRowsColumns() - Method in enum org.apache.sysds.common.Types.CorrectionLocationType
-
- getNumRmRows() - Method in class org.apache.sysds.runtime.transform.meta.TfOffsetMap
-
- getNumRowBlocks() - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- getNumRowBlocks() - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBroadcast
-
- getNumRowBlocks() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- getNumRowBlocks() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- getNumRows() - Method in class org.apache.sysds.api.mlcontext.Metadata
-
Obtain the number of rows
- getNumRows() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- getNumRows() - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix
-
- getNumRows() - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap.DensityMap
-
- getNumRows() - Method in class org.apache.sysds.lops.OutputParameters
-
- getNumRows() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Get number of rows contained in the ColGroup.
- getNumRows() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- getNumRows() - Method in interface org.apache.sysds.runtime.controlprogram.caching.CacheBlock
-
- getNumRows() - Method in class org.apache.sysds.runtime.controlprogram.caching.FrameObject
-
- getNumRows() - Method in class org.apache.sysds.runtime.controlprogram.caching.TensorObject
-
- getNumRows(DataCharacteristics) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
-
- getNumRows() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- getNumRows() - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- getNumRows() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- getNumRows() - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- getNumRows() - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBroadcast
-
- getNumRows() - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- getNumRows() - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Get the number of rows of the frame block.
- getNumRows() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- getNumRows() - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- getNumRows() - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- getNumRowsOrig() - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap.DensityMap
-
- getNumSkipPlans(boolean[]) - Method in class org.apache.sysds.hops.codegen.opt.ReachabilityGraph
-
- getNumStatementBlocks() - Method in class org.apache.sysds.parser.DMLProgram
-
- getNumStatements() - Method in class org.apache.sysds.parser.StatementBlock
-
- getNumThreads() - Method in class org.apache.sysds.runtime.matrix.operators.AggregateBinaryOperator
-
- getNumThreads() - Method in class org.apache.sysds.runtime.matrix.operators.AggregateTernaryOperator
-
- getNumThreads() - Method in class org.apache.sysds.runtime.matrix.operators.AggregateUnaryOperator
-
- getNumThreads() - Method in class org.apache.sysds.runtime.matrix.operators.ReorgOperator
-
- getNumThreads() - Method in class org.apache.sysds.runtime.matrix.operators.ScalarOperator
-
- getNumThreads() - Method in class org.apache.sysds.runtime.matrix.operators.UnaryOperator
-
- getNumTotalPlans() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.Optimizer
-
- getNumValues() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupValue
-
Obtain number of distinct sets of values associated with the bitmaps in this column group.
- getNumValues() - Method in class org.apache.sysds.runtime.compress.utils.ABitmap
-
Obtain number of distinct value groups in the column.
- getNumValues() - Method in class org.apache.sysds.runtime.compress.utils.Bitmap
-
- getNumValues() - Method in class org.apache.sysds.runtime.compress.utils.BitmapLossy
-
Obtain number of distinct values in the column.
- getNumVectorIntermediates() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
-
- getObjectRowIterator() - Method in class org.apache.sysds.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(Types.ValueType[]) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Get a row iterator over the frame where all fields are encoded
as boxed objects according to the value types of the provided
target schema.
- getObjectRowIterator(int[]) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Get a row iterator over the frame where all selected fields are
encoded as boxed objects according to their value types.
- getObjectRowIterator(int, int) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Get a row iterator over the frame where all fields are encoded
as boxed objects according to their value types.
- getObjectRowIterator(int, int, int[]) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Get a row iterator over the frame where all selected fields are
encoded as boxed objects according to their value types.
- getOffset(long) - Method in class org.apache.sysds.runtime.transform.meta.TfOffsetMap
-
- getOffsetColumnIndexFnObject(int) - Static method in class org.apache.sysds.runtime.functionobjects.OffsetColumnIndex
-
- getOffsetList() - Method in class org.apache.sysds.runtime.compress.utils.ABitmap
-
- getOffsetsList(int) - Method in class org.apache.sysds.runtime.compress.utils.ABitmap
-
- getOffsetsList(int) - Method in class org.apache.sysds.runtime.compress.utils.BitmapLossy
-
- getOp() - Method in class org.apache.sysds.hops.AggUnaryOp
-
- getOp() - Method in class org.apache.sysds.hops.BinaryOp
-
- getOp() - Method in class org.apache.sysds.hops.DataGenOp
-
- getOp() - Method in class org.apache.sysds.hops.DataOp
-
- getOp() - Method in class org.apache.sysds.hops.DnnOp
-
- getOp() - Method in class org.apache.sysds.hops.estim.MMNode
-
- getOp() - Method in class org.apache.sysds.hops.NaryOp
-
- getOp() - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- getOp() - Method in class org.apache.sysds.hops.QuaternaryOp
-
- getOp() - Method in class org.apache.sysds.hops.ReorgOp
-
- getOp() - Method in class org.apache.sysds.hops.TernaryOp
-
- getOp() - Method in class org.apache.sysds.hops.UnaryOp
-
- getOp() - Method in class org.apache.sysds.lops.DnnTransform
-
method to get operation type
- getOp() - Method in class org.apache.sysds.lops.Nary
-
- getOp() - Method in class org.apache.sysds.lops.ParameterizedBuiltin
-
- getOp() - Method in class org.apache.sysds.lops.Transform
-
method to get operation type
- getOpcode(Types.OpOp2) - Static method in class org.apache.sysds.lops.BinaryM
-
- getOpcode(Types.AggOp, Types.Direction) - Static method in class org.apache.sysds.lops.PartialAggregate
-
- getOpCode() - Method in class org.apache.sysds.parser.BinaryExpression
-
- getOpCode() - Method in class org.apache.sysds.parser.BooleanExpression
-
- getOpCode() - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- getOpCode() - Method in class org.apache.sysds.parser.DataExpression
-
- getOpCode() - Method in class org.apache.sysds.parser.FunctionCallIdentifier
-
- getOpCode() - Method in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- getOpCode() - Method in class org.apache.sysds.parser.RelationalExpression
-
- getOpcode() - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- getOpCode(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- getOpcode() - Method in class org.apache.sysds.runtime.lineage.LineageItem
-
- getOperationType() - Method in class org.apache.sysds.lops.Binary
-
- getOperationType() - Method in class org.apache.sysds.lops.BinaryM
-
- getOperationType() - Method in class org.apache.sysds.lops.BinaryScalar
-
- getOperationType() - Method in class org.apache.sysds.lops.Ctable
-
method to get operation type
- getOperationType(String) - Static method in class org.apache.sysds.lops.Ctable
-
- getOperationType() - Method in class org.apache.sysds.lops.Data
-
method to get operation type, i.e.
- getOperationType() - Method in class org.apache.sysds.lops.PickByCount
-
- getOperator() - Method in class org.apache.sysds.runtime.instructions.cp.BinaryCPInstruction
-
- getOperator() - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- getOperatorClass() - Method in class org.apache.sysds.runtime.instructions.cp.SpoofCPInstruction
-
- getOperatorTypesCol() - Method in class org.apache.sysds.runtime.privacy.propagation.MatrixMultiplicationPropagator
-
Gets the operator types of all columns of the right-hand input in the matrix multiplication.
- getOperatorTypesRow() - Method in class org.apache.sysds.runtime.privacy.propagation.MatrixMultiplicationPropagator
-
Gets the operator types of all rows of the left-hand input in the matrix multiplication.
- getOpString() - Method in class org.apache.sysds.hops.AggBinaryOp
-
- getOpString() - Method in class org.apache.sysds.hops.AggUnaryOp
-
- getOpString() - Method in class org.apache.sysds.hops.BinaryOp
-
- getOpString() - Method in class org.apache.sysds.hops.codegen.SpoofFusedOp
-
- getOpString() - Method in class org.apache.sysds.hops.DataGenOp
-
- getOpString() - Method in class org.apache.sysds.hops.DataOp
-
- getOpString() - Method in class org.apache.sysds.hops.DnnOp
-
- getOpString() - Method in class org.apache.sysds.hops.FunctionOp
-
- getOpString() - Method in class org.apache.sysds.hops.Hop
-
- getOpString() - Method in class org.apache.sysds.hops.IndexingOp
-
- getOpString() - Method in class org.apache.sysds.hops.LeftIndexingOp
-
- getOpString() - Method in class org.apache.sysds.hops.LiteralOp
-
- getOpString() - Method in class org.apache.sysds.hops.NaryOp
-
- getOpString() - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- getOpString() - Method in class org.apache.sysds.hops.QuaternaryOp
-
- getOpString() - Method in class org.apache.sysds.hops.ReorgOp
-
- getOpString() - Method in class org.apache.sysds.hops.TernaryOp
-
- getOpString() - Method in class org.apache.sysds.hops.UnaryOp
-
- getOptChangeInSize() - Method in class org.apache.sysds.runtime.compress.cocode.PlanningMemoTable
-
- getOptimizationMode() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- getOptLevel() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getOptMode() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.Optimizer
-
- getOptMode() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerConstrained
-
- getOptMode() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerHeuristic
-
- getOptMode() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerRuleBased
-
- getOptNode(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMapping
-
- getOpType() - Method in class org.apache.sysds.lops.SortKeys
-
- getOrCreate(PlanningCoCodingGroup, PlanningCoCodingGroup, CompressedSizeEstimator, int) - Method in class org.apache.sysds.runtime.compress.cocode.PlanningMemoTable
-
- getOrCreate(CPOperand) - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- getOrCreate(CPOperand) - Method in class org.apache.sysds.runtime.lineage.LineageMap
-
- getOrCreateLineageItem(CPOperand) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getOrFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.Or
-
- getOrigDim1() - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- getOrigDim2() - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- getOtherInput(Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getOtherValue() - Method in class org.apache.sysds.runtime.matrix.data.WeightedPair
-
- getOuterNonZeros(long, long, long, long, Types.OpOp2) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getOuterProdType() - Method in class org.apache.sysds.runtime.codegen.SpoofOuterProduct
-
- getOuterProductType(Hop, Hop, Hop, Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- getOutProdType() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeOuterProduct
-
- getOutput() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- getOutput() - Method in class org.apache.sysds.parser.Expression
-
Obtain identifier.
- getOutput() - Method in class org.apache.sysds.runtime.instructions.cp.BuiltinNaryCPInstruction
-
- getOutput() - Method in class org.apache.sysds.runtime.instructions.cp.ComputationCPInstruction
-
- getOutput(int) - Method in class org.apache.sysds.runtime.instructions.cp.MultiReturnBuiltinCPInstruction
-
- getOutput(int) - Method in class org.apache.sysds.runtime.instructions.cp.MultiReturnParameterizedBuiltinCPInstruction
-
- getOutput() - Method in class org.apache.sysds.runtime.instructions.cp.SqlCPInstruction
-
- getOutput() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- getOutput(int) - Method in class org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction
-
- getOutputDimType() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- getOutputDimType() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
-
- getOutputDimType() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeOuterProduct
-
- getOutputDimType() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
-
- getOutputDimType() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
-
- getOutputMemEstimate() - Method in class org.apache.sysds.hops.Hop
-
- getOutputNames() - Method in class org.apache.sysds.runtime.instructions.cp.MultiReturnBuiltinCPInstruction
-
- getOutputNames() - Method in class org.apache.sysds.runtime.instructions.cp.MultiReturnParameterizedBuiltinCPInstruction
-
- getOutputNamesofSB() - Method in class org.apache.sysds.parser.StatementBlock
-
- getOutputParameters() - Method in class org.apache.sysds.lops.Lop
-
Method to get output parameters
- getOutputParams() - Method in class org.apache.sysds.parser.FunctionStatement
-
- getOutputParams() - Method in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
-
- getOutputs() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
-
- getOutputs() - Method in class org.apache.sysds.hops.FunctionOp
-
- getOutputs() - Method in class org.apache.sysds.lops.Lop
-
Method to get output of Lops
- getOutputs() - Method in class org.apache.sysds.parser.Expression
-
Obtain identifiers.
- getOutputs() - Method in class org.apache.sysds.runtime.instructions.cp.MultiReturnBuiltinCPInstruction
-
- getOutputs() - Method in class org.apache.sysds.runtime.instructions.cp.MultiReturnParameterizedBuiltinCPInstruction
-
- getOutputsofSB() - Method in class org.apache.sysds.parser.StatementBlock
-
- getOutputVariableName() - Method in class org.apache.sysds.runtime.instructions.cp.ComputationCPInstruction
-
- getOutputVariableName() - Method in class org.apache.sysds.runtime.instructions.cp.SqlCPInstruction
-
- getOutputVariableName() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- getOutputVariableName() - Method in class org.apache.sysds.runtime.instructions.fed.ComputationFEDInstruction
-
- getOutputVariableName() - Method in class org.apache.sysds.runtime.instructions.spark.ComputationSPInstruction
-
- getOutputVariableNames() - Method in class org.apache.sysds.hops.FunctionOp
-
- getOutputVariables() - Method in class org.apache.sysds.api.mlcontext.Script
-
Obtain the output variable names as an unmodifiable set of strings.
- getP(long, long, long, long) - Static method in class org.apache.sysds.runtime.util.DnnUtils
-
- getPage(int) - Static method in class org.apache.sysds.runtime.controlprogram.caching.PageCache
-
- getPairList(CacheBlock) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheBlockFactory
-
- getParallelBinaryReadParallelism() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getParallelBinaryWriteParallelism() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getParallelTextReadParallelism() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Returns the degree of parallelism used for parallel text read.
- getParallelTextWriteParallelism() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Returns the degree of parallelism used for parallel text write.
- getParam(String) - Method in class org.apache.sysds.hops.DataGenOp
-
- getParam(int) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
-
- getParam(OptNode.ParamType) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- getParam(String) - Method in class org.apache.sysds.runtime.instructions.cp.ParameterizedBuiltinCPInstruction
-
- getParam(String) - Method in class org.apache.sysds.runtime.instructions.fed.ParameterizedBuiltinFEDInstruction
-
- getParamBuiltinFunctionExpression(ParserRuleContext, String, ArrayList<ParameterExpression>, String) - Static method in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- getParameterHop(String) - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- getParameterIndex(String) - Method in class org.apache.sysds.hops.DataOp
-
- getParameterizedBuiltinFnObject(String) - Static method in class org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin
-
- getParameterizedBuiltinFnObject(String, String) - Static method in class org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin
-
- getParameterMap() - Method in class org.apache.sysds.runtime.instructions.cp.ParameterizedBuiltinCPInstruction
-
- getParameterMap() - Method in class org.apache.sysds.runtime.instructions.fed.ParameterizedBuiltinFEDInstruction
-
- getParamExprs() - Method in class org.apache.sysds.parser.FunctionCallIdentifier
-
- getParamIndex(String) - Method in class org.apache.sysds.hops.DataGenOp
-
- getParamIndexMap() - Method in class org.apache.sysds.hops.DataGenOp
-
- getParamIndexMap() - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- getParams() - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction
-
- getParent() - Method in class org.apache.sysds.hops.Hop
-
- getParforInitTime() - Static method in class org.apache.sysds.utils.Statistics
-
- getParforMergeTime() - Static method in class org.apache.sysds.utils.Statistics
-
- getParforOptCount() - Static method in class org.apache.sysds.utils.Statistics
-
- getParforOptTime() - Static method in class org.apache.sysds.utils.Statistics
-
- getParForParam(String) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- getParForParams() - Method in class org.apache.sysds.parser.IterablePredicate
-
- getParForParams() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- getParseExceptionList() - Method in class org.apache.sysds.parser.Expression
-
- getParseIssues() - Method in class org.apache.sysds.parser.dml.CustomErrorListener
-
Obtain the list of parse issues.
- getParseIssues() - Method in exception org.apache.sysds.parser.ParseException
-
Obtain the list of parse issues that occurred.
- getParseIssues() - Method in class org.apache.sysds.parser.ParserWrapper
-
- getParseIssueType() - Method in class org.apache.sysds.parser.dml.CustomErrorListener.ParseIssue
-
Obtain the type of the parse issue.
- getPartFileName(int) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- getPartition() - Method in class org.apache.sysds.hops.codegen.opt.PlanPartition
-
- getPartition(Object) - Method in class org.apache.sysds.runtime.instructions.spark.data.BlockPartitioner
-
- getPartitionedBroadcast() - Method in class org.apache.sysds.runtime.instructions.spark.data.BroadcastObject
-
- getPartitionedBroadcastSize() - Method in class org.apache.sysds.runtime.instructions.spark.data.BroadcastObject
-
- getPartitionFileName(IndexRange, int) - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
- getPartitionFormat() - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
- getPartitionSize() - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
- getPath() - Method in class org.apache.sysds.runtime.lineage.LineageDedupBlock
-
- getPathMaps() - Method in class org.apache.sysds.runtime.lineage.LineageDedupBlock
-
- getPathValue() - Method in class org.apache.sysds.parser.PathStatement
-
- getPdf() - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- getPdf() - Method in class org.apache.sysds.runtime.instructions.spark.RandSPInstruction
-
- getPdfParams() - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- getPdfParams() - Method in class org.apache.sysds.runtime.instructions.spark.RandSPInstruction
-
- getPinnedDataSize() - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
-
- getPlanInputType() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.Optimizer
-
- getPlanInputType() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerRuleBased
-
- getPlanInputType() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTree
-
- getPlanRefIndex() - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- getPlans() - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- getPlansExcludeListed() - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- getPlusFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.Plus
-
- getPoolingBackwardWorkers(DnnParameters, boolean, LibMatrixDNN.PoolingType) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNPooling
-
Factory method that returns list of callable tasks for performing maxpooling backward operation
- getPoolingWorkers(DnnParameters, LibMatrixDNN.PoolingType) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNPooling
-
Factory method that returns list of callable tasks for performing pooling operation
- getPower2FnObject() - Static method in class org.apache.sysds.runtime.functionobjects.Power2
-
- getPowerFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.Power
-
- getPredicate() - Method in class org.apache.sysds.parser.ConditionalPredicate
-
- getPredicate() - Method in class org.apache.sysds.runtime.controlprogram.IfProgramBlock
-
- getPredicate() - Method in class org.apache.sysds.runtime.controlprogram.WhileProgramBlock
-
- getPredicateHops() - Method in class org.apache.sysds.parser.IfStatementBlock
-
- getPredicateHops() - Method in class org.apache.sysds.parser.WhileStatementBlock
-
- getPredicateLops() - Method in class org.apache.sysds.parser.IfStatementBlock
-
- getPredicateLops() - Method in class org.apache.sysds.parser.WhileStatementBlock
-
- getPrefixFromSparkDebugInfo(String) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- getPrivacy() - Method in class org.apache.sysds.hops.Hop
-
- getPrivacy() - Method in class org.apache.sysds.parser.Identifier
-
- getPrivacyConstraint() - Method in class org.apache.sysds.lops.Lop
-
- getPrivacyConstraint() - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- getPrivacyConstraint() - Method in class org.apache.sysds.runtime.instructions.cp.Data
-
- getPrivacyConstraint() - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- getPrivacyLevel(DataRange) - Method in interface org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacy
-
Get the data ranges and related privacy levels within given data search range.
- getPrivacyLevel(DataRange) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyList
-
- getPrivacyLevel(DataRange) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyMap
-
- getPrivacyLevel() - Method in class org.apache.sysds.runtime.privacy.PrivacyConstraint
-
- getPrivacyLevelOfElement(long[]) - Method in interface org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacy
-
Get the data ranges and related privacy levels of the element with the given index.
- getPrivacyLevelOfElement(long[]) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyList
-
- getPrivacyLevelOfElement(long[]) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyMap
-
- getProducesIntermediateOutput() - Method in class org.apache.sysds.lops.Lop
-
- getProducesIntermediateOutput() - Method in class org.apache.sysds.lops.LopProperties
-
- getProgram() - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getProgram() - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- getProgramBlocks() - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- getProjectInfo() - Static method in class org.apache.sysds.api.mlcontext.ProjectInfo
-
Return a ProjectInfo singleton instance.
- getQ(long, long, long, long) - Static method in class org.apache.sysds.runtime.util.DnnUtils
-
- getQueueSize() - Static method in class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
-
- getRank() - Method in enum org.apache.sysds.hops.codegen.template.TemplateBase.TemplateType
-
- getRDD() - Method in class org.apache.sysds.runtime.instructions.spark.data.RDDObject
-
- getRDDHandle() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- getRDDHandleForFrameObject(FrameObject, Types.FileFormat) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
FIXME: currently this implementation assumes matrix representations but frame signature
in order to support the old transform implementation.
- getRDDHandleForMatrixObject(MatrixObject, Types.FileFormat) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- getRDDHandleForMatrixObject(MatrixObject, Types.FileFormat, int, boolean) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- getRDDHandleForTensorObject(TensorObject, Types.FileFormat, int, boolean) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- getRDDHandleForVariable(String, Types.FileFormat, int, boolean) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- getRDDStringCSV(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a RDD<String>
in CSV format.
- getRDDStringIJV(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a RDD<String>
in IJV format.
- getReachable() - Method in class org.apache.sysds.lops.Lop
-
- getReachableFunctions() - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Returns all functions that are reachable either directly or indirectly
form the main program, except the main program itself.
- getReachableFunctions(Set<String>) - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Returns all functions that are reachable either directly or indirectly
form the main program, except the main program itself and the given
exclude-list of function names.
- getReadOnlyParentMatrixVars() - Method in class org.apache.sysds.parser.ParForStatementBlock
-
- getRecodeMap(int) - Method in class org.apache.sysds.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.
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.sysds.runtime.util.BinaryBlockInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.sysds.runtime.util.InputStreamInputFormat
-
- getReduceAllFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.ReduceAll
-
- getReduceColFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.ReduceCol
-
- getReduceDiagFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.ReduceDiag
-
- getReduceRowFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.ReduceRow
-
- getRegisteredOutputs() - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
-
- getRelationalOp(String) - Static method in class org.apache.sysds.parser.Expression
-
Convert string value to relational operator.
- getReleaseTime() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- getRelevantNodeList() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- getReluBackwardWorkers(DnnParameters) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNRelu
-
Factory method that returns list of callable tasks for performing relu backward operation
- getRemoteParallelMapTasks() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
Gets the number of remote parallel map slots.
- getRemoteParallelNodes() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
Gets the number of cluster nodes (number of tasktrackers).
- getRemoteParallelReduceTasks() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
Gets the total number of remote parallel reduce slots.
- getRemovedBranches() - Method in class org.apache.sysds.hops.rewrite.ProgramRewriteStatus
-
- getReplacement(int) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
-
- getReplacements() - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
-
- getRequiredPartialResult(Operator) - Method in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
- getRequiredResult(Operator) - Method in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
Return the result of the aggregated operation given the
operator.
- getRequiredResult(CMOperator.AggregateOperationTypes) - Method in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
Return the result of the aggregated operation given the
operation type.
- getResult() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamServer
-
- getResultModel() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcResponse
-
- getResults() - Method in class org.apache.sysds.api.mlcontext.Script
-
Obtain the results of the script execution.
- getResults(Future<FederatedResponse>[]) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
-
- getResults(List<Tuple2<Long, String>>, Log) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForUtils
-
- getResultVariables() - Method in class org.apache.sysds.parser.ParForStatementBlock
-
- getResultVariables() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ParForBody
-
- getResultVariables() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- getReusableScalarVariables(DMLProgram, StatementBlock, LocalVariableMap) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.ProgramRecompiler
-
- getRevIndexFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.RevIndex
-
- getRight() - Method in class org.apache.sysds.hops.estim.MMNode
-
- getRight() - Method in class org.apache.sysds.parser.BinaryExpression
-
- getRight() - Method in class org.apache.sysds.parser.BooleanExpression
-
- getRight() - Method in class org.apache.sysds.parser.RelationalExpression
-
- getRightGroup() - Method in class org.apache.sysds.runtime.compress.cocode.PlanningCoCodingGroup
-
- getRmvarPointer(String, long) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
Get any pointer of the given size from rmvar-ed pointers (applicable if eager cudaFree is set to false)
- getRmvarPointerMinSize(String, long) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
- getRoot() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTree
-
- getRootNodes() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
-
- getRootProgram() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingAbstract
-
- getRoots() - Method in class org.apache.sysds.hops.codegen.opt.PlanPartition
-
- getRow() - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.Cell
-
- getRow() - Method in class org.apache.sysds.runtime.instructions.spark.data.RowMatrixBlock
-
- getRowBlockize(int) - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap.DensityMap
-
- getRowCounts() - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram.MatrixHistogram
-
- getRowIndex() - Method in class org.apache.sysds.runtime.matrix.data.MatrixIndexes
-
- getRowIterator(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Create a dense row iterator for a row index range.
- getRowIterator(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
-
- getRowIterator(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
- getRowIterator(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
-
- getRowIterator(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- getRowLowerBound() - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- getRowLowerEqualsUpper() - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- getRowPrivacy(int, int) - Method in interface org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacy
-
- getRowPrivacy(int, int) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyList
-
- getRowPrivacy(int, int) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyMap
-
- getRows() - Method in class org.apache.sysds.hops.cost.VarStats
-
- getRows() - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram.MatrixHistogram
-
- getRows() - Method in class org.apache.sysds.hops.estim.MMNode
-
- getRows() - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
Helper function for MCSR -> {COO, CSR}
- getRows() - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- getRows() - Method in class org.apache.sysds.runtime.instructions.cp.StringInitCPInstruction
-
- getRows() - Method in class org.apache.sysds.runtime.instructions.spark.RandSPInstruction
-
- getRows() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- getRows() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- getRowTemplateMatrixInput(Hop, CPlanMemoTable) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- getRowType() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
-
- getRowType(Hop, Hop...) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- getRowType() - Method in class org.apache.sysds.runtime.codegen.SpoofRowwise
-
- getRowUpperBound() - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- getRuleIndex() - Method in class org.apache.sysds.parser.dml.DmlParser.DataIdentifierContext
-
- getRuleIndex() - Method in class org.apache.sysds.parser.dml.DmlParser.DataTypeContext
-
- getRuleIndex() - Method in class org.apache.sysds.parser.dml.DmlParser.ExpressionContext
-
- getRuleIndex() - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionStatementContext
-
- getRuleIndex() - Method in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateContext
-
- getRuleIndex() - Method in class org.apache.sysds.parser.dml.DmlParser.Ml_typeContext
-
- getRuleIndex() - Method in class org.apache.sysds.parser.dml.DmlParser.ParameterizedExpressionContext
-
- getRuleIndex() - Method in class org.apache.sysds.parser.dml.DmlParser.ProgramrootContext
-
- getRuleIndex() - Method in class org.apache.sysds.parser.dml.DmlParser.StatementContext
-
- getRuleIndex() - Method in class org.apache.sysds.parser.dml.DmlParser.StrictParameterizedExpressionContext
-
- getRuleIndex() - Method in class org.apache.sysds.parser.dml.DmlParser.StrictParameterizedKeyValueStringContext
-
- getRuleIndex() - Method in class org.apache.sysds.parser.dml.DmlParser.TypedArgAssignContext
-
- getRuleIndex() - Method in class org.apache.sysds.parser.dml.DmlParser.TypedArgNoAssignContext
-
- getRuleIndex() - Method in class org.apache.sysds.parser.dml.DmlParser.ValueTypeContext
-
- getRuleNames() - Method in class org.apache.sysds.parser.dml.DmlLexer
-
- getRuleNames() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- getRunTime() - Static method in class org.apache.sysds.utils.Statistics
-
Returns the total time of run in nanoseconds.
- getRuntimeProgram() - Method in class org.apache.sysds.api.mlcontext.ScriptExecutor
-
Obtain the runtime program
- getRuntimeProgram(DMLProgram, DMLConfig) - Method in class org.apache.sysds.parser.DMLTranslator
-
- getSBID() - Method in class org.apache.sysds.parser.StatementBlock
-
- getScalar() - Method in class org.apache.sysds.runtime.matrix.operators.QuaternaryOperator
-
Obtain epsilon value
- getScalarInput(CPOperand) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getScalarInput(String, Types.ValueType, boolean) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getScalarInputs(CPOperand[]) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getScalarObject(String) - Method in class org.apache.sysds.api.jmlc.ResultVariables
-
Obtain the ScalarObject represented by the given output variable.
- getScalarObject(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain an output as a Scalar
object.
- getScalarObject(LiteralOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getScale() - Method in class org.apache.sysds.runtime.compress.colgroup.QDictionary
-
- getScale() - Method in class org.apache.sysds.runtime.compress.utils.BitmapLossy
-
- getSchema() - Method in class org.apache.sysds.api.mlcontext.FrameSchema
-
Obtain the frame schema
- getSchema() - Method in class org.apache.sysds.runtime.controlprogram.caching.FrameObject
-
- getSchema(int, int) - Method in class org.apache.sysds.runtime.controlprogram.caching.FrameObject
-
Obtain schema of value types
- getSchema() - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- getSchema() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
Get the schema if this TensorBlock
is heterogeneous.
- getSchema() - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Returns the schema of the frame block.
- getSchema() - Method in class org.apache.sysds.runtime.transform.decode.Decoder
-
- getSchemaAsString() - Method in class org.apache.sysds.api.mlcontext.FrameSchema
-
Obtain the schema as a comma-separated string
- getSchemaTypeOf() - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- getScratchSpace() - Static method in class org.apache.sysds.conf.ConfigurationManager
-
- getScript() - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain the Script object associated with these results.
- getScript() - Method in class org.apache.sysds.api.mlcontext.ScriptExecutor
-
Obtain the Script object associated with this ScriptExecutor
- getScriptExecutionString() - Method in class org.apache.sysds.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.sysds.api.mlcontext.Script
-
Obtain the script executor used by this Script.
- getScriptString() - Method in class org.apache.sysds.api.mlcontext.Script
-
Obtain the script string.
- getScriptString() - Method in exception org.apache.sysds.parser.ParseException
-
Obtain the original DML/PyDML script string.
- getSecond() - Method in class org.apache.sysds.runtime.util.RandNPair
-
- getSecondExpr() - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- getSecondIndex() - Method in class org.apache.sysds.runtime.matrix.data.TripleIndexes
-
- getSeed() - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- getSeed() - Method in class org.apache.sysds.runtime.instructions.spark.RandSPInstruction
-
- getSelectedRangeForZeroOut(IndexedMatrixValue, int, IndexRange) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- getSelectedRangeForZeroOut(Pair<Long, FrameBlock>, int, IndexRange, long, long) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- getSelfProductOutputNnz(MatrixBlock) - Static method in class org.apache.sysds.hops.estim.EstimationUtils
-
This utility function computes the exact output nnz
of a self matrix product without need to materialize
the output.
- getSeqArray(int, int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
Obtain sequence array
- getSeqLength(double, double, double) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- getSeqLength(double, double, double, boolean) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- getSeqList(int, int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
Obtain sequence list
- getSequenceFilePaths(FileSystem, Path) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- getSerializedATN() - Method in class org.apache.sysds.parser.dml.DmlLexer
-
- getSerializedATN() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- getSerializer(Class) - Method in class org.apache.sysds.runtime.io.BinaryBlockSerialization
-
- getSerializeStorageLevelString() - Static method in class org.apache.sysds.lops.Checkpoint
-
- getSeventhExpr() - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- getSimpleInstructionType() - Method in class org.apache.sysds.lops.BinaryScalar
-
- getSimpleInstructionType() - Method in class org.apache.sysds.lops.Lop
-
Method should be overridden if needed
- getSixthExpr() - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- getSize() - Method in class org.apache.sysds.parser.VariableSet
-
- getSize() - Method in class org.apache.sysds.runtime.controlprogram.caching.ByteBuffer
-
Returns the buffer size in bytes.
- getSize() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
-
- getSize(int) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
-
- getSize() - Method in class org.apache.sysds.runtime.instructions.cp.BooleanObject
-
- getSize() - Method in class org.apache.sysds.runtime.instructions.cp.DoubleObject
-
- getSize() - Method in class org.apache.sysds.runtime.instructions.cp.IntObject
-
- getSize() - Method in class org.apache.sysds.runtime.instructions.cp.ScalarObject
-
- getSize() - Method in class org.apache.sysds.runtime.instructions.cp.StringObject
-
- getSize() - Method in class org.apache.sysds.runtime.instructions.spark.data.FrameReblockBuffer
-
- getSize() - Method in class org.apache.sysds.runtime.instructions.spark.data.ReblockBuffer
-
- getSize() - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
-
- getSizeAllocatedGPUPointer(Pointer) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryManager
-
Get size of allocated GPU Pointer
- getSizeEstimator(MatrixBlock, CompressionSettings) - Static method in class org.apache.sysds.runtime.compress.estim.CompressedSizeEstimatorFactory
-
- getSizeofPinnedObjects() - Static method in class org.apache.sysds.utils.Statistics
-
- getSortedSampleIndexes(int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- getSortedSampleIndexes(int, int, long) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- getSortedSearchSpace() - Method in class org.apache.sysds.hops.codegen.opt.ReachabilityGraph
-
- getSource() - Method in class org.apache.sysds.parser.AssignmentStatement
-
- getSource() - Method in class org.apache.sysds.parser.MultiAssignmentStatement
-
- getSource() - Method in class org.apache.sysds.parser.OutputStatement
-
- getSOValue() - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
-
- getSparkClusterConfig() - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
Obtains the lazily analyzed spark cluster configuration.
- getSparkContext(MLContext) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Obtain the Spark Context
- getSparkContext() - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
Returns the used singleton spark context.
- getSparkContextFromProxy() - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Obtain the Spark Context from the MLContextProxy
- getSparkContextStatic() - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- getSparkRepartitionVariables() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- getSparkSession() - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Obtain the SparkSession associated with this MLContext.
- getSparkSessionFromProxy() - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Obtain the Spark Session from the MLContextProxy
- getSparseBlock() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- getSparseBlock() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- getSparseBlockIterator() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- getSparseBlockIterator(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- getSparseBlockType(SparseBlock) - Static method in class org.apache.sysds.runtime.data.SparseBlockFactory
-
- getSparseMatrixCudaPointer() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Convenience method to directly examine the Sparse matrix on GPU
- getSparseMatrixOutputForGPUInstruction(String, long, long, long) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
Allocates a sparse matrix in CSR format on the GPU.
- getSparseProductOutputNnz(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.hops.estim.EstimationUtils
-
- getSparseRowIterator(int, int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- getSparsity() - Method in class org.apache.sysds.hops.cost.VarStats
-
- getSparsity() - Method in class org.apache.sysds.hops.Hop
-
- getSparsity(DataCharacteristics) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getSparsity(long, long, long) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getSparsity(long[], long) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getSparsity() - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
- getSparsity() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNodeStatistics
-
- getSparsity() - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- getSparsity() - Method in class org.apache.sysds.runtime.instructions.spark.RandSPInstruction
-
- getSparsity() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- getSparsity() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- getSparsity() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- getSpBroadcastSize() - Method in class org.apache.sysds.hops.Hop
-
- getSPInstructionType() - Method in class org.apache.sysds.runtime.instructions.spark.SPInstruction
-
- getSplits(JobConf, int) - Method in class org.apache.sysds.runtime.util.InputStreamInputFormat
-
- getSpoofType() - Method in class org.apache.sysds.runtime.codegen.SpoofCellwise
-
- getSpoofType() - Method in class org.apache.sysds.runtime.codegen.SpoofMultiAggregate
-
- getSpoofType() - Method in class org.apache.sysds.runtime.codegen.SpoofOperator
-
- getSpoofType() - Method in class org.apache.sysds.runtime.codegen.SpoofOuterProduct
-
- getSpoofType() - Method in class org.apache.sysds.runtime.codegen.SpoofRowwise
-
- getSPType(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- getSPTypeByOpcode(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- getStartLineFromSparkDebugInfo(String) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- getStatement(int) - Method in class org.apache.sysds.parser.StatementBlock
-
- getStatementBlock(int) - Method in class org.apache.sysds.parser.DMLProgram
-
- getStatementBlock(Statement) - Static method in class org.apache.sysds.parser.ParserWrapper
-
Custom wrapper to convert statement into statement blocks.
- getStatementBlock() - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- getStatementBlocks() - Method in class org.apache.sysds.parser.DMLProgram
-
- getStatements() - Method in class org.apache.sysds.parser.StatementBlock
-
- getStatisticsMaxHeavyHitters() - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Obtain the maximum number of heavy hitters that are printed out as part
of the statistics.
- getStats() - Method in class org.apache.sysds.runtime.compress.cocode.PlanningMemoTable
-
- getStatus() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- getStatus() - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- getStorageLevel() - Method in class org.apache.sysds.lops.Checkpoint
-
- getStorageLevelString(StorageLevel) - Static method in class org.apache.sysds.lops.Checkpoint
-
This is a utility method because Sparks StorageLevel.toString() is incompatible with its own
fromString() method.
- getStream(Iterator<T>) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
-
- getStreamManager() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcHandler
-
- getString(String) - Method in class org.apache.sysds.api.jmlc.ResultVariables
-
Obtain the string value represented by the given output variable.
- getString(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain a String
output
- getString(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Get the value of a given cell as a String
- getString(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- getString(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- getString(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- getString(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- getString(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- getString(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
-
- getString(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
-
- getString(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
-
- getString(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
-
- getString(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
-
- getString(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
-
- getString(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- getStringForCPMiscTimesPerInstruction(String) - Static method in class org.apache.sysds.utils.GPUStatistics
-
Used to print misc timers (and their counts) for a given instruction/op
- getStringForCudaTimers() - Static method in class org.apache.sysds.utils.GPUStatistics
-
Used to print out cuda timers & counters
- getStringRowIterator() - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Get a row iterator over the frame where all fields are encoded
as strings independent of their value types.
- getStringRowIterator(int[]) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Get a row iterator over the frame where all selected fields are
encoded as strings independent of their value types.
- getStringRowIterator(int, int) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Get a row iterator over the frame where all fields are encoded
as strings independent of their value types.
- getStringRowIterator(int, int, int[]) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Get a row iterator over the frame where all selected fields are
encoded as strings independent of their value types.
- getStringValue() - Method in class org.apache.sysds.hops.LiteralOp
-
- getStringValue() - Method in class org.apache.sysds.lops.Data
-
- getStringValue() - Method in class org.apache.sysds.runtime.instructions.cp.BooleanObject
-
- getStringValue() - Method in class org.apache.sysds.runtime.instructions.cp.DoubleObject
-
- getStringValue() - Method in class org.apache.sysds.runtime.instructions.cp.IntObject
-
- getStringValue() - Method in class org.apache.sysds.runtime.instructions.cp.ScalarObject
-
- getStringValue() - Method in class org.apache.sysds.runtime.instructions.cp.StringObject
-
- getSubproblems(boolean[]) - Method in class org.apache.sysds.hops.codegen.opt.ReachabilityGraph
-
- getSumValidInputDims(Hop, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getSumValidInputDims(DataCharacteristics[], boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getSumValidInputNnz(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getSumValidInputNnz(DataCharacteristics[], boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getSwapIndexFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.SwapIndex
-
- getSymbolTable() - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain the symbol table, which is essentially a Map<String, Data>
representing variables and their values as SystemDS representations.
- getSymbolTable() - Method in class org.apache.sysds.api.mlcontext.Script
-
Obtain the symbol table, which is essentially a
HashMap<String, Data>
representing variables and their values.
- getSymmetry() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesMM
-
- getSynopsis() - Method in class org.apache.sysds.hops.estim.MMNode
-
- getTag() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeTaggedMatrixIndexes
-
- getTarget() - Method in class org.apache.sysds.parser.AssignmentStatement
-
- getTarget(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.ParameterizedBuiltinCPInstruction
-
- getTarget(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.ParameterizedBuiltinFEDInstruction
-
- getTargetHop() - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- getTargetList() - Method in class org.apache.sysds.parser.AssignmentStatement
-
- getTargetList() - Method in class org.apache.sysds.parser.MultiAssignmentStatement
-
- getTemplate(boolean, boolean, boolean, boolean) - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
-
- getTemplate(boolean, long, ArrayList<CNode>) - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeNary.NaryType
-
- getTemplate(boolean) - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeTernary.TernaryType
-
- getTemplate(boolean) - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
-
- getTemplateInfo() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- getTemplateInfo() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
-
- getTemplateInfo() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeOuterProduct
-
- getTemplateInfo() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
-
- getTemplateInfo() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
-
- getTempName() - Static method in class org.apache.sysds.parser.Expression
-
Obtain temporary name ("parsertemp" + _tempId) for expression.
- getTensorDimensions(ExecutionContext, CPOperand) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- getTensorInput(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
Pins a matrix variable into memory and returns the internal matrix block.
- getTensorObject(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getText() - Method in class org.apache.sysds.hops.Hop
-
- getText() - Method in class org.apache.sysds.parser.ConditionalPredicate
-
- getText() - Method in enum org.apache.sysds.parser.dml.CustomErrorListener.ParseIssueType
-
Obtain the user-friendly string representation of the enum value.
- getText() - Method in class org.apache.sysds.parser.Expression
-
- getText() - Method in interface org.apache.sysds.parser.ParseInfo
-
- getText() - Method in class org.apache.sysds.parser.Statement
-
- getText() - Method in class org.apache.sysds.parser.StatementBlock
-
- getText() - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- getTextValue(String) - Method in class org.apache.sysds.conf.DMLConfig
-
Method to get string value of a configuration parameter
Handles processing of configuration parameters
- getThirdExpr() - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- getThirdIndex() - Method in class org.apache.sysds.runtime.matrix.data.TripleIndexes
-
- getThreadID() - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- getTID() - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getTID() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
-
- getTID() - Method in class org.apache.sysds.runtime.instructions.fed.FEDInstruction
-
- getTimeArrayList() - Method in class org.apache.sysds.runtime.compress.CompressionStatistics
-
- getTimeEstimate(Program, ExecutionContext) - Static method in class org.apache.sysds.hops.cost.CostEstimationWrapper
-
- getTimeEstimate(ProgramBlock, ExecutionContext, boolean) - Static method in class org.apache.sysds.hops.cost.CostEstimationWrapper
-
- getTimeEstimate(Program, LocalVariableMap, HashMap<String, VarStats>) - Method in class org.apache.sysds.hops.cost.CostEstimator
-
- getTimeEstimate(ProgramBlock, LocalVariableMap, HashMap<String, VarStats>, boolean) - Method in class org.apache.sysds.hops.cost.CostEstimator
-
- getTo() - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- getToExpr() - Method in class org.apache.sysds.parser.IterablePredicate
-
- getToHopID() - Method in class org.apache.sysds.hops.codegen.opt.InterestingPoint
-
- getToHops() - Method in class org.apache.sysds.parser.ForStatementBlock
-
- getToInstructions() - Method in class org.apache.sysds.runtime.controlprogram.ForProgramBlock
-
- getTokenNames() - Method in class org.apache.sysds.parser.dml.DmlLexer
-
Deprecated.
- getTokenNames() - Method in class org.apache.sysds.parser.dml.DmlParser
-
Deprecated.
- getToLops() - Method in class org.apache.sysds.parser.ForStatementBlock
-
- getTotalInputNnz(ArrayList<MatrixBlock>) - Static method in class org.apache.sysds.runtime.codegen.SpoofOperator
-
- getTotalInputSize(ArrayList<MatrixBlock>) - Static method in class org.apache.sysds.runtime.codegen.SpoofOperator
-
- getTotalK() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- getTotalLix() - Static method in class org.apache.sysds.utils.Statistics
-
- getTotalLixUIP() - Static method in class org.apache.sysds.utils.Statistics
-
- getTotalMemEstimate(Hop[], Hop) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getTotalMemEstimate(Hop[], Hop, boolean) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- getTotalMemoryAllocated() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
Return the total memory in bytes used by this memory manager
- getTotalUIPVar() - Static method in class org.apache.sysds.utils.Statistics
-
- getTraces() - Method in class org.apache.sysds.runtime.lineage.LineageMap
-
- getTuple(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String, String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String, String, String) - Method in class org.apache.sysds.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTuple(String, String, String, String, String, String, String, String, String, String, String) - Method in class org.apache.sysds.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.sysds.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.sysds.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.sysds.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.sysds.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.sysds.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.sysds.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.sysds.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.sysds.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.sysds.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.sysds.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.sysds.api.mlcontext.MLResults
-
Obtain a Scala tuple.
- getTWriteStats() - Method in class org.apache.sysds.hops.recompile.RecompileStatus
-
- getType() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeBinary
-
- getType() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeNary
-
- getType() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTernary
-
- getType() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeUnary
-
- getType() - Method in class org.apache.sysds.hops.codegen.opt.InterestingPoint
-
- getType() - Method in class org.apache.sysds.hops.codegen.template.TemplateBase
-
- getType() - Method in class org.apache.sysds.lops.Lop
-
Method to get Lop type.
- getType() - Method in class org.apache.sysds.parser.PrintStatement
-
- getType() - Method in class org.apache.sysds.runtime.compress.utils.ABitmap
-
- getType() - Method in class org.apache.sysds.runtime.compress.utils.Bitmap
-
- getType() - Method in class org.apache.sysds.runtime.compress.utils.BitmapLossy
-
- getType() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
-
- getType() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- getType() - Method in class org.apache.sysds.runtime.controlprogram.parfor.Task
-
- getType() - Method in class org.apache.sysds.runtime.instructions.cp.CPInstruction
-
- getType() - Method in class org.apache.sysds.runtime.instructions.fed.FEDInstruction
-
- getType() - Method in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- getType() - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- getType() - Method in class org.apache.sysds.runtime.instructions.spark.SPInstruction
-
- getType() - Method in class org.apache.sysds.runtime.lineage.LineageItem
-
- getType(String) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
-
- getUncompressedColBlock(ColGroup) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConverter
-
Extracts the Uncompressed MatrixBlock representation of a Col Group
- getUniqueFileName(String) - Static method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- getUniqueID() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- getUniqueTempFileName() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Wrapper over internal filename construction for external usage.
- getUniqueWorkingDir(String) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
- getUpdateInPlaceVars() - Method in class org.apache.sysds.parser.StatementBlock
-
- getUpdateType() - Method in class org.apache.sysds.hops.Hop
-
- getUpdateType() - Method in class org.apache.sysds.lops.OutputParameters
-
- getUpdateType() - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
- getUTFSize(String) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
Returns the serialized size in bytes of the given string value,
following the modified UTF-8 specification as used by Java's
DataInput/DataOutput.
- getUtilThreadPool() - Static method in class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
-
- getUUID() - Static method in class org.apache.sysds.api.DMLScript
-
- getV() - Method in class org.apache.sysds.runtime.matrix.data.IJV
-
- getValidFunctions() - Method in class org.apache.sysds.hops.ipa.FunctionCallSizeInfo
-
Gets the set of functions that are valid for statistics
propagation.
- getValidOpPos(Types.OpOp2, Types.OpOp2...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- getValue() - Method in class org.apache.sysds.parser.BooleanIdentifier
-
- getValue() - Method in class org.apache.sysds.parser.DoubleIdentifier
-
- getValue() - Method in class org.apache.sysds.parser.ExpressionList
-
- getValue() - Method in class org.apache.sysds.parser.IntIdentifier
-
- getValue() - Method in class org.apache.sysds.parser.StringIdentifier
-
- getValue(int, int) - Method in class org.apache.sysds.runtime.codegen.SpoofOperator.SideInput
-
- getValue(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ADictionary
-
Get Specific value contained in the dictionary at index.
- getValue(int) - Method in class org.apache.sysds.runtime.compress.colgroup.Dictionary
-
- getValue(int) - Method in class org.apache.sysds.runtime.compress.colgroup.QDictionary
-
- getValue() - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.Cell
-
- getValue() - Method in class org.apache.sysds.runtime.data.IndexedTensorBlock
-
- getValue() - Method in class org.apache.sysds.runtime.instructions.cp.BooleanObject
-
- getValue() - Method in class org.apache.sysds.runtime.instructions.cp.DoubleObject
-
- getValue() - Method in class org.apache.sysds.runtime.instructions.cp.IntObject
-
- getValue() - Method in class org.apache.sysds.runtime.instructions.cp.ScalarObject
-
- getValue() - Method in class org.apache.sysds.runtime.instructions.cp.StringObject
-
- getValue() - Method in class org.apache.sysds.runtime.instructions.spark.data.CorrMatrixBlock
-
- getValue() - Method in class org.apache.sysds.runtime.instructions.spark.data.IndexedMatrixValue
-
- getValue() - Method in class org.apache.sysds.runtime.instructions.spark.data.RowMatrixBlock
-
- getValue(int, int) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- getValue(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- getValue() - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- getValue(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- getValue(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- getValue() - Method in class org.apache.sysds.runtime.matrix.data.Pair
-
- getValue() - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
-
- getValueByte(int) - Method in class org.apache.sysds.runtime.compress.colgroup.QDictionary
-
- getValueDenseUnsafe(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- getValues() - Method in class org.apache.sysds.runtime.compress.colgroup.ADictionary
-
Get all the values contained in the dictionary as a linearized double array.
- getValues() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Get all the values in the colGroup.
- getValues() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- getValues() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupValue
-
- getValues() - Method in class org.apache.sysds.runtime.compress.colgroup.Dictionary
-
- getValues() - Method in class org.apache.sysds.runtime.compress.colgroup.QDictionary
-
- getValues() - Method in class org.apache.sysds.runtime.compress.utils.Bitmap
-
Get all values without unnecessary allocations and copies.
- getValues(int) - Method in class org.apache.sysds.runtime.compress.utils.Bitmap
-
Obtain tuple of column values associated with index.
- getValues() - Method in class org.apache.sysds.runtime.compress.utils.BitmapLossy
-
Get all values without unnecessary allocations and copies.
- getValues(int) - Method in class org.apache.sysds.runtime.compress.utils.BitmapLossy
-
Obtain tuple of column values associated with index.
- getValuesAsBlock() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Returns the ColGroup as a MatrixBlock.
- getValuesAsBlock() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- getValuesAsBlock() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupValue
-
- getValuesByte() - Method in class org.apache.sysds.runtime.compress.colgroup.QDictionary
-
- getValuesLength() - Method in class org.apache.sysds.runtime.compress.colgroup.ADictionary
-
returns the count of values contained in the dictionary.
- getValuesLength() - Method in class org.apache.sysds.runtime.compress.colgroup.Dictionary
-
- getValuesLength() - Method in class org.apache.sysds.runtime.compress.colgroup.QDictionary
-
- getValuesSize() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- getValueType() - Method in class org.apache.sysds.hops.Hop
-
- getValueType() - Method in class org.apache.sysds.lops.Lop
-
get value type of the output that is produced by this lop
- getValueType() - Method in class org.apache.sysds.parser.Identifier
-
- getValueType() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- getValueType() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
Get the ValueType
if this TensorBlock
is homogeneous.
- getValueType() - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- getValueType() - Method in class org.apache.sysds.runtime.instructions.cp.Data
-
- getValueTypeCastOperator(Types.ValueType) - Static method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
Convert a value type (double, int, or boolean) to a built-in function operator.
- getVariable(String) - Method in class org.apache.sysds.parser.VariableSet
-
- getVariable(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getVariable(CPOperand) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getVariableNames() - Method in class org.apache.sysds.api.jmlc.ResultVariables
-
Obtain the output variable names held by this ResultVariables object.
- getVariableNames() - Method in class org.apache.sysds.parser.VariableSet
-
- getVariableOpcode() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- getVariables() - Method in class org.apache.sysds.hops.rewrite.ProgramRewriteStatus
-
- getVariables() - Method in class org.apache.sysds.parser.VariableSet
-
- getVariables() - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- getVariables() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ParForBody
-
- getVariables() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ParWorker
-
- getVariables() - Method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForJobReturn
-
- getVarID() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
-
- getVarList() - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
NOTE: No order guaranteed, so keep same list for pin and unpin.
- getVarListPartitioned() - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
NOTE: No order guaranteed, so keep same list for pin and unpin.
- getVarname() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- getVarname() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeData
-
- getVarName() - Method in class org.apache.sysds.runtime.controlprogram.parfor.Task
-
- getVarParam(String) - Method in class org.apache.sysds.parser.DataExpression
-
- getVarParam(String) - Method in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- getVarParams() - Method in class org.apache.sysds.parser.DataExpression
-
- getVarParams() - Method in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- getVectorAddPrimitive() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
-
- getVectorAddPrimitive() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
-
- getVectorLength() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- getVectorPrimitiveName() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
-
- getVectorPrimitiveName() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
-
- getVisited() - Method in class org.apache.sysds.lops.Lop
-
get visit status of node
- getVocabulary() - Method in class org.apache.sysds.parser.dml.DmlLexer
-
- getVocabulary() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- getWarn() - Method in class org.apache.sysds.parser.LiveVariableAnalysis
-
- getWarpSize() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Gets the warp size supported by the active cuda device.
- getWeight() - Method in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
- getWeight() - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
-
- getWorker(MatrixBlock, MatrixBlock, DnnParameters, boolean, boolean) - Static method in interface org.apache.sysds.runtime.matrix.data.LibMatrixDNNRotate180.Rotate180Worker
-
- getWorkerID() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcCall
-
- getWorkerName() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.LocalPSWorker
-
- getWorkerName() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.PSWorker
-
- getWorkerName() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.SparkPSWorker
-
- getWorkingDir(String) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
- getWorkingFilePath(String) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- getWriteBufferFree() - Static method in class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
-
- getWriteBufferLimit() - Static method in class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
-
- getWriteBufferSize() - Static method in class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
-
- getXorFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.Xor
-
- getZeroCounts() - Method in class org.apache.sysds.runtime.compress.utils.ABitmap
-
- gpu - Variable in class org.apache.sysds.api.DMLOptions
-
- GPU_EVICTION_POLICY - Static variable in class org.apache.sysds.conf.DMLConfig
-
- GPU_INST_PREFIX - Static variable in class org.apache.sysds.runtime.instructions.Instruction
-
- GPU_MEMORY_ALLOCATOR - Static variable in class org.apache.sysds.api.DMLScript
-
- GPU_MEMORY_ALLOCATOR - Static variable in class org.apache.sysds.conf.DMLConfig
-
- GPU_MEMORY_UTILIZATION_FACTOR - Static variable in class org.apache.sysds.api.DMLScript
-
- GPU_MEMORY_UTILIZATION_FACTOR - Static variable in class org.apache.sysds.conf.DMLConfig
-
- GPUContext - Class in org.apache.sysds.runtime.instructions.gpu.context
-
Represents a context per GPU accessible through the same JVM.
- GPUContextPool - Class in org.apache.sysds.runtime.instructions.gpu.context
-
- GPUContextPool() - Constructor for class org.apache.sysds.runtime.instructions.gpu.context.GPUContextPool
-
- GPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
- GPUInstruction.GPUINSTRUCTION_TYPE - Enum in org.apache.sysds.runtime.instructions.gpu
-
- GPUInstructionParser - Class in org.apache.sysds.runtime.instructions
-
- GPUInstructionParser() - Constructor for class org.apache.sysds.runtime.instructions.GPUInstructionParser
-
- GPULazyCudaFreeMemoryManager - Class in org.apache.sysds.runtime.instructions.gpu.context
-
- GPULazyCudaFreeMemoryManager(GPUMemoryManager) - Constructor for class org.apache.sysds.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
- GPUMatrixMemoryManager - Class in org.apache.sysds.runtime.instructions.gpu.context
-
- GPUMatrixMemoryManager(GPUMemoryManager) - Constructor for class org.apache.sysds.runtime.instructions.gpu.context.GPUMatrixMemoryManager
-
- GPUMemoryAllocator - Interface in org.apache.sysds.runtime.instructions.gpu.context
-
- GPUMemoryManager - Class in org.apache.sysds.runtime.instructions.gpu.context
-
- All cudaFree and cudaMalloc in SystemDS should go through this class to avoid OOM or incorrect results.
- GPUMemoryManager(GPUContext) - Constructor for class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryManager
-
- GPUMemoryManager.EvictionPolicyBasedComparator - Class in org.apache.sysds.runtime.instructions.gpu.context
-
Class that governs the eviction policy
- GPUObject - Class in org.apache.sysds.runtime.instructions.gpu.context
-
Handle to a matrix block on the GPU
- GPUStatistics - Class in org.apache.sysds.utils
-
Measures performance numbers when GPU mode is enabled
Printed as part of
Statistics
.
- GPUStatistics() - Constructor for class org.apache.sysds.utils.GPUStatistics
-
- GreaterThan - Class in org.apache.sysds.runtime.functionobjects
-
- GreaterThanEquals - Class in org.apache.sysds.runtime.functionobjects
-
- gridDimX - Variable in class org.apache.sysds.runtime.instructions.gpu.context.ExecutionConfig
-
- gridDimY - Variable in class org.apache.sysds.runtime.instructions.gpu.context.ExecutionConfig
-
- gridDimZ - Variable in class org.apache.sysds.runtime.instructions.gpu.context.ExecutionConfig
-
- GroupableColInfo(double, long) - Constructor for class org.apache.sysds.runtime.compress.cocode.PlanningCoCoder.GroupableColInfo
-
- groupedAggOperations(MatrixValue, MatrixValue, MatrixValue, int, Operator) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- groupedAggOperations(MatrixValue, MatrixValue, MatrixValue, int, Operator, int) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- groupedAggOperations(MatrixValue, MatrixValue, MatrixValue, int, Operator) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Invocation from CP instructions.
- groupedAggOperations(MatrixValue, MatrixValue, MatrixValue, int, Operator, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- GroupedAggregate - Class in org.apache.sysds.lops
-
Lop to perform grouped aggregates
- GroupedAggregate(HashMap<String, Lop>, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.GroupedAggregate
-
- GroupedAggregate(HashMap<String, Lop>, Types.DataType, Types.ValueType, LopProperties.ExecType, boolean) - Constructor for class org.apache.sysds.lops.GroupedAggregate
-
- GroupedAggregate(HashMap<String, Lop>, Types.DataType, Types.ValueType, LopProperties.ExecType, int) - Constructor for class org.apache.sysds.lops.GroupedAggregate
-
- groupedAggregate(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, int, Operator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
-
- groupedAggregate(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, int, Operator, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
-
- GroupedAggregateM - Class in org.apache.sysds.lops
-
Lop to perform mr map-side grouped aggregates
(restriction: sum, w/o weights, ngroups), groups broadcasted
- GroupedAggregateM(HashMap<String, Lop>, Types.DataType, Types.ValueType, boolean, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.GroupedAggregateM
-
- GroupedAggregateM.CacheType - Enum in org.apache.sysds.lops
-
- GuaranteedErrorEstimator - Class in org.apache.sysds.runtime.compress.estim.sample
-
- GuaranteedErrorEstimator() - Constructor for class org.apache.sysds.runtime.compress.estim.sample.GuaranteedErrorEstimator
-
- ID - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- ID() - Method in class org.apache.sysds.parser.dml.DmlParser.BuiltinFunctionExpressionContext
-
- ID() - Method in class org.apache.sysds.parser.dml.DmlParser.ExternalFunctionDefExpressionContext
-
- ID() - Method in class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
-
- ID() - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionCallAssignmentStatementContext
-
- ID() - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionCallMultiAssignmentStatementContext
-
- ID - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- ID() - Method in class org.apache.sysds.parser.dml.DmlParser.ImportStatementContext
-
- ID() - Method in class org.apache.sysds.parser.dml.DmlParser.IndexedExpressionContext
-
- ID() - Method in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
-
- ID() - Method in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateSeqExpressionContext
-
- ID() - Method in class org.apache.sysds.parser.dml.DmlParser.MatrixDataTypeCheckContext
-
- ID() - Method in class org.apache.sysds.parser.dml.DmlParser.ParameterizedExpressionContext
-
- ID() - Method in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
-
- ID() - Method in class org.apache.sysds.parser.dml.DmlParser.SimpleDataIdentifierExpressionContext
-
- ID() - Method in class org.apache.sysds.parser.dml.DmlParser.StrictParameterizedExpressionContext
-
- ID() - Method in class org.apache.sysds.parser.dml.DmlParser.StrictParameterizedKeyValueStringContext
-
- ID() - Method in class org.apache.sysds.parser.dml.DmlParser.TypedArgAssignContext
-
- ID() - Method in class org.apache.sysds.parser.dml.DmlParser.TypedArgNoAssignContext
-
- identCopy(long, long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- Identifier - Class in org.apache.sysds.parser
-
- Identifier() - Constructor for class org.apache.sysds.parser.Identifier
-
- IDHandler - Class in org.apache.sysds.runtime.controlprogram.parfor.util
-
Functionalities for extracting numeric IDs from Hadoop taskIDs and other
things related to modification of IDs.
- IDHandler() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.util.IDHandler
-
- IDSequence - Class in org.apache.sysds.runtime.controlprogram.parfor.util
-
ID sequence for generating unique long identifiers with start 0 and increment 1.
- IDSequence() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.util.IDSequence
-
- IDSequence(boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.util.IDSequence
-
- IDSequence(boolean, long) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.util.IDSequence
-
- ifBody - Variable in class org.apache.sysds.parser.dml.DmlParser.IfStatementContext
-
- IfdefAssignmentStatementContext(DmlParser.StatementContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.IfdefAssignmentStatementContext
-
- IfElse - Class in org.apache.sysds.runtime.functionobjects
-
- IfProgramBlock - Class in org.apache.sysds.runtime.controlprogram
-
- IfProgramBlock(Program, ArrayList<Instruction>) - Constructor for class org.apache.sysds.runtime.controlprogram.IfProgramBlock
-
- IfStatement - Class in org.apache.sysds.parser
-
- IfStatement() - Constructor for class org.apache.sysds.parser.IfStatement
-
- IfStatementBlock - Class in org.apache.sysds.parser
-
- IfStatementBlock() - Constructor for class org.apache.sysds.parser.IfStatementBlock
-
- IfStatementContext(DmlParser.StatementContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.IfStatementContext
-
- IJV - Class in org.apache.sysds.runtime.matrix.data
-
Helper class for external key/value exchange.
- IJV() - Constructor for class org.apache.sysds.runtime.matrix.data.IJV
-
- im2col(MatrixBlock, MatrixBlock, int, DnnParameters, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNIm2Col
-
- im2col(MatrixBlock, MatrixBlock, int, int, int, int, int, int, int, int, int, int, int, int, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNIm2Col
-
- im2colDense(double[], double[], int, int, int, int, int, int, int, int, int, int, int, int, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNIm2Col
-
- im2colDenseStride1Pad0(double[], double[], int, int, int, int, int, int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNIm2Col
-
- im2colSparse(MatrixBlock, MatrixBlock, int, int, int, int, int, int, int, int, int, int, int, int, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNIm2Col
-
- ImportStatement - Class in org.apache.sysds.parser
-
- ImportStatement() - Constructor for class org.apache.sysds.parser.ImportStatement
-
- ImportStatementContext(DmlParser.StatementContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.ImportStatementContext
-
- in(Map<String, Object>) - Method in class org.apache.sysds.api.mlcontext.Script
-
Pass a map of inputs to the script.
- in(Map<String, ?>) - Method in class org.apache.sysds.api.mlcontext.Script
-
Pass a Scala Map of inputs to the script.
- in(Seq<Object>) - Method in class org.apache.sysds.api.mlcontext.Script
-
Pass a Scala Seq of inputs to the script.
- in(String, Object) - Method in class org.apache.sysds.api.mlcontext.Script
-
Register an input (parameter ($) or variable).
- in(String, Object, Metadata) - Method in class org.apache.sysds.api.mlcontext.Script
-
Register an input (parameter ($) or variable) with optional matrix
metadata.
- incFederated(FederatedRequest.RequestType) - Static method in class org.apache.sysds.utils.Statistics
-
- INCLUDE_FUNCTIONS - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
-
- inColRange(long) - Method in class org.apache.sysds.runtime.util.IndexRange
-
- incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Increments the given value for a given row and column.
- incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Increments the given value for a given row and column
by delta.
- incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
-
- incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
-
- incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
-
- incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
-
- incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
-
- incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
-
- incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
-
- incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
-
- incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
-
- incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
-
- incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
-
- incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
-
- incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- increment - Variable in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateSeqExpressionContext
-
- increment - Variable in class org.apache.sysds.parser.dml.ExpressionInfo
-
- incrementAcquireMTime(long) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementAcquireRTime(long) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementalAggregate(AggregateOperator, MatrixValue, MatrixValue, boolean) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- incrementalAggregate(AggregateOperator, MatrixValue) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- incrementalAggregate(AggregateOperator, BasicTensorBlock) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- incrementalAggregate(AggregateOperator, MatrixValue, MatrixValue, boolean) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- incrementalAggregate(AggregateOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- incrementalAggregate(AggregateOperator, MatrixValue, MatrixValue, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- incrementalAggregate(AggregateOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- incrementalAggregate(AggregateOperator, MatrixValue, MatrixValue, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- incrementalAggregate(AggregateOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- incrementalAggregate(AggregateOperator, MatrixValue, MatrixValue, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- incrementalAggregate(AggregateOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- incrementalAggregation(MatrixValue, MatrixValue, MatrixValue, AggregateOperator, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- incrementalAggregation(MatrixValue, MatrixValue, MatrixValue, AggregateOperator, boolean, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- incrementCodegenClassCompile() - Static method in class org.apache.sysds.utils.Statistics
-
- incrementCodegenClassCompileTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incrementCodegenCompileTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incrementCodegenCPlanCompile(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incrementCodegenDAGCompile() - Static method in class org.apache.sysds.utils.Statistics
-
- incrementCodegenEnumAll(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incrementCodegenEnumAllP(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incrementCodegenEnumEval(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incrementCodegenEnumEvalP(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incrementCodegenOpCacheHits() - Static method in class org.apache.sysds.utils.Statistics
-
- incrementCodegenOpCacheTotal() - Static method in class org.apache.sysds.utils.Statistics
-
- incrementCodegenPlanCacheHits() - Static method in class org.apache.sysds.utils.Statistics
-
- incrementCodegenPlanCacheTotal() - Static method in class org.apache.sysds.utils.Statistics
-
- incrementDelHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- incrementExportTime(long) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementFSBuffHits() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementFSBuffHits(int) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementFSBuffWrites() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementFSBuffWrites(int) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementFSHits() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementFSHits(int) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementFSHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- incrementFSReadTime(long) - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- incrementFSWrites() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementFSWrites(int) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementFSWrites() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- incrementFSWriteTime(long) - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- incrementFuncHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- incrementFunRecompiles() - Static method in class org.apache.sysds.utils.Statistics
-
- incrementFunRecompileTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incrementHDFSHits() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementHDFSHits(int) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementHDFSWrites() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementHDFSWrites(int) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementHOPRecompilePred() - Static method in class org.apache.sysds.utils.Statistics
-
- incrementHOPRecompilePred(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incrementHOPRecompileSB() - Static method in class org.apache.sysds.utils.Statistics
-
- incrementHOPRecompileSB(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incrementHOPRecompileTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incrementInstHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- incrementJITCompileTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incrementJVMgcCount(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incrementJVMgcTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incrementMemDeletes() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- incrementMemHits() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementMemHits(int) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementMemHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- incrementMemWrites() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- incrementNativeFailuresCounter() - Static method in class org.apache.sysds.utils.Statistics
-
- incrementNoOfCompiledSPInst() - Static method in class org.apache.sysds.utils.Statistics
-
- incrementNoOfExecutedGPUInst() - Static method in class org.apache.sysds.utils.GPUStatistics
-
- incrementNoOfExecutedSPInst() - Static method in class org.apache.sysds.utils.Statistics
-
- incrementNumReferences() - Method in class org.apache.sysds.runtime.instructions.spark.data.LineageObject
-
- incrementParForInitTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incrementParForMergeTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incrementParForMRCounters(Reporter, long, long) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForUtils
-
- incrementParForOptimCount() - Static method in class org.apache.sysds.utils.Statistics
-
- incrementParForOptimTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incrementPRewrites() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- incrementReleaseTime(long) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- incrementSBHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- incrementTotalLix() - Static method in class org.apache.sysds.utils.Statistics
-
- incrementTotalLixUIP() - Static method in class org.apache.sysds.utils.Statistics
-
- incrementTotalUIPVar() - Static method in class org.apache.sysds.utils.Statistics
-
- increOp - Variable in class org.apache.sysds.runtime.matrix.operators.AggregateOperator
-
- incrStats(int, int, int) - Method in class org.apache.sysds.runtime.compress.cocode.PlanningMemoTable
-
- incSparkBroadcastCount(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incSparkCollectCount(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incSparkParallelizeCount(long) - Static method in class org.apache.sysds.utils.Statistics
-
- incWorkerNumber() - Static method in class org.apache.sysds.utils.Statistics
-
- incWorkerNumber(long) - Static method in class org.apache.sysds.utils.Statistics
-
- index(int) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Get the block index for a given row.
- index(int) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- index(int) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- index(int) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- index(int) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- index(int) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- index(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
-
- index(int) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- IndexComparator(boolean) - Constructor for class org.apache.sysds.runtime.instructions.spark.utils.RDDSortUtils.IndexComparator
-
- IndexComparator2(boolean) - Constructor for class org.apache.sysds.runtime.instructions.spark.utils.RDDSortUtils.IndexComparator2
-
- IndexedExpressionContext(DmlParser.DataIdentifierContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.IndexedExpressionContext
-
- IndexedIdentifier - Class in org.apache.sysds.parser
-
- IndexedIdentifier(String, boolean, boolean) - Constructor for class org.apache.sysds.parser.IndexedIdentifier
-
- IndexedMatrixValue - Class in org.apache.sysds.runtime.instructions.spark.data
-
- IndexedMatrixValue() - Constructor for class org.apache.sysds.runtime.instructions.spark.data.IndexedMatrixValue
-
- IndexedMatrixValue(Class<? extends MatrixValue>) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.IndexedMatrixValue
-
- IndexedMatrixValue(MatrixIndexes, MatrixValue) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.IndexedMatrixValue
-
- IndexedMatrixValue(IndexedMatrixValue) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.IndexedMatrixValue
-
- IndexedTensorBlock - Class in org.apache.sysds.runtime.data
-
- IndexedTensorBlock() - Constructor for class org.apache.sysds.runtime.data.IndexedTensorBlock
-
- IndexedTensorBlock(TensorIndexes, TensorBlock) - Constructor for class org.apache.sysds.runtime.data.IndexedTensorBlock
-
- IndexedTensorBlock(IndexedTensorBlock) - Constructor for class org.apache.sysds.runtime.data.IndexedTensorBlock
-
- indexes - Variable in class org.apache.sysds.runtime.controlprogram.parfor.util.PairWritableBlock
-
- indexes - Variable in class org.apache.sysds.runtime.controlprogram.parfor.util.PairWritableCell
-
- indexes(int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Get the sorted array of column indexes of all non-zero entries in
row r.
- indexes(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- indexes() - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
Get raw access to underlying array of column indices
For use in GPU code
- indexes() - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
Get raw access to underlying array of column indices
For use in GPU code
- indexes(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- indexes(int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- indexes() - Method in class org.apache.sysds.runtime.data.SparseRow
-
Get the index array of non-zero entries, co-aligned
with the array of values.
- indexes() - Method in class org.apache.sysds.runtime.data.SparseRowScalar
-
- indexes() - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- indexFn - Variable in class org.apache.sysds.runtime.matrix.operators.AggregateTernaryOperator
-
- indexFn - Variable in class org.apache.sysds.runtime.matrix.operators.AggregateUnaryOperator
-
- IndexFunction - Class in org.apache.sysds.runtime.functionobjects
-
- IndexFunction() - Constructor for class org.apache.sysds.runtime.functionobjects.IndexFunction
-
- IndexingCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- IndexingOp - Class in org.apache.sysds.hops
-
- IndexingOp(String, Types.DataType, Types.ValueType, Hop, Hop, Hop, Hop, Hop, boolean, boolean) - Constructor for class org.apache.sysds.hops.IndexingOp
-
- IndexingSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
This class implements the matrix indexing functionality inside Spark.
- IndexRange - Class in org.apache.sysds.runtime.util
-
- IndexRange(long, long, long, long) - Constructor for class org.apache.sysds.runtime.util.IndexRange
-
- info() - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Obtain information about the project such as version and build time from
the manifest in the SystemDS jar file.
- info() - Method in class org.apache.sysds.api.mlcontext.Script
-
Display information about the script as a String.
- info - Variable in class org.apache.sysds.parser.dml.DmlParser.ExpressionContext
-
- info - Variable in class org.apache.sysds.parser.dml.DmlParser.FunctionStatementContext
-
- info - Variable in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateContext
-
- info - Variable in class org.apache.sysds.parser.dml.DmlParser.StatementContext
-
- InfrastructureAnalyzer - Class in org.apache.sysds.runtime.controlprogram.parfor.stat
-
Central place for analyzing and obtaining static infrastructure properties
such as memory and number of logical processors.
- InfrastructureAnalyzer() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
- init(ArrayList<Hop>, RecompileStatus) - Method in class org.apache.sysds.hops.MemoTable
-
- init(Hop, RecompileStatus) - Method in class org.apache.sysds.hops.MemoTable
-
- init(Lop, Lop, Lop, Types.DataType, Types.ValueType) - Method in class org.apache.sysds.lops.Append
-
- init(Lop, Lop, Lop, Lop, Types.DataType, Types.ValueType, LopProperties.ExecType) - Method in class org.apache.sysds.lops.AppendG
-
- init(Lop, Lop, Lop, Types.DataType, Types.ValueType) - Method in class org.apache.sysds.lops.AppendGAlignedSP
-
- init(Lop, Lop, Lop, Types.DataType, Types.ValueType, LopProperties.ExecType) - Method in class org.apache.sysds.lops.AppendM
-
- init(Lop, Lop, Types.DataType, Types.ValueType, LopProperties.ExecType) - Method in class org.apache.sysds.lops.AppendR
-
- init(DataIdentifier, String, LopProperties.ExecType) - Method in class org.apache.sysds.lops.DataGen
-
- init() - Static method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- init(Map<String, String>) - Static method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- init() - Static method in class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
-
- init() - Static method in class org.apache.sysds.runtime.controlprogram.caching.PageCache
-
- init(double[][], int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
NOTE: This method is designed only for dense representation.
- init(double[], int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
NOTE: This method is designed only for dense representation.
- init(RandomMatrixGenerator.PDF, int, int, int, double, double, double) - Method in class org.apache.sysds.runtime.matrix.data.RandomMatrixGenerator
-
Initializes internal data structures.
- init(RandomMatrixGenerator.PDF, int, int, int, double, double, double, double) - Method in class org.apache.sysds.runtime.matrix.data.RandomMatrixGenerator
-
Instantiates a Random number generator with a specific poisson mean
- initCaching() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
Inits caching with the default uuid of DMLScript
- initCaching(String) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
Creates the DML-script-specific caching working dir.
- initColList(JSONArray) - Method in class org.apache.sysds.runtime.transform.encode.Encoder
-
- initColList(int[]) - Method in class org.apache.sysds.runtime.transform.encode.Encoder
-
- initFederatedData(long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
-
- InitFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
-
- InitFEDInstruction(CPOperand, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysds.runtime.instructions.fed.InitFEDInstruction
-
- initHadoopExecution(DMLConfig) - Static method in class org.apache.sysds.api.DMLScript
-
- initialCapacity - Static variable in class org.apache.sysds.runtime.data.SparseRowVector
-
- initialGPUMemBudget() - Static method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContextPool
-
Gets the initial GPU memory budget.
- initialize(String, String) - Static method in class org.apache.sysds.utils.NativeHelper
-
Initialize the native library before executing the DML program
- initializebackwardLV(VariableSet) - Method in class org.apache.sysds.parser.AssignmentStatement
-
- initializebackwardLV(VariableSet) - Method in class org.apache.sysds.parser.ForStatement
-
- initializebackwardLV(VariableSet) - Method in class org.apache.sysds.parser.ForStatementBlock
-
- initializebackwardLV(VariableSet) - Method in class org.apache.sysds.parser.FunctionStatement
-
- initializebackwardLV(VariableSet) - Method in class org.apache.sysds.parser.FunctionStatementBlock
-
- initializebackwardLV(VariableSet) - Method in class org.apache.sysds.parser.IfStatement
-
- initializebackwardLV(VariableSet) - Method in class org.apache.sysds.parser.IfStatementBlock
-
- initializebackwardLV(VariableSet) - Method in class org.apache.sysds.parser.ImportStatement
-
- initializebackwardLV(VariableSet) - Method in class org.apache.sysds.parser.LiveVariableAnalysis
-
- initializebackwardLV(VariableSet) - Method in class org.apache.sysds.parser.MultiAssignmentStatement
-
- initializebackwardLV(VariableSet) - Method in class org.apache.sysds.parser.OutputStatement
-
- initializebackwardLV(VariableSet) - Method in class org.apache.sysds.parser.PathStatement
-
- initializebackwardLV(VariableSet) - Method in class org.apache.sysds.parser.PrintStatement
-
- initializebackwardLV(VariableSet) - Method in class org.apache.sysds.parser.Statement
-
- initializebackwardLV(VariableSet) - Method in class org.apache.sysds.parser.StatementBlock
-
- initializebackwardLV(VariableSet) - Method in class org.apache.sysds.parser.WhileStatement
-
- initializebackwardLV(VariableSet) - Method in class org.apache.sysds.parser.WhileStatementBlock
-
- initializeDedupBlock(ProgramBlock, ExecutionContext) - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- initializeDedupBlock(ProgramBlock, ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageDedupUtils
-
- initializeforwardLV(VariableSet) - Method in class org.apache.sysds.parser.AssignmentStatement
-
- initializeforwardLV(VariableSet) - Method in class org.apache.sysds.parser.ForStatement
-
- initializeforwardLV(VariableSet) - Method in class org.apache.sysds.parser.ForStatementBlock
-
- initializeforwardLV(VariableSet) - Method in class org.apache.sysds.parser.FunctionStatement
-
- initializeforwardLV(VariableSet) - Method in class org.apache.sysds.parser.FunctionStatementBlock
-
- initializeforwardLV(VariableSet) - Method in class org.apache.sysds.parser.IfStatement
-
- initializeforwardLV(VariableSet) - Method in class org.apache.sysds.parser.IfStatementBlock
-
- initializeforwardLV(VariableSet) - Method in class org.apache.sysds.parser.ImportStatement
-
- initializeforwardLV(VariableSet) - Method in class org.apache.sysds.parser.LiveVariableAnalysis
-
- initializeforwardLV(VariableSet) - Method in class org.apache.sysds.parser.MultiAssignmentStatement
-
- initializeforwardLV(VariableSet) - Method in class org.apache.sysds.parser.OutputStatement
-
- initializeforwardLV(VariableSet) - Method in class org.apache.sysds.parser.PathStatement
-
- initializeforwardLV(VariableSet) - Method in class org.apache.sysds.parser.PrintStatement
-
- initializeforwardLV(VariableSet) - Method in class org.apache.sysds.parser.Statement
-
- initializeforwardLV(VariableSet) - Method in class org.apache.sysds.parser.StatementBlock
-
For each statement:
gen rule: for each variable read in current statement but not updated in any PRIOR statement, add to gen
Handles case where variable both read and updated in same statement (i = i + 1, i needs to be added to gen)
kill rule: for each variable updated in current statement but not read in this or any PRIOR statement,
add to kill.
- initializeforwardLV(VariableSet) - Method in class org.apache.sysds.parser.WhileStatement
-
- initializeforwardLV(VariableSet) - Method in class org.apache.sysds.parser.WhileStatementBlock
-
- initializeGPU() - Static method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContextPool
-
Static initialization of the number of devices
Also sets behaviour for J{Cuda, Cudnn, Cublas, Cusparse} in case of error
Initializes the CUDA driver
All these need be done once, and not per GPU
- initializeThread() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Sets the device for the calling thread.
- initialValue - Variable in class org.apache.sysds.runtime.matrix.operators.AggregateOperator
-
- initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.decode.Decoder
-
- initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.decode.DecoderComposite
-
- initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.decode.DecoderDummycode
-
- initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.decode.DecoderPassThrough
-
- initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.decode.DecoderRecode
-
- initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.Encoder
-
Sets up the required meta data for a subsequent call to apply.
- initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderBin
-
- initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderComposite
-
- initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderDummycode
-
- initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderFeatureHash
-
- initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
-
- initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
-
- initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderPassThrough
-
- initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderRecode
-
Construct the recodemaps from the given input frame for all
columns registered for recode.
- initRecodeIDList(List<Integer>) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
-
- initSparse(int, int, DataInput) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
Initializes the CSR sparse block from an ordered input
stream of sparse rows (rownnz, jv-pairs*).
- initUltraSparse(int, DataInput) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
Initializes the CSR sparse block from an ordered input
stream of ultra-sparse ijv triples.
- inmemoryIndexing(JavaPairRDD<MatrixIndexes, MatrixBlock>, DataCharacteristics, DataCharacteristics, IndexRange) - Static method in class org.apache.sysds.runtime.instructions.spark.MatrixIndexingSPInstruction
-
- input(int) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- input1 - Variable in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- input1 - Variable in class org.apache.sysds.runtime.instructions.cp.ComputationCPInstruction
-
- input1 - Variable in class org.apache.sysds.runtime.instructions.fed.ComputationFEDInstruction
-
- input1 - Variable in class org.apache.sysds.runtime.instructions.spark.ComputationSPInstruction
-
- input1 - Variable in class org.apache.sysds.runtime.instructions.spark.WriteSPInstruction
-
- input1 - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- input2 - Variable in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- input2 - Variable in class org.apache.sysds.runtime.instructions.cp.ComputationCPInstruction
-
- input2 - Variable in class org.apache.sysds.runtime.instructions.fed.ComputationFEDInstruction
-
- input2 - Variable in class org.apache.sysds.runtime.instructions.spark.ComputationSPInstruction
-
- input2 - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- input3 - Variable in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- input3 - Variable in class org.apache.sysds.runtime.instructions.cp.ComputationCPInstruction
-
- input3 - Variable in class org.apache.sysds.runtime.instructions.fed.ComputationFEDInstruction
-
- input3 - Variable in class org.apache.sysds.runtime.instructions.spark.ComputationSPInstruction
-
- inputFormatClass - Variable in class org.apache.sysds.runtime.io.InputOutputInfo
-
- InputOutputInfo - Class in org.apache.sysds.runtime.io
-
- InputOutputInfo(Class<? extends InputFormat>, Class<? extends OutputFormat>, Class<? extends Writable>, Class<? extends Writable>) - Constructor for class org.apache.sysds.runtime.io.InputOutputInfo
-
- inputParams - Variable in class org.apache.sysds.parser.dml.DmlParser.ExternalFunctionDefExpressionContext
-
- inputParams - Variable in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
-
- InputStreamInputFormat - Class in org.apache.sysds.runtime.util
-
Custom input format and record reader to redirect common implementation of csv read
over record readers (which are required for the parallel readers) to an input stream.
- InputStreamInputFormat(InputStream) - Constructor for class org.apache.sysds.runtime.util.InputStreamInputFormat
-
- inRowRange(long) - Method in class org.apache.sysds.runtime.util.IndexRange
-
- INST_BEGIN - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- INST_END - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- InstallDependencyForIntegrationTests - Class in org.apache.sysds.utils
-
This class will be used to setup dependency on Eclipse environment as well as on Jenkins server
- InstallDependencyForIntegrationTests() - Constructor for class org.apache.sysds.utils.InstallDependencyForIntegrationTests
-
- Instruction - Class in org.apache.sysds.runtime.instructions
-
- Instruction.IType - Enum in org.apache.sysds.runtime.instructions
-
- INSTRUCTION_DELIM - Static variable in class org.apache.sysds.runtime.instructions.Instruction
-
- INSTRUCTION_DELIMITOR - Static variable in class org.apache.sysds.lops.Lop
-
- InstructionParser - Class in org.apache.sysds.runtime.instructions
-
- InstructionParser() - Constructor for class org.apache.sysds.runtime.instructions.InstructionParser
-
- InstructionUtils - Class in org.apache.sysds.runtime.instructions
-
- InstructionUtils() - Constructor for class org.apache.sysds.runtime.instructions.InstructionUtils
-
- INT - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- INT() - Method in class org.apache.sysds.parser.dml.DmlParser.ConstIntIdExpressionContext
-
- INT - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- INT_SIZE - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
- INT_VALUE_TYPE - Static variable in class org.apache.sysds.parser.Statement
-
- intArrayCost(int) - Static method in class org.apache.sysds.utils.MemoryEstimates
-
- IntArrayList - Class in org.apache.sysds.runtime.compress.utils
-
This class provides a memory-efficient replacement for ArrayList<Integer>
for restricted use cases.
- IntArrayList() - Constructor for class org.apache.sysds.runtime.compress.utils.IntArrayList
-
- IntArrayList(int) - Constructor for class org.apache.sysds.runtime.compress.utils.IntArrayList
-
- IntArrayList(int[]) - Constructor for class org.apache.sysds.runtime.compress.utils.IntArrayList
-
- intDiv(double, double) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- IntegerDivide - Class in org.apache.sysds.runtime.functionobjects
-
- INTEGRATION - Static variable in class org.apache.sysds.hops.codegen.SpoofCompiler
-
- INTERAL_FN_INDEX_COL - Static variable in class org.apache.sysds.parser.ParForStatementBlock
-
- INTERAL_FN_INDEX_ROW - Static variable in class org.apache.sysds.parser.ParForStatementBlock
-
- InterestingPoint - Class in org.apache.sysds.hops.codegen.opt
-
Interesting decision point with regard to materialization of intermediates.
- InterestingPoint(InterestingPoint.DecisionType, long, long) - Constructor for class org.apache.sysds.hops.codegen.opt.InterestingPoint
-
- InterestingPoint.DecisionType - Enum in org.apache.sysds.hops.codegen.opt
-
- INTERNAL_NAMESPACE - Static variable in class org.apache.sysds.parser.DMLProgram
-
- InternalFunctionDefExpressionContext(DmlParser.FunctionStatementContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
-
- InternalProxy() - Constructor for class org.apache.sysds.api.mlcontext.MLContext.InternalProxy
-
- InterProceduralAnalysis - Class in org.apache.sysds.hops.ipa
-
This Inter Procedural Analysis (IPA) serves two major purposes:
1) Inter-Procedure Analysis: propagate statistics from calling program into
functions and back into main program.
- InterProceduralAnalysis(DMLProgram) - Constructor for class org.apache.sysds.hops.ipa.InterProceduralAnalysis
-
Creates a handle for performing inter-procedural analysis
for a given DML program and its associated HOP DAGs.
- InterProceduralAnalysis(StatementBlock) - Constructor for class org.apache.sysds.hops.ipa.InterProceduralAnalysis
-
- interQuartileMean() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- intHashCode(int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- intHashCodeRobust(int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- IntIdentifier - Class in org.apache.sysds.parser
-
- IntIdentifier(long) - Constructor for class org.apache.sysds.parser.IntIdentifier
-
- IntIdentifier(long, ParseInfo) - Constructor for class org.apache.sysds.parser.IntIdentifier
-
- IntIdentifier(IntIdentifier, ParseInfo) - Constructor for class org.apache.sysds.parser.IntIdentifier
-
- IntIdentifier(ParserRuleContext, long, String) - Constructor for class org.apache.sysds.parser.IntIdentifier
-
- IntObject - Class in org.apache.sysds.runtime.instructions.cp
-
- IntObject(long) - Constructor for class org.apache.sysds.runtime.instructions.cp.IntObject
-
- intToBa(int, byte[], int) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- INVALID_PARAMETERS - Static variable in class org.apache.sysds.parser.LanguageException.LanguageErrorCodes
-
- INVALID_SIZE - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
- invalidByLength(MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
This method validates the frame data against an attribute length constrain
if data value in any cell is greater than the specified threshold of that attribute
the output frame will store a null on that cell position, thus removing the length-violating values.
- investigateEstimate - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
-
Boolean specifying if the compression strategy should be investigated and monitored.
- invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.sysds.runtime.util.CommonThreadPool
-
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.sysds.runtime.util.CommonThreadPool
-
- invokeAndShutdown(ExecutorService, Collection<? extends Callable<T>>) - Static method in class org.apache.sysds.runtime.util.CommonThreadPool
-
- invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.sysds.runtime.util.CommonThreadPool
-
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.sysds.runtime.util.CommonThreadPool
-
- IO_FILE_BUFFER_SIZE - Static variable in class org.apache.sysds.runtime.util.HDFSTool
-
- IO_FILENAME - Static variable in class org.apache.sysds.parser.DataExpression
-
- IO_SERIALIZATIONS - Static variable in class org.apache.sysds.runtime.util.HDFSTool
-
- IOUtilFunctions - Class in org.apache.sysds.runtime.io
-
- IOUtilFunctions() - Constructor for class org.apache.sysds.runtime.io.IOUtilFunctions
-
- IOUtilFunctions.CountRowsTask - Class in org.apache.sysds.runtime.io
-
- IPA_NUM_REPETITIONS - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Number of inter-procedural analysis (IPA) repetitions.
- IPAPass - Class in org.apache.sysds.hops.ipa
-
Base class for all IPA passes.
- IPAPass() - Constructor for class org.apache.sysds.hops.ipa.IPAPass
-
- IPAPassApplyStaticAndDynamicHopRewrites - Class in org.apache.sysds.hops.ipa
-
This rewrite applies static hop dag and statement block
rewrites such as constant folding and branch removal
in order to simplify statistic propagation.
- IPAPassApplyStaticAndDynamicHopRewrites() - Constructor for class org.apache.sysds.hops.ipa.IPAPassApplyStaticAndDynamicHopRewrites
-
- IPAPassEliminateDeadCode - Class in org.apache.sysds.hops.ipa
-
This rewrite eliminates unnecessary sub-DAGs that produce
transient write outputs which are never consumed subsequently.
- IPAPassEliminateDeadCode() - Constructor for class org.apache.sysds.hops.ipa.IPAPassEliminateDeadCode
-
- IPAPassFlagFunctionsRecompileOnce - Class in org.apache.sysds.hops.ipa
-
This rewrite marks functions with loops as recompile once
in order to reduce recompilation overhead.
- IPAPassFlagFunctionsRecompileOnce() - Constructor for class org.apache.sysds.hops.ipa.IPAPassFlagFunctionsRecompileOnce
-
- IPAPassFlagNonDeterminism - Class in org.apache.sysds.hops.ipa
-
- IPAPassFlagNonDeterminism() - Constructor for class org.apache.sysds.hops.ipa.IPAPassFlagNonDeterminism
-
- IPAPassForwardFunctionCalls - Class in org.apache.sysds.hops.ipa
-
This rewrite forwards a function call to a function with a simple
function call that only consumes function parameters and literals
into the original call location.
- IPAPassForwardFunctionCalls() - Constructor for class org.apache.sysds.hops.ipa.IPAPassForwardFunctionCalls
-
- IPAPassInlineFunctions - Class in org.apache.sysds.hops.ipa
-
This rewrite inlines single statement block functions, which have fewer
operations than an internal threshold.
- IPAPassInlineFunctions() - Constructor for class org.apache.sysds.hops.ipa.IPAPassInlineFunctions
-
- IPAPassPropagateReplaceLiterals - Class in org.apache.sysds.hops.ipa
-
This rewrite propagates and replaces literals into functions
in order to enable subsequent rewrites such as branch removal.
- IPAPassPropagateReplaceLiterals() - Constructor for class org.apache.sysds.hops.ipa.IPAPassPropagateReplaceLiterals
-
- IPAPassRemoveConstantBinaryOps - Class in org.apache.sysds.hops.ipa
-
This rewrite identifies binary operations with constant matrices
such as X * ones, where ones might be created as a vector of ones
before a loop.
- IPAPassRemoveConstantBinaryOps() - Constructor for class org.apache.sysds.hops.ipa.IPAPassRemoveConstantBinaryOps
-
- IPAPassRemoveUnnecessaryCheckpoints - Class in org.apache.sysds.hops.ipa
-
This rewrite identifies and removes unnecessary checkpoints, i.e.,
persisting of Spark RDDs into a given storage level.
- IPAPassRemoveUnnecessaryCheckpoints() - Constructor for class org.apache.sysds.hops.ipa.IPAPassRemoveUnnecessaryCheckpoints
-
- IPAPassRemoveUnusedFunctions - Class in org.apache.sysds.hops.ipa
-
This rewrite identifies and removes unused functions in order
to reduce compilation overhead and other overheads such as
parfor worker creation, where we construct function copies.
- IPAPassRemoveUnusedFunctions() - Constructor for class org.apache.sysds.hops.ipa.IPAPassRemoveUnusedFunctions
-
- isAccumulator() - Method in class org.apache.sysds.parser.AssignmentStatement
-
- isActive() - Static method in class org.apache.sysds.utils.MLContextProxy
-
- isActiveAM() - Static method in class org.apache.sysds.api.DMLScript
-
- isAggUnaryOp(Hop, Types.AggOp, Types.Direction) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isAggUnaryOp(Hop, Types.AggOp...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isAligned(FederationMap, boolean) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- isAligned(SparseBlock) - Method in class org.apache.sysds.runtime.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.sysds.runtime.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.
- isAllCols() - Method in class org.apache.sysds.hops.IndexingOp
-
- isAllocated() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- isAllocated() - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- isAllocated(int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Indicates if the underlying data structure for a given row
is already allocated.
- isAllocated(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- isAllocated(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- isAllocated(int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- isAllocated() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- isAllocated() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
- isAllocated() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- isAllOnes(Integer...) - Method in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- isAllPathsTaken() - Method in class org.apache.sysds.runtime.lineage.LineageDedupBlock
-
- isAllRows() - Method in class org.apache.sysds.hops.IndexingOp
-
- isAllZero() - Method in class org.apache.sysds.runtime.instructions.cp.KahanObject
-
- isApplicable(FunctionCallGraph) - Method in class org.apache.sysds.hops.ipa.IPAPass
-
Indicates if an IPA pass is applicable for the current
configuration such as global flags or the chosen execution
mode (e.g., HYBRID).
- isApplicable(FunctionCallGraph) - Method in class org.apache.sysds.hops.ipa.IPAPassApplyStaticAndDynamicHopRewrites
-
- isApplicable(FunctionCallGraph) - Method in class org.apache.sysds.hops.ipa.IPAPassEliminateDeadCode
-
- isApplicable(FunctionCallGraph) - Method in class org.apache.sysds.hops.ipa.IPAPassFlagFunctionsRecompileOnce
-
- isApplicable(FunctionCallGraph) - Method in class org.apache.sysds.hops.ipa.IPAPassFlagNonDeterminism
-
- isApplicable(FunctionCallGraph) - Method in class org.apache.sysds.hops.ipa.IPAPassForwardFunctionCalls
-
- isApplicable(FunctionCallGraph) - Method in class org.apache.sysds.hops.ipa.IPAPassInlineFunctions
-
- isApplicable(FunctionCallGraph) - Method in class org.apache.sysds.hops.ipa.IPAPassPropagateReplaceLiterals
-
- isApplicable(FunctionCallGraph) - Method in class org.apache.sysds.hops.ipa.IPAPassRemoveConstantBinaryOps
-
- isApplicable(FunctionCallGraph) - Method in class org.apache.sysds.hops.ipa.IPAPassRemoveUnnecessaryCheckpoints
-
- isApplicable(FunctionCallGraph) - Method in class org.apache.sysds.hops.ipa.IPAPassRemoveUnusedFunctions
-
- isApplicable() - Method in class org.apache.sysds.runtime.transform.encode.Encoder
-
Indicates if this encoder is applicable, i.e, if there is at
least one column to encode.
- isApplicable(int) - Method in class org.apache.sysds.runtime.transform.encode.Encoder
-
Indicates if this encoder is applicable for the given column ID,
i.e., if it is subject to this transformation.
- isApplicableForReuseVariable(DMLProgram, StatementBlock, String) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.ProgramRecompiler
-
This function determines if an parfor input variable is guaranteed to be read-only
across multiple invocations of parfor optimization (e.g., in a surrounding while loop).
- isASP() - Method in enum org.apache.sysds.parser.Statement.PSUpdateType
-
- isAssignOrCopyVariable() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- isAssignVariable() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- isAtLeastOneError() - Method in class org.apache.sysds.parser.dml.CustomErrorListener
-
- isAtLeastOneError() - Method in class org.apache.sysds.parser.ParserWrapper
-
- isAtLeastOneWarning() - Method in class org.apache.sysds.parser.dml.CustomErrorListener
-
- isAtLeastOneWarning() - Method in class org.apache.sysds.parser.ParserWrapper
-
- isAutoCreateVars() - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- isBasic() - Method in enum org.apache.sysds.lops.WeightedDivMM.WDivMMType
-
- isBasic() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- isBasic1NSequence(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isBasic1NSequence(Hop, Hop, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isBasicN1Sequence(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isBasicType(Object) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Is the object one of the supported basic data types? (Integer, Boolean,
Double, String)
- isBinary(CNode, CNodeBinary.BinType...) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isBinary(Hop, Types.OpOp2) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isBinary(Hop, Types.OpOp2...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isBinary(Hop, Types.OpOp2, int) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isBinaryMatrixColVector(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isBinaryMatrixColVectorOperation(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isBinaryMatrixMatrixOperation(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isBinaryMatrixMatrixOperationWithSharedInput(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isBinaryMatrixRowVector(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isBinaryMatrixScalar(Hop, Types.OpOp2, double) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isBinaryMatrixScalarOperation(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isBinaryOpConditionalSparseSafe(Types.OpOp2) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Determines if a given binary op is potentially conditional sparse safe.
- isBinaryOpConditionalSparseSafeExact(Types.OpOp2, LiteralOp) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Determines if a given binary op with scalar literal guarantee an output
sparsity which is exactly the same as its matrix input sparsity.
- isBinaryOpSparsityConditionalSparseSafe(Types.OpOp2, LiteralOp) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- isBinaryPPred(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isBinarySparseSafe(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isBlocked() - Method in class org.apache.sysds.lops.OutputParameters
-
- IsBlockInList - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- IsBlockInList(long[], DataCharacteristics) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.IsBlockInList
-
- IsBlockInRange - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- IsBlockInRange(long, long, long, long, DataCharacteristics) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.IsBlockInRange
-
- isBlockwise() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
-
- isBSP() - Method in enum org.apache.sysds.parser.Statement.PSUpdateType
-
- isBuffered() - Method in class org.apache.sysds.runtime.instructions.gpu.context.ShadowBuffer
-
Check if the gpu object is shadow buffered
- isBuiltinCode(ValueFunction, Builtin.BuiltinCode) - Static method in class org.apache.sysds.runtime.functionobjects.Builtin
-
- isBuiltinFnObject(String) - Static method in class org.apache.sysds.runtime.functionobjects.Builtin
-
- isBuiltinFunction(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- isCached(boolean) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- isCachingActive() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- isCastUnaryOperation() - Method in class org.apache.sysds.hops.UnaryOp
-
- isCellOp() - Method in enum org.apache.sysds.common.Types.OpOpN
-
- isCheckpointRDD() - Method in class org.apache.sysds.runtime.instructions.spark.data.RDDObject
-
- isCleanupEnabled() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
Indicates if cleanup of the associated data object
is enabled on clearData().
- isClosed() - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- isClosed() - Method in enum org.apache.sysds.hops.codegen.template.TemplateBase.CloseType
-
- isClosed() - Method in class org.apache.sysds.hops.codegen.template.TemplateBase
-
- isCMAllZeros() - Method in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
- isCodegenEnabled() - Static method in class org.apache.sysds.conf.ConfigurationManager
-
- isColAggregate() - Method in class org.apache.sysds.runtime.matrix.operators.AggregateUnaryOperator
-
- isColLowerEqualsUpper() - Method in class org.apache.sysds.hops.IndexingOp
-
- isColLowerEqualsUpper() - Method in class org.apache.sysds.hops.LeftIndexingOp
-
- isColNameDefault(int) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- isColNamesDefault() - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- isColumnAgg() - Method in enum org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
-
- isColumnMetadataDefault() - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- isColumnMetadataDefault(int) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- isColumnRangeIndexing(IndexingOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isColumnRightIndexing(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isColVector(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isColVector(CNode) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isCommutative() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
-
- isCompareOperator(BinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixOuterAgg
-
This will return if uaggOp is of type RowIndexMin
- isComplexType(Object) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Is the object one of the supported complex data types? (JavaRDD, RDD,
DataFrame, Matrix, double[][], MatrixBlock, URL)
- isConsecutiveIndex(Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isConstDim2(long) - Method in enum org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
-
- isContiguous() - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Indicates if the dense block has a single
underlying block, i.e., if numBlocks==1.
- isContiguous(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Indicates if the dense block has a single
underlying block for the given row range.
- isContiguous() - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
-
- isContiguous(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
-
- isContiguous() - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
-
- isContiguous(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
-
- isContiguous() - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
-
- isContiguous() - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
-
- isContiguous() - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
-
- isContiguous() - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
-
- isContiguous() - Method in class org.apache.sysds.runtime.data.DenseBlockLString
-
- isContiguous() - Method in class org.apache.sysds.runtime.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.sysds.runtime.data.SparseBlockCOO
-
- isContiguous() - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- isContiguous() - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- isCostBased() - Method in enum org.apache.sysds.hops.codegen.SpoofCompiler.PlanSelector
-
- isCountFunction() - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- isCOVAllZeros() - Method in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
- isCPOnly() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
Determines if all program blocks and instructions exhibit
the execution type CP.
- isCreateVariable() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- isCSVLineAllNumbers(String) - Static method in class org.apache.sysds.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)
- isCSVReadWithUnknownSize() - Method in class org.apache.sysds.parser.DataExpression
-
- isCumulativeUnaryOperation() - Method in class org.apache.sysds.hops.UnaryOp
-
- isCutSet(boolean[]) - Method in class org.apache.sysds.hops.codegen.opt.ReachabilityGraph
-
- isCutSet(ReachabilityGraph.CutSet, boolean[]) - Method in class org.apache.sysds.hops.codegen.opt.ReachabilityGraph
-
- isData(Hop, Types.OpOpData) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isDataExecLocation() - Method in class org.apache.sysds.lops.Lop
-
- isDataFrameWithIDColumn(MatrixMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Return whether or not the DataFrame has an ID column.
- isDataFrameWithIDColumn(FrameMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Return whether or not the DataFrame has an ID column.
- isDataGenOp(Hop, Types.OpOpDG...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isDataGenOpWithConstantValue(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isDataGenOpWithConstantValue(Hop, double) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isDataGenOpWithLiteralInputs(Hop, Types.OpOpDG...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isDataGenOpWithNonDeterminism(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isDedup() - Method in class org.apache.sysds.runtime.lineage.LineageItem
-
- isDelimitedFormat() - Method in enum org.apache.sysds.common.Types.FileFormat
-
- isDelimitedFormat(String) - Static method in enum org.apache.sysds.common.Types.FileFormat
-
- isDense(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isDenseBlockType(DenseBlock, DenseBlock.Type) - Static method in class org.apache.sysds.runtime.data.DenseBlockFactory
-
- isDensePointerNull() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Checks if the dense pointer is null
- isDiag() - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
- isDimsKnown(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isDimsPreservingFunction(String) - Method in class org.apache.sysds.hops.ipa.FunctionCallSizeInfo
-
Indicates if the given function belongs to the set
of dimension-preserving functions.
- isDirectory(String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- isDirty() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
true
if the in-memory or evicted matrix may be different from
the matrix located at
CacheableData._hdfsFileName
;
false
if the two
matrices are supposed to be the same.
- isDirty() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Whether this block is dirty on the GPU
- isDistQuaternaryOpcode(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- isDnn(Hop, Types.OpOpDnn) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isDnn(Hop, Types.OpOpDnn...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isDynamicRecompilation() - Static method in class org.apache.sysds.conf.ConfigurationManager
-
- isEligibleForBuffering(boolean, boolean) - Method in class org.apache.sysds.runtime.instructions.gpu.context.ShadowBuffer
-
Checks if the GPU object is eligible for shadow buffering
- isEmpty(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isEmpty(boolean) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- isEmpty(boolean) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- isEmpty(int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Get information if row r is empty, i.e., does not contain non-zero
values.
- isEmpty(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- isEmpty(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- isEmpty(int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- isEmpty() - Method in class org.apache.sysds.runtime.data.SparseRow
-
Indicates if the sparse row is empty, i.e., if is has
size zero.
- isEmpty() - Method in class org.apache.sysds.runtime.data.SparseRowScalar
-
- isEmpty() - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- isEmpty() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- isEmpty(boolean) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- isEmpty() - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- isEmpty() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- isEmpty() - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- isEmpty() - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- isEmptyBlock(boolean) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- isEmptyBlock() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- isEmptyBlock(boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- isEmptyNewLineStatement() - Method in class org.apache.sysds.parser.Statement
-
- isEnabled() - Method in enum org.apache.sysds.lops.Compression.CompressConfig
-
- isEqualMatrixSize(BinaryOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isEqualSize(Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isEqualSize(Hop, Hop...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isEqualValue(LiteralOp, LiteralOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isExisting(String) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
- isExpensiveUnaryOperation() - Method in class org.apache.sysds.hops.UnaryOp
-
- isExplain() - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Whether or not an explanation of the DML/PYDML program should be output
to standard output.
- isFederated() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
Check if object is federated.
- isFederated(FederationMap.FType) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- isFileEmpty(FileSystem, Path) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- isFill() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
-
- isFlipOuter(int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- isForceGPU() - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Whether or not the "force" GPU mode is enabled.
- isFrame() - Method in enum org.apache.sysds.common.Types.DataType
-
- isFrame() - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- IsFrameBlockInRange - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- IsFrameBlockInRange(long, long, DataCharacteristics) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.IsFrameBlockInRange
-
- isFrameObject(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- isFullColumnIndexing(LeftIndexingOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isFullColumnIndexing(IndexingOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isFullReuse() - Method in enum org.apache.sysds.runtime.lineage.LineageCacheConfig.ReuseCacheType
-
- isFullRowIndexing(LeftIndexingOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isFullRowIndexing(IndexingOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isGenerated() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- isGPU() - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Whether or not the GPU mode is enabled.
- isGPUEnabled() - Method in class org.apache.sysds.hops.AggBinaryOp
-
- isGPUEnabled() - Method in class org.apache.sysds.hops.AggUnaryOp
-
- isGPUEnabled() - Method in class org.apache.sysds.hops.BinaryOp
-
- isGPUEnabled() - Method in class org.apache.sysds.hops.codegen.SpoofFusedOp
-
- isGPUEnabled() - Method in class org.apache.sysds.hops.DataGenOp
-
- isGPUEnabled() - Method in class org.apache.sysds.hops.DataOp
-
- isGPUEnabled() - Method in class org.apache.sysds.hops.DnnOp
-
- isGPUEnabled() - Method in class org.apache.sysds.hops.FunctionOp
-
- isGPUEnabled() - Method in class org.apache.sysds.hops.Hop
-
In memory-based optimizer mode (see OptimizerUtils.isMemoryBasedOptLevel()),
the exectype is determined by checking this method as well as memory budget of this Hop.
- isGPUEnabled() - Method in class org.apache.sysds.hops.IndexingOp
-
- isGPUEnabled() - Method in class org.apache.sysds.hops.LeftIndexingOp
-
- isGPUEnabled() - Method in class org.apache.sysds.hops.LiteralOp
-
- isGPUEnabled() - Method in class org.apache.sysds.hops.NaryOp
-
- isGPUEnabled() - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- isGPUEnabled() - Method in class org.apache.sysds.hops.QuaternaryOp
-
- isGPUEnabled() - Method in class org.apache.sysds.hops.ReorgOp
-
- isGPUEnabled() - Method in class org.apache.sysds.hops.TernaryOp
-
- isGPUEnabled() - Method in class org.apache.sysds.hops.UnaryOp
-
- isHashPartitioned(JavaPairRDD<?, ?>) - Static method in class org.apache.sysds.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
.
- isHDFSFile() - Method in class org.apache.sysds.runtime.instructions.spark.data.RDDObject
-
- isHDFSFileEmpty(String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- isHDFSFileExists() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- isHeuristic() - Method in enum org.apache.sysds.hops.codegen.SpoofCompiler.PlanSelector
-
- isHopsType(boolean) - Method in enum org.apache.sysds.utils.Explain.ExplainType
-
- isHybridExecutionMode() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- isIDSpec(String) - Static method in class org.apache.sysds.runtime.transform.meta.TfMetaUtils
-
- isIDSpec(JSONObject) - Static method in class org.apache.sysds.runtime.transform.meta.TfMetaUtils
-
- isIJVFormat() - Method in enum org.apache.sysds.common.Types.FileFormat
-
- isIn(TemplateBase.TemplateType...) - Method in enum org.apache.sysds.hops.codegen.template.TemplateBase.TemplateType
-
- isInBlockRange(MatrixIndexes, int, long, long, long, long) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- isInBlockRange(MatrixIndexes, int, IndexRange) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- isIndexingRangeBlockAligned(IndexRange, DataCharacteristics) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Indicates if the given indexing range is block aligned, i.e., it does not require
global aggregation of blocks.
- isIndexingRangeBlockAligned(long, long, long, long, long) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Indicates if the given indexing range is block aligned, i.e., it does not require
global aggregation of blocks.
- isInFrameBlockRange(Long, int, long, long) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- isInFrameBlockRange(Long, int, IndexRange) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- isInitBeforeExecution() - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Whether or not the default ScriptExecutor should be initialized before
execution.
- isInitialCodegen() - Method in class org.apache.sysds.hops.recompile.RecompileStatus
-
- isInitialized() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
-
- isInitialized() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- isInMemoryResultMerge(long, long, double) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerRuleBased
-
- isInParforContext() - Method in class org.apache.sysds.hops.rewrite.ProgramRewriteStatus
-
- isInPlace() - Method in enum org.apache.sysds.runtime.controlprogram.caching.MatrixObject.UpdateType
-
- isInplace() - Method in class org.apache.sysds.runtime.matrix.operators.UnaryOperator
-
- isInSparseFormat() - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- isInSparseFormat(GPUContext, MatrixObject) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
- isInSparseFormat() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Returns the current representation (true for sparse).
- isInSparseFormat() - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- isInSparseFormat() - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- isInstruction() - Method in class org.apache.sysds.runtime.lineage.LineageItem
-
- isIntegerNumber(String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- isIntField() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesMM
-
- isLastLevelStatementBlock(StatementBlock) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isLazySparkContextCreation() - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- isLeaf() - Method in class org.apache.sysds.hops.estim.MMNode
-
- isLeaf() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- isLeaf() - Method in class org.apache.sysds.runtime.lineage.LineageItem
-
- isLeft() - Method in enum org.apache.sysds.lops.MMTSJ.MMTSJType
-
- isLeft() - Method in enum org.apache.sysds.lops.WeightedDivMM.WDivMMType
-
- isList() - Method in enum org.apache.sysds.common.Types.DataType
-
- isList() - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- isLiteral() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- isLiteral(CNode) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isLiteral(CNode, String) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isLiteral() - Method in class org.apache.sysds.lops.Data
-
method to check if this data lop represents a literal.
- isLiteral() - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- isLiteralOfValue(Hop, Double...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isLiteralOfValue(Hop, double) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isLiteralOfValue(Hop, String) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isLiteralOfValue(Hop, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isLocal() - Method in enum org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PResultMerge
-
- isLocalMaster() - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- isLocalMode() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
- isLocalMode(JobConf) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
- isLocked() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
- isLookup(CNode, boolean) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isLoop() - Method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.NodeType
-
- isLoopStatementBlock(StatementBlock) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isLossy() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Is Lossy
- isLossy() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- isLossy() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupValue
-
- isMaintainSymbolTable() - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Obtain whether or not all values should be maintained in the symbol table
after execution.
- isMaintainSymbolTable() - Method in class org.apache.sysds.api.mlcontext.ScriptExecutor
-
Obtain whether or not all values should be maintained in the symbol table
after execution.
- isMarked() - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
- isMatMultMemoryBound(int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixNative
-
- isMatPoint(InterestingPoint[], long, CPlanMemoTable.MemoTableEntry, boolean[]) - Static method in class org.apache.sysds.hops.codegen.opt.InterestingPoint
-
- isMatPoint(InterestingPoint[], long, long) - Static method in class org.apache.sysds.hops.codegen.opt.InterestingPoint
-
- isMatrix() - Method in enum org.apache.sysds.common.Types.DataType
-
- isMatrix(CNode) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isMatrix(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isMatrix() - Method in class org.apache.sysds.hops.Hop
-
- isMatrix(String) - Method in class org.apache.sysds.parser.VariableSet
-
- isMatrix() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- isMatrix() - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- isMatrixCall() - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- isMatrixIgnoreZeroRewriteApplicable() - Method in class org.apache.sysds.hops.TernaryOp
-
Used for (1) constructing CP lops (hop-lop rewrite), and (2) in order to determine
if dag split after removeEmpty necessary (#2 is precondition for #1).
- isMatrixMultiply() - Method in class org.apache.sysds.hops.AggBinaryOp
-
- isMatrixMultiply(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isMatrixObject(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- isMatrixValue() - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
-
- isMaxLocalParallelism(int) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- isMemEstimated() - Method in class org.apache.sysds.hops.Hop
-
- isMemoryBasedOptLevel() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- isMergeableFunctionCallBlock(DMLProgram) - Method in class org.apache.sysds.parser.StatementBlock
-
- isMeta() - Method in enum org.apache.sysds.runtime.instructions.cp.AggregateUnaryCPInstruction.AUType
-
- isMetadataOperation() - Method in class org.apache.sysds.hops.UnaryOp
-
- isMinus() - Method in enum org.apache.sysds.lops.WeightedDivMM.WDivMMType
-
- isMult() - Method in enum org.apache.sysds.lops.WeightedDivMM.WDivMMType
-
- isMultiBlockLookup(JavaPairRDD<?, ?>, DataCharacteristics, DataCharacteristics, IndexRange) - Static method in class org.apache.sysds.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).
- isMultiLevelReuse() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- isMultilevelReuse() - Method in enum org.apache.sysds.runtime.lineage.LineageCacheConfig.ReuseCacheType
-
- isMultiReturn() - Method in enum org.apache.sysds.common.Builtins
-
- isMultiThreadedOp(Types.OpOp1) - Static method in class org.apache.sysds.lops.Unary
-
- isMultiThreadedOpType() - Method in class org.apache.sysds.hops.AggBinaryOp
-
- isMultiThreadedOpType() - Method in class org.apache.sysds.hops.AggUnaryOp
-
- isMultiThreadedOpType() - Method in class org.apache.sysds.hops.BinaryOp
-
- isMultiThreadedOpType() - Method in class org.apache.sysds.hops.codegen.SpoofFusedOp
-
- isMultiThreadedOpType() - Method in class org.apache.sysds.hops.DataGenOp
-
- isMultiThreadedOpType() - Method in class org.apache.sysds.hops.DnnOp
-
- isMultiThreadedOpType() - Method in class org.apache.sysds.hops.MultiThreadedHop
-
- isMultiThreadedOpType() - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- isMultiThreadedOpType() - Method in class org.apache.sysds.hops.QuaternaryOp
-
- isMultiThreadedOpType() - Method in class org.apache.sysds.hops.ReorgOp
-
- isMultiThreadedOpType() - Method in class org.apache.sysds.hops.UnaryOp
-
- isNA(String[], String) - Static method in class org.apache.sysds.runtime.transform.TfUtils
-
Function that checks if the given string is one of NA strings.
- isNamedList() - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- isNary(Hop, Types.OpOpN) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isNary(Hop, Types.OpOpN...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isNativeLibraryLoaded() - Static method in class org.apache.sysds.utils.NativeHelper
-
Called by runtime to check if the BLAS is available for exploitation
- isNested() - Method in class org.apache.sysds.runtime.controlprogram.BasicProgramBlock
-
- isNested() - Method in class org.apache.sysds.runtime.controlprogram.ForProgramBlock
-
- isNested() - Method in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
-
- isNested() - Method in class org.apache.sysds.runtime.controlprogram.IfProgramBlock
-
- isNested() - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
Indicates if the program block is nested, i.e.,
if it contains other program blocks (e.g., loops).
- isNested() - Method in class org.apache.sysds.runtime.controlprogram.WhileProgramBlock
-
- isNodeType(OptNode.NodeType...) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- isNondeterministic() - Method in class org.apache.sysds.parser.FunctionStatementBlock
-
- isNondeterministic() - Method in class org.apache.sysds.parser.StatementBlock
-
- isNondeterministic() - Method in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
-
- isNone() - Static method in enum org.apache.sysds.runtime.lineage.LineageCacheConfig.ReuseCacheType
-
- isNonPartitionedBroadcastValid() - Method in class org.apache.sysds.runtime.instructions.spark.data.BroadcastObject
-
- isNonZero(Object) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- isNonZeroIndicator(Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isNotMatrixVectorBinaryOperation(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isNullVal() - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
-
- isNumeric() - Method in enum org.apache.sysds.common.Types.ValueType
-
- isNumeric() - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Indicates if the dense block is numeric.
- isNumeric() - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- isNumeric() - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- isNumeric() - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- isNumeric() - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- isNumeric() - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- isNumeric() - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
-
- isNumeric() - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
-
- isNumeric() - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
-
- isNumeric() - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
-
- isNumeric() - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
-
- isNumeric() - Method in class org.apache.sysds.runtime.data.DenseBlockLString
-
- isNumeric() - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- isObjectStoreFileScheme(Path) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- isOnesCol() - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- isOpcode(String) - Static method in class org.apache.sysds.lops.BinaryM
-
- isOperationSupported(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isOptLevel(OptimizerUtils.OptimizationLevel) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- isOuter() - Method in class org.apache.sysds.hops.BinaryOp
-
- isOuterBinary(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isOuterProductLikeMM(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isOutputEmptyBlocks() - Method in class org.apache.sysds.hops.Hop
-
- isOutputThreadSafe() - Method in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- isParallelizedRDD() - Method in class org.apache.sysds.runtime.instructions.spark.data.RDDObject
-
- isParallelMatrixOperations() - Static method in class org.apache.sysds.conf.ConfigurationManager
-
- isParallelParFor() - Static method in class org.apache.sysds.conf.ConfigurationManager
-
- isParameterBuiltinOp(Hop, Types.ParamBuiltinOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isParameterized() - Method in enum org.apache.sysds.common.Builtins
-
- isPartialAggregateOperator() - Method in class org.apache.sysds.runtime.matrix.operators.CMOperator
-
- isPartialReuse() - Method in enum org.apache.sysds.runtime.lineage.LineageCacheConfig.ReuseCacheType
-
- isPartitioned() - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
- isPartitionedBroadcastValid() - Method in class org.apache.sysds.runtime.instructions.spark.data.BroadcastObject
-
- isPatternField() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesMM
-
- isPending() - Method in class org.apache.sysds.runtime.instructions.spark.data.RDDObject
-
- isPersistent() - Method in enum org.apache.sysds.common.Types.OpOpData
-
- isPersistentRead() - Method in class org.apache.sysds.lops.Data
-
- isPersistentReadWrite() - Method in class org.apache.sysds.hops.DataOp
-
- isPersistentWrite() - Method in class org.apache.sysds.lops.Data
-
- isPlanRef(int) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- isPPredOperation() - Method in class org.apache.sysds.hops.BinaryOp
-
- isPseudoNumeric() - Method in enum org.apache.sysds.common.Types.ValueType
-
- isRDDCached(int) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- isReachableFunction(String, String) - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Indicates if the given function is reachable either directly or indirectly
from the main program.
- isReachableFunction(String) - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Indicates if the given function is reachable either directly or indirectly
from the main program.
- isRead() - Method in enum org.apache.sysds.common.Types.OpOpData
-
- isRead() - Method in class org.apache.sysds.hops.DataOp
-
- isRead() - Method in class org.apache.sysds.parser.DataExpression
-
- isRecompileOnce() - Method in class org.apache.sysds.parser.FunctionStatementBlock
-
- isRecompileOnce() - Method in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
-
- isRecursive() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- isRecursiveFunction(String, String) - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Indicates if the given function is either directly or indirectly recursive.
- isRecursiveFunction(String) - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Indicates if the given function is either directly or indirectly recursive.
- isRemoveEmpty(Hop, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isRemoveEmpty(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isRemoveVariable(String) - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
Checks if this instruction is a remove instruction for varName
- isRemoveVariable() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- isRemoveVariableNoFile() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- isReorg(Hop, Types.ReOrgOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isReorg(Hop, Types.ReOrgOp...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isReset() - Method in enum org.apache.sysds.hops.recompile.Recompiler.ResetType
-
- isReusable(Instruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- isRewritableFunctionCall(Statement, DMLProgram) - Method in class org.apache.sysds.parser.StatementBlock
-
- isRight() - Method in enum org.apache.sysds.lops.MapMult.CacheType
-
- isRight() - Method in enum org.apache.sysds.lops.WeightedDivMM.WDivMMType
-
- isRowAggregate() - Method in class org.apache.sysds.runtime.matrix.operators.AggregateUnaryOperator
-
- isRowIndexMax(AggregateUnaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixOuterAgg
-
This will return if uaggOp is of type RowIndexMax
- isRowIndexMin(AggregateUnaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixOuterAgg
-
This will return if uaggOp is of type RowIndexMin
- isRowLowerEqualsUpper() - Method in class org.apache.sysds.hops.IndexingOp
-
- isRowLowerEqualsUpper() - Method in class org.apache.sysds.hops.LeftIndexingOp
-
- isRows() - Method in enum org.apache.sysds.common.Types.CorrectionLocationType
-
- isRowTypeB1() - Method in enum org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
-
- isRowTypeB1ColumnAgg() - Method in enum org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
-
- isRowVector(CNode) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isRowwise() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
-
- isRuntimeType(boolean) - Method in enum org.apache.sysds.utils.Explain.ExplainType
-
- isSafeLiteral(String, int) - Method in class org.apache.sysds.hops.ipa.FunctionCallSizeInfo
-
Indicates if the given function input allows for safe
literal propagation and replacement, i.e., all function calls
have consistent literal inputs.
- isSafeNnz(String, int) - Method in class org.apache.sysds.hops.ipa.FunctionCallSizeInfo
-
Indicates if the given function input allows for safe
nnz propagation, i.e., all function calls have a consistent
number of non-zeros.
- isSameDimensionBinaryOp(Expression.BinaryOp) - Static method in class org.apache.sysds.parser.BinaryExpression
-
- isSameFileScheme(Path, Path) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- isScalar() - Method in enum org.apache.sysds.common.Types.DataType
-
- isScalar() - Method in class org.apache.sysds.hops.Hop
-
- isScalar() - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- isScalar() - Method in class org.apache.sysds.runtime.util.IndexRange
-
- isScalarBoolean() - Method in class org.apache.sysds.parser.Identifier
-
- isScalarLookup() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
-
- isScalarMatrixBinaryMult(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isScalarOutput() - Method in enum org.apache.sysds.common.Types.OpOp1
-
- isScript() - Method in enum org.apache.sysds.common.Builtins
-
- isSetSpill() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- isShallow() - Method in class org.apache.sysds.runtime.controlprogram.caching.ByteBuffer
-
- isShallowSerialize() - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- isShallowSerialize(boolean) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- isShallowSerialize() - Method in interface org.apache.sysds.runtime.controlprogram.caching.CacheBlock
-
Indicates if the cache block is subject to shallow serialized,
which is generally true if in-memory size and serialized size
are almost identical allowing to avoid unnecessary deep serialize.
- isShallowSerialize(boolean) - Method in interface org.apache.sysds.runtime.controlprogram.caching.CacheBlock
-
Indicates if the cache block is subject to shallow serialized,
which is generally true if in-memory size and serialized size
are almost identical allowing to avoid unnecessary deep serialize.
- isShallowSerialize() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- isShallowSerialize(boolean) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- isShallowSerialize() - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- isShallowSerialize(boolean) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- isShallowSerialize() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- isShallowSerialize(boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- isShortcutRandOperation(double, double, double, RandomMatrixGenerator.PDF) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDatagen
-
- isShutdown() - Method in class org.apache.sysds.runtime.util.CommonThreadPool
-
- isSideEffectFreeFunction(String, String) - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Indicates if the given function is side effect free, i.e., has no
prints, no persistent write, and includes no or only calls to
side-effect-free functions.
- isSideEffectFreeFunction(String) - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Indicates if the given function is side effect free, i.e., has no
prints, no persistent write, and includes no or only calls to
side-effect-free functions.
- isSingleBlock(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isSingleBlock(Hop, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
Checks our BLOCKSIZE CONSTRAINT, w/ awareness of forced single node
execution mode.
- isSingleBlockLookup(DataCharacteristics, IndexRange) - Static method in class org.apache.sysds.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.sysds.runtime.compress.CompressedMatrixBlock
-
- isSizeExpressionOf(Hop, Hop, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isSkinnyRightHandSide(long, long, long, long, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- isSorted(int, int, int[]) - Static method in class org.apache.sysds.runtime.util.SortUtils
-
- isSorted(int, int, double[]) - Static method in class org.apache.sysds.runtime.util.SortUtils
-
- isSorted(MatrixBlock) - Static method in class org.apache.sysds.runtime.util.SortUtils
-
- isSparkContextCreated() - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
Indicates if the spark context has been created or has
been passed in from outside.
- isSparkExecutionMode() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- isSparkVersionSupported(String, String) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Determine whether the Spark version is supported.
- isSparse(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isSparse(Hop, double) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isSparse() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- isSparse() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
- isSparse() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
-
- isSparseAndEmpty() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
If this
GPUObject
is sparse and empty
Being allocated is a prerequisite to being sparse and empty.
- isSparseBlockType(SparseBlock, SparseBlock.Type) - Static method in class org.apache.sysds.runtime.data.SparseBlockFactory
-
- isSparsePermutationMatrix() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- isSparseSafe() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- isSparseSafe() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
-
- isSparseSafe() - Method in class org.apache.sysds.runtime.codegen.SpoofCellwise
-
- isSparseSafe() - Method in class org.apache.sysds.runtime.codegen.SpoofMultiAggregate
-
- isSparseSafeDivide(BinaryOperator, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixBincell
-
- isSparseSafeScalar() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
-
- isSplitDag() - Method in class org.apache.sysds.parser.StatementBlock
-
- isStatistics() - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Whether or not statistics of the DML/PYDML program execution should be
output to standard output.
- isStride1Pad0() - Method in class org.apache.sysds.hops.DnnOp
-
- isStride1Pad0() - Method in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- isSuccessful() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedResponse
-
- isSuccessful() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcResponse
-
- isSuccessful() - Method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForJobReturn
-
- isSum(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isSumSq(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isSupportedMatrixMatrixOperation(String) - Static method in class org.apache.sysds.runtime.matrix.data.LibCommonsMath
-
- isSupportedMultiReturnOperation(String) - Static method in class org.apache.sysds.runtime.matrix.data.LibCommonsMath
-
- isSupportedReorgOperator(ReorgOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
- isSupportedUaggOp(AggregateUnaryOperator, BinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixOuterAgg
-
- isSupportedUnaryAggregateOperator(AggregateUnaryOperator) - Static method in class org.apache.sysds.runtime.data.LibTensorAgg
-
Determines whether the unary operator is supported.
- isSupportedUnaryAggregateOperator(AggregateUnaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
-
- isSupportedUnaryOperation(String) - Static method in class org.apache.sysds.runtime.matrix.data.LibCommonsMath
-
- isSupportedUnaryOperator(UnaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
-
- isSymmetric() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesMM
-
- isTargetDiagInput() - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- isTensor() - Method in enum org.apache.sysds.common.Types.DataType
-
- isTensor() - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- isTerminated() - Method in class org.apache.sysds.runtime.util.CommonThreadPool
-
- isTernary(CNode, CNodeTernary.TernaryType...) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isTernary(Hop, Types.OpOp3) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isTernary(Hop, Types.OpOp3...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isTextFormat() - Method in enum org.apache.sysds.common.Types.FileFormat
-
- isTextFormat(String) - Static method in enum org.apache.sysds.common.Types.FileFormat
-
- isThreadID(long) - Static method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- isThreadSafe() - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Indicates if the underlying implementation allows thread-safe row
updates if concurrent threads update disjoint rows.
- isThreadSafe() - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- isThreadSafe() - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- isThreadSafe() - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- isThreadSafe() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Indicates if concurrent modifications of disjoint rows are thread-safe.
- isThreadSafe(boolean) - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Indicates if concurrent modifications of disjoint rows are thread-safe.
- isTimeBased() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- isTopLevelParFor() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- isTransient() - Method in enum org.apache.sysds.common.Types.OpOpData
-
- isTransposeOfItself(Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isTransposeOperation(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isTransposeOperation(Hop, int) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isTransposeOutput() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeOuterProduct
-
- isTransposeSafe() - Method in class org.apache.sysds.hops.AggUnaryOp
-
- isTransposeSafe() - Method in class org.apache.sysds.hops.Hop
-
Defines if this operation is transpose-safe, which means that
the result of op(input) is equivalent to op(t(input)).
- isTransposeSafe() - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- isTsmm(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isTsmmInput(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isType(TemplateBase.TemplateType, TemplateBase.TemplateType...) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isUltraSparse(int, int) - Method in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
Check for ultra sparsity
- isUltraSparse() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- isUltraSparse(boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- isUltraSparse() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- isUltraSparse() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- isUltraSparseMatrixMult(MatrixBlock, MatrixBlock, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- isUnary(CNode, CNodeUnary.UnaryType...) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isUnary(Hop, Types.OpOp1) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isUnary(Hop, Types.OpOp1, int) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isUnary(Hop, Types.OpOp1...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isUnaryMetadata(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- isUnaryOperatorPipeline(CNode) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isUnknown() - Method in enum org.apache.sysds.common.Types.DataType
-
- isUnknown() - Method in enum org.apache.sysds.common.Types.ValueType
-
- isUnnecessaryRightIndexing(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isValid() - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- isValid() - Method in enum org.apache.sysds.hops.codegen.template.TemplateBase.CloseType
-
- isValidCapacity(long, CacheBlock) - Static method in class org.apache.sysds.runtime.controlprogram.caching.ByteBuffer
-
Determines if byte buffer can hold the given size given this specific cache block.
- isValidCPDimensions(DataCharacteristics) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- isValidCPDimensions(long, long) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Returns false if dimensions known to be invalid; other true
- isValidCPDimensions(Types.ValueType[], String[]) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Returns false if schema and names are not properly specified; other true
Length to be > 0, and length of both to be equal.
- isValidCPMatrixSize(long, long, double) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Determines if valid matrix size to be represented in CP data structures.
- isValidDedupBlock(ProgramBlock, boolean) - Static method in class org.apache.sysds.runtime.lineage.LineageDedupUtils
-
- isValidDimensionsBinary(TensorBlock, TensorBlock) - Static method in class org.apache.sysds.runtime.data.LibTensorBincell
-
- isValidDimensionsBinary(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixBincell
-
- isValidFunction(String) - Method in class org.apache.sysds.hops.ipa.FunctionCallSizeInfo
-
Indicates if the given function is valid for statistics
propagation.
- isValidNumVectorIntermediates(CNode, CNode, Map<Long, Set<Long>>, Map<Long, Pair<Long, MutableInt>>, Set<Long>, int) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isValidOp(Types.AggOp, Types.AggOp...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isValidOp(Types.OpOp1, Types.OpOp1...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isValidOp(Types.OpOp2, Types.OpOp2...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isValidOp(Types.ReOrgOp, Types.ReOrgOp...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isValidOp(Types.ParamBuiltinOp, Types.ParamBuiltinOp...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isValidOuter() - Method in enum org.apache.sysds.common.Types.OpOp2
-
- isValidOuterBinaryOp(Types.OpOp2) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isValidParamName(String) - Static method in class org.apache.sysds.parser.OutputStatement
-
- isValidSingleOperation(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isValueTypeCast(Types.OpOp1) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- isVariable() - Method in class org.apache.sysds.lops.Lop
-
Function that determines if the output of a LOP is defined by a variable or not.
- isVariableCastInstruction() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- isVector(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isVector() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- isVector() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- isVectorBased() - Method in enum org.apache.sysds.api.mlcontext.MatrixFormat
-
Is the matrix format vector-based?
- isVectorBased() - Method in class org.apache.sysds.runtime.instructions.spark.data.DatasetObject
-
- isVectorBasedDataFrame(MatrixMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Return whether or not the DataFrame is vector-based.
- isVectorMatrixPrimitive() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
-
- isVectorOrScalar(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- isVectorPrimitive() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
-
- isVectorPrimitive() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeNary.NaryType
-
- isVectorPrimitive() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeTernary.TernaryType
-
- isVectorScalarPrimitive() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
-
- isVectorScalarPrimitive() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
-
- isVectorVectorPrimitive() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
-
- isVisited() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- isVisited() - Method in class org.apache.sysds.hops.Hop
-
- isVisited() - Method in class org.apache.sysds.runtime.lineage.LineageItem
-
- isWeighted() - Method in enum org.apache.sysds.lops.MapMultChain.ChainType
-
- isWrite() - Method in enum org.apache.sysds.common.Types.OpOpData
-
- isWrite() - Method in class org.apache.sysds.hops.DataOp
-
- isZero(double[]) - Static method in class org.apache.sysds.runtime.compress.utils.DblArray
-
- isZero(DblArray) - Static method in class org.apache.sysds.runtime.compress.utils.DblArray
-
- iterablePredicate() - Method in class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
-
- iterablePredicate() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- iterablePredicate() - Method in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
-
- IterablePredicate - Class in org.apache.sysds.parser
-
- IterablePredicate(ParserRuleContext, DataIdentifier, Expression, Expression, Expression, HashMap<String, String>, String) - Constructor for class org.apache.sysds.parser.IterablePredicate
-
- IterablePredicateColonExpressionContext(DmlParser.IterablePredicateContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.IterablePredicateColonExpressionContext
-
- IterablePredicateContext(ParserRuleContext, int) - Constructor for class org.apache.sysds.parser.dml.DmlParser.IterablePredicateContext
-
- IterablePredicateContext() - Constructor for class org.apache.sysds.parser.dml.DmlParser.IterablePredicateContext
-
- IterablePredicateSeqExpressionContext(DmlParser.IterablePredicateContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.IterablePredicateSeqExpressionContext
-
- iterator() - Method in class org.apache.sysds.runtime.instructions.spark.data.LazyIterableIterator
-
- iterPred - Variable in class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
-
- iterPred - Variable in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
-
- iterVar - Variable in class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
-
- iterVar - Variable in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
-
- m2 - Variable in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
- m3 - Variable in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
- m4 - Variable in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
- main(String[]) - Static method in class org.apache.sysds.api.DMLScript
-
Main entry point for systemDS dml script execution
- main(String[]) - Static method in class org.apache.sysds.api.PythonDMLScript
-
Entry point for Python API.
- main(String[]) - Static method in class org.apache.sysds.utils.InstallDependencyForIntegrationTests
-
- maintainCPFuncCallStats(String) - Static method in class org.apache.sysds.utils.Statistics
-
- maintainCPHeavyHitters(String, long) - Static method in class org.apache.sysds.utils.Statistics
-
"Maintains" or adds time to per instruction/op timers, also increments associated count
- maintainCPHeavyHittersMem(String, double) - Static method in class org.apache.sysds.utils.Statistics
-
Helper method which keeps track of the heaviest weight objects (by total memory used)
throughout execution of the program.
- malloc(String, long) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryManager
-
Allocate pointer of the given size in bytes.
- map(String) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- map(FrameBlock.FrameMapFunction) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- MapInputSignature - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- MapInputSignature() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.MapInputSignature
-
- MapJoinSignature - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- MapJoinSignature() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.MapJoinSignature
-
- MapJoinSignature1() - Constructor for class org.apache.sysds.runtime.instructions.spark.CtableSPInstruction.MapJoinSignature1
-
- MapJoinSignature2() - Constructor for class org.apache.sysds.runtime.instructions.spark.CtableSPInstruction.MapJoinSignature2
-
- MapJoinSignature3() - Constructor for class org.apache.sysds.runtime.instructions.spark.CtableSPInstruction.MapJoinSignature3
-
- MapmmChainSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- MapmmSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- MapMult - Class in org.apache.sysds.lops
-
- MapMult(Lop, Lop, Types.DataType, Types.ValueType, boolean, boolean, boolean, AggBinaryOp.SparkAggType) - Constructor for class org.apache.sysds.lops.MapMult
-
Constructor to setup a partial Matrix-Vector Multiplication for Spark
- MapMult.CacheType - Enum in org.apache.sysds.lops
-
- MAPMULT_MEM_MULTIPLIER - Static variable in class org.apache.sysds.hops.AggBinaryOp
-
- MapMultChain - Class in org.apache.sysds.lops
-
- MapMultChain(Lop, Lop, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.MapMultChain
-
Constructor to setup a map mult chain without weights
- MapMultChain(Lop, Lop, Lop, MapMultChain.ChainType, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.MapMultChain
-
Constructor to setup a map mult chain with weights
- MapMultChain.ChainType - Enum in org.apache.sysds.lops
-
- mapParallel(long, BiFunction<FederatedRange, FederatedData, Void>) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
Execute a function for each FederatedRange
+ FederatedData
pair mapping the pairs to
their new form by directly changing both FederatedRange
and FederatedData
.
- MarkForLineageReuse - Class in org.apache.sysds.hops.rewrite
-
- MarkForLineageReuse() - Constructor for class org.apache.sysds.hops.rewrite.MarkForLineageReuse
-
- matMult(EstimatorBitsetMM.BitsetMatrix) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix
-
- matmult(ExecutionContext, GPUContext, String, MatrixObject, MatrixObject, String, boolean, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuMatMult
-
Matrix multiply on GPU Examines sparsity and shapes and routes call to
appropriate method from cuBLAS or cuSparse C = op(A) x op(B)
The user is expected to call
ec.releaseMatrixOutputForGPUInstruction(outputName);
- matMult(MatrixIndexes, MatrixBlock, MatrixIndexes, MatrixBlock, MatrixIndexes, MatrixBlock, AggregateBinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- matMult(MatrixBlock, MatrixBlock, MatrixBlock, AggregateBinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- MatMultCP - Class in org.apache.sysds.lops
-
- MatMultCP(Lop, Lop, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.MatMultCP
-
- MatMultCP(Lop, Lop, Types.DataType, Types.ValueType, LopProperties.ExecType, int) - Constructor for class org.apache.sysds.lops.MatMultCP
-
- MatMultCP(Lop, Lop, Types.DataType, Types.ValueType, LopProperties.ExecType, boolean, boolean) - Constructor for class org.apache.sysds.lops.MatMultCP
-
- matmultTSMM(ExecutionContext, GPUContext, String, MatrixObject, String, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs tsmm, A %*% A' or A' %*% A, on GPU by exploiting cublasDsyrk(...)
- Matrix - Class in org.apache.sysds.api.mlcontext
-
Matrix encapsulates a SystemDS matrix.
- Matrix(MatrixObject, SparkExecutionContext) - Constructor for class org.apache.sysds.api.mlcontext.Matrix
-
- Matrix(Dataset<Row>, MatrixMetadata) - Constructor for class org.apache.sysds.api.mlcontext.Matrix
-
Convert a Spark DataFrame to a SystemDS binary-block representation.
- Matrix(Dataset<Row>, long, long) - Constructor for class org.apache.sysds.api.mlcontext.Matrix
-
Convert a Spark DataFrame to a SystemDS binary-block representation,
specifying the number of rows and columns.
- Matrix(JavaPairRDD<MatrixIndexes, MatrixBlock>, MatrixMetadata) - Constructor for class org.apache.sysds.api.mlcontext.Matrix
-
Create a Matrix, specifying the SystemDS binary-block matrix and its
metadata.
- Matrix(Dataset<Row>) - Constructor for class org.apache.sysds.api.mlcontext.Matrix
-
Convert a Spark DataFrame to a SystemDS binary-block representation.
- MATRIX_DATA_TYPE - Static variable in class org.apache.sysds.parser.Statement
-
- MATRIX_VAR_NAME_PREFIX - Static variable in class org.apache.sysds.lops.Lop
-
- MatrixAppendCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- MatrixAppendGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
Implements the cbind and rbind functions for matrices
- MatrixAppendMSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- MatrixAppendRSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- MatrixBlock - Class in org.apache.sysds.runtime.matrix.data
-
- MatrixBlock() - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- MatrixBlock(int, int, boolean) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- MatrixBlock(int, int, long) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- MatrixBlock(int, int, boolean, long) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- MatrixBlock(MatrixBlock) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- MatrixBlock(double) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- MatrixBlock(int, int, double) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- MatrixBlock(int, int, long, SparseBlock) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- MatrixBlock(MatrixBlock, SparseBlock.Type, boolean) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- MatrixBlock(int, int, DenseBlock) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- MatrixBlock.SparsityEstimate - Class in org.apache.sysds.runtime.matrix.data
-
- MatrixBlockDataInput - Interface in org.apache.sysds.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.sysds.runtime.matrix.data
-
Any data output that is intended to support fast serialization / write
of entire blocks should implement this interface.
- MatrixBlockDeserializer() - Constructor for class org.apache.sysds.runtime.io.BinaryBlockSerialization.MatrixBlockDeserializer
-
- MatrixBlockSerializer() - Constructor for class org.apache.sysds.runtime.io.BinaryBlockSerialization.MatrixBlockSerializer
-
- matrixBlockToBinaryBlock(JavaSparkContext, JavaPairRDD<MatrixIndexes, MatrixBlock>, DataCharacteristics) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- matrixBlockToBinaryBlockLongIndex(JavaSparkContext, JavaPairRDD<MatrixIndexes, MatrixBlock>, DataCharacteristics) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- matrixBlockToMatrixObject(String, MatrixBlock, MatrixMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixBlock
to a MatrixObject
.
- MatrixBuiltinGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
- MatrixBuiltinNaryCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- MatrixCell - Class in org.apache.sysds.runtime.matrix.data
-
- MatrixCell() - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- MatrixCell(MatrixCell) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- MatrixCell(MatrixValue) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- MatrixCell(double) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- MatrixCharacteristics - Class in org.apache.sysds.runtime.meta
-
- MatrixCharacteristics() - Constructor for class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- MatrixCharacteristics(long, long) - Constructor for class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- MatrixCharacteristics(long, long, long) - Constructor for class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- MatrixCharacteristics(long, long, int) - Constructor for class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- MatrixCharacteristics(long, long, int, long) - Constructor for class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- MatrixCharacteristics(DataCharacteristics) - Constructor for class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- MatrixDataTypeCheckContext(DmlParser.DataTypeContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.MatrixDataTypeCheckContext
-
- matrixDescriptor - Static variable in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
- MatrixFormat - Enum in org.apache.sysds.api.mlcontext
-
MatrixFormat represents the different matrix formats supported by the
MLContext API.
- MatrixHistogram(MatrixBlock, boolean) - Constructor for class org.apache.sysds.hops.estim.EstimatorMatrixHistogram.MatrixHistogram
-
- MatrixHistogram(int[], int[], int[], int[], int, int) - Constructor for class org.apache.sysds.hops.estim.EstimatorMatrixHistogram.MatrixHistogram
-
- MatrixIndexes - Class in org.apache.sysds.runtime.matrix.data
-
This represent the indexes to the blocks of the matrix.
- MatrixIndexes() - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixIndexes
-
- MatrixIndexes(long, long) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixIndexes
-
- MatrixIndexes(MatrixIndexes) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixIndexes
-
- MatrixIndexingCPFileInstruction - Class in org.apache.sysds.runtime.instructions.cpfile
-
This instruction is used if a single partition is too large to fit in memory.
- MatrixIndexingCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- MatrixIndexingCPInstruction(CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysds.runtime.instructions.cp.MatrixIndexingCPInstruction
-
- MatrixIndexingGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
- MatrixIndexingSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
This class implements the matrix indexing functionality inside CP.
- MatrixMarketInputOutputInfo - Static variable in class org.apache.sysds.runtime.io.InputOutputInfo
-
- matrixMatrixArithmetic(ExecutionContext, GPUContext, String, MatrixObject, MatrixObject, String, boolean, boolean, BinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs elementwise arithmetic operation specified by op of two input matrices in1 and in2
- MatrixMatrixArithmeticGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
- MatrixMatrixAxpyGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
- MatrixMatrixBinaryOpFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- MatrixMatrixBinaryOpFunction(BinaryOperator) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.MatrixMatrixBinaryOpFunction
-
- MatrixMatrixBuiltinGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
- matrixMatrixOperations(MatrixBlock, MatrixBlock, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibCommonsMath
-
- matrixMatrixRelational(ExecutionContext, GPUContext, String, MatrixObject, MatrixObject, String, BinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs elementwise operation relational specified by op of two input matrices in1 and in2
- MatrixMatrixRelationalBinaryGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
- MatrixMetadata - Class in org.apache.sysds.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.sysds.api.mlcontext.MatrixMetadata
-
- MatrixMetadata(MatrixFormat) - Constructor for class org.apache.sysds.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on matrix format.
- MatrixMetadata(MatrixFormat, Long, Long) - Constructor for class org.apache.sysds.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.sysds.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.sysds.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.sysds.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) - Constructor for class org.apache.sysds.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) - Constructor for class org.apache.sysds.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.sysds.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.sysds.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.sysds.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) - Constructor for class org.apache.sysds.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) - Constructor for class org.apache.sysds.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) - Constructor for class org.apache.sysds.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) - Constructor for class org.apache.sysds.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(DataCharacteristics) - Constructor for class org.apache.sysds.api.mlcontext.MatrixMetadata
-
Constructor to create a MatrixMetadata object based on a
DataCharacteristics object.
- MatrixMulExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.MatrixMulExpressionContext
-
- matrixMult(MatrixBlock, MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.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.sysds.runtime.matrix.data.LibMatrixMult
-
This method allows one to disabling exam sparsity.
- matrixMult(MatrixBlock, MatrixBlock, MatrixBlock, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- matrixMult(MatrixBlock, MatrixBlock, MatrixBlock, int, int, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- matrixMult(MatrixBlock, MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
Performs a multi-threaded matrix multiplication and stores the result in the output matrix.
- matrixMult(MatrixBlock, MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixNative
-
Performs matrix multiplication using native library if BLAS is available or else falls back to
Java BLAS.
- matrixMult(MatrixBlock, MatrixBlock, MatrixBlock, int, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixNative
-
- matrixMultChain(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, MapMultChain.ChainType) - Static method in class org.apache.sysds.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.sysds.runtime.matrix.data.LibMatrixMult
-
Performs a parallel matrix multiplication chain operation of type t(X)%*%(X%*%v) or t(X)%*%(w*(X%*%v)).
- matrixMultDenseDenseMM(DenseBlock, DenseBlock, DenseBlock, int, int, int, int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- MatrixMultiplicationPropagator - Class in org.apache.sysds.runtime.privacy.propagation
-
Used for propagating constraints in a matrix multiplication.
- MatrixMultiplicationPropagator() - Constructor for class org.apache.sysds.runtime.privacy.propagation.MatrixMultiplicationPropagator
-
Constructor for empty instance.
- MatrixMultiplicationPropagator(MatrixBlock, PrivacyConstraint, MatrixBlock, PrivacyConstraint) - Constructor for class org.apache.sysds.runtime.privacy.propagation.MatrixMultiplicationPropagator
-
Constructs the propagator and initializes the fields used for propagation.
- MatrixMultiplicationPropagatorNaive - Class in org.apache.sysds.runtime.privacy.propagation
-
MatrixMultiplicationPropagator that overrides generateFineGrainedConstraints
with a naive propagation of the fine-grained constraints.
- MatrixMultiplicationPropagatorNaive() - Constructor for class org.apache.sysds.runtime.privacy.propagation.MatrixMultiplicationPropagatorNaive
-
- MatrixMultiplicationPropagatorNaive(MatrixBlock, PrivacyConstraint, MatrixBlock, PrivacyConstraint) - Constructor for class org.apache.sysds.runtime.privacy.propagation.MatrixMultiplicationPropagatorNaive
-
- MatrixMultiplicationPropagatorPrivateFirst - Class in org.apache.sysds.runtime.privacy.propagation
-
MatrixMultiplicationPropagator that overrides generateFineGrainedConstraints by finding the private elements first
followed by propagating PrivateAggregation in case of non-aggregating operator types.
- MatrixMultiplicationPropagatorPrivateFirst() - Constructor for class org.apache.sysds.runtime.privacy.propagation.MatrixMultiplicationPropagatorPrivateFirst
-
- MatrixMultiplicationPropagatorPrivateFirst(MatrixBlock, PrivacyConstraint, MatrixBlock, PrivacyConstraint) - Constructor for class org.apache.sysds.runtime.privacy.propagation.MatrixMultiplicationPropagatorPrivateFirst
-
- MatrixMultiplicationPropagatorPrivateFirstOptimized - Class in org.apache.sysds.runtime.privacy.propagation
-
MatrixMultiplicationPropagator that overrides generateFineGrainedConstraints by finding the private elements first
while propagating PrivateAggregation in case of non-aggregating operator types.
- MatrixMultiplicationPropagatorPrivateFirstOptimized() - Constructor for class org.apache.sysds.runtime.privacy.propagation.MatrixMultiplicationPropagatorPrivateFirstOptimized
-
- matrixMultPermute(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- matrixMultPermute(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- matrixMultTransposeSelf(MatrixBlock, MatrixBlock, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- matrixMultTransposeSelf(MatrixBlock, MatrixBlock, boolean, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- matrixMultWCeMM(MatrixBlock, MatrixBlock, MatrixBlock, double, MatrixBlock, WeightedCrossEntropy.WCeMMType) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- matrixMultWCeMM(MatrixBlock, MatrixBlock, MatrixBlock, double, MatrixBlock, WeightedCrossEntropy.WCeMMType, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- matrixMultWDivMM(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, WeightedDivMM.WDivMMType) - Static method in class org.apache.sysds.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.sysds.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.sysds.runtime.matrix.data.LibMatrixMult
-
- matrixMultWSigmoid(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, WeightedSigmoid.WSigmoidType, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- matrixMultWSLoss(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, WeightedSquaredLoss.WeightsType) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- matrixMultWSLoss(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, WeightedSquaredLoss.WeightsType, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- matrixMultWuMM(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, WeightedUnaryMM.WUMMType, ValueFunction) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- matrixMultWuMM(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, WeightedUnaryMM.WUMMType, ValueFunction, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- MatrixObject - Class in org.apache.sysds.runtime.controlprogram.caching
-
Represents a matrix in control program.
- MatrixObject(Types.ValueType, String) - Constructor for class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
Constructor that takes the value type and the HDFS filename.
- MatrixObject(Types.ValueType, String, MetaData) - Constructor for class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
Constructor that takes the value type, HDFS filename and associated metadata.
- MatrixObject(MatrixObject) - Constructor for class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
Copy constructor that copies meta data but NO data.
- MatrixObject.UpdateType - Enum in org.apache.sysds.runtime.controlprogram.caching
-
- matrixObjectTo2DDoubleArray(MatrixObject) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a two-dimensional double array.
- matrixObjectToBinaryBlocks(MatrixObject, SparkExecutionContext) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a
JavaPairRDD<MatrixIndexes, MatrixBlock>
.
- matrixObjectToDataFrame(MatrixObject, SparkExecutionContext, boolean) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a DataFrame
.
- matrixObjectToJavaRDDStringCSV(MatrixObject) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a JavaRDD<String>
in CSV
format.
- matrixObjectToJavaRDDStringIJV(MatrixObject) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a JavaRDD<String>
in IJV
format.
- matrixObjectToListStringCSV(MatrixObject) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a List<String>
in CSV format.
- matrixObjectToListStringIJV(MatrixObject) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a List<String>
in IJV format.
- matrixObjectToRDDStringCSV(MatrixObject) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a RDD<String>
in CSV format.
- matrixObjectToRDDStringIJV(MatrixObject) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a MatrixObject
to a RDD<String>
in IJV format.
- MatrixReader - Class in org.apache.sysds.runtime.io
-
Base class for all format-specific matrix readers.
- MatrixReader() - Constructor for class org.apache.sysds.runtime.io.MatrixReader
-
- MatrixReaderFactory - Class in org.apache.sysds.runtime.io
-
- MatrixReaderFactory() - Constructor for class org.apache.sysds.runtime.io.MatrixReaderFactory
-
- MatrixReshapeGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
- MatrixReshapeSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- matrixScalarArithmetic(ExecutionContext, GPUContext, String, MatrixObject, String, boolean, ScalarOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Entry point to perform elementwise matrix-scalar arithmetic operation specified by op
- matrixScalarOp(ExecutionContext, GPUContext, String, MatrixObject, String, boolean, ScalarOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Utility to do matrix-scalar operation kernel
- matrixScalarRelational(ExecutionContext, GPUContext, String, MatrixObject, String, ScalarOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Entry point to perform elementwise matrix-scalar relational operation specified by op
- MatrixScalarUnaryFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- MatrixScalarUnaryFunction(ScalarOperator) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.MatrixScalarUnaryFunction
-
- MatrixValue - Class in org.apache.sysds.runtime.matrix.data
-
- MatrixValue() - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- MatrixValue(MatrixValue) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- MatrixValue.CellIndex - Class in org.apache.sysds.runtime.matrix.data
-
- MatrixVectorBinaryOpPartitionFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- MatrixVectorBinaryOpPartitionFunction(BinaryOperator, PartitionedBroadcast<MatrixBlock>, BinaryM.VectorType) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.MatrixVectorBinaryOpPartitionFunction
-
- MatrixWriter - Class in org.apache.sysds.runtime.io
-
Base class for all format-specific matrix writers.
- MatrixWriter() - Constructor for class org.apache.sysds.runtime.io.MatrixWriter
-
- MatrixWriterFactory - Class in org.apache.sysds.runtime.io
-
- MatrixWriterFactory() - Constructor for class org.apache.sysds.runtime.io.MatrixWriterFactory
-
- max(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
- max() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Wrapper method for reduceall-max of a matrix.
- max(byte[]) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- MAX_NNZ_CP_SPARSE - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
- MAX_NUMCELLS_CP_DENSE - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
- MAX_PREFIX - Static variable in class org.apache.sysds.runtime.transform.encode.EncoderBin
-
- MAX_REPLICATION_FACTOR_EXPORT - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerRuleBased
-
- MAX_REPLICATION_FACTOR_PARTITIONING - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerRuleBased
-
- MAX_RETRYS_ON_ERROR - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- MAX_SHALLOW_SERIALIZE_OVERHEAD - Static variable in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- MAX_SIZE - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.LocalTaskQueue
-
- MAX_SOLVE_CACHE_SIZE - Static variable in class org.apache.sysds.runtime.compress.estim.sample.HassAndStokes
-
- MAX_TASK_SIZE - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.Task
-
- MAX_VARNAME_SIZE - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.Task
-
- maxStaticColGroupCoCode - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
-
The maximum number of columns CoCoded if the Static CoCoding strategy is selected
- mdat - Variable in class org.apache.sysds.runtime.codegen.SpoofOperator.SideInput
-
- Mean - Class in org.apache.sysds.runtime.functionobjects
-
- mean - Variable in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
- mean() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Wrapper method for reduceall-mean of a matrix.
- mean_v - Variable in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
- median() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- MEM_UTIL_FACTOR - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Utilization factor used in deciding whether an operation to be scheduled on CP or MR.
- memoizeStatistics(long, long, long, long) - Method in class org.apache.sysds.hops.MemoTable
-
- memoizeStatistics(long, DataCharacteristics) - Method in class org.apache.sysds.hops.MemoTable
-
- memoryEstimate() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfo
-
Method for returning the calculated memory usage from this specific compression plan.
- MemoryEstimates - Class in org.apache.sysds.utils
-
Memory Estimates is a helper class containing static classes that estimate the memory requirements of different types
of objects in java.
- MemoryEstimates() - Constructor for class org.apache.sysds.utils.MemoryEstimates
-
- MemoTable - Class in org.apache.sysds.hops
-
Memoization Table (hop id, worst-case matrix characteristics).
- MemoTable() - Constructor for class org.apache.sysds.hops.MemoTable
-
- MemoTableEntry(TemplateBase.TemplateType, long, long, long, int) - Constructor for class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- MemoTableEntry(TemplateBase.TemplateType, long, long, long, int, TemplateBase.CloseType) - Constructor for class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- MemoTableEntrySet(Hop, Hop, TemplateBase) - Constructor for class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntrySet
-
- memStats - Variable in class org.apache.sysds.api.DMLOptions
-
- merge(Hop, Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateBase
-
Indicates if the template at the current hop can be expanded
by merging another template available for one of its other inputs
which is not yet covered by the template of the current hop.
- merge(Hop, Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateCell
-
- merge(Hop, Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateMultiAgg
-
- merge(Hop, Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateOuterProduct
-
- merge(Hop, Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateRow
-
- merge(CacheBlock, boolean) - Method in interface org.apache.sysds.runtime.controlprogram.caching.CacheBlock
-
Merge the given block into the current block.
- merge(CacheBlock, boolean) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- merge(CacheBlock, boolean) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- merge(FrameBlock) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- merge(CacheBlock, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- merge(MatrixBlock, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Merge disjoint: merges all non-zero values of the given input into the current
matrix block.
- merge(MatrixBlock, boolean, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- merge(MatrixBlock, boolean, boolean, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- mergeable() - Method in class org.apache.sysds.parser.StatementBlock
-
- mergeAt(Encoder, int, int) - Method in class org.apache.sysds.runtime.transform.encode.Encoder
-
Merges another encoder, of a compatible type, in after a certain position.
- mergeAt(Encoder, int, int) - Method in class org.apache.sysds.runtime.transform.encode.EncoderBin
-
- mergeAt(Encoder, int, int) - Method in class org.apache.sysds.runtime.transform.encode.EncoderComposite
-
- mergeAt(Encoder, int, int) - Method in class org.apache.sysds.runtime.transform.encode.EncoderDummycode
-
- mergeAt(Encoder, int, int) - Method in class org.apache.sysds.runtime.transform.encode.EncoderFeatureHash
-
- mergeAt(Encoder, int, int) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
-
- mergeAt(Encoder, int, int) - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
-
- mergeAt(Encoder, int, int) - Method in class org.apache.sysds.runtime.transform.encode.EncoderPassThrough
-
- mergeAt(Encoder, int, int) - Method in class org.apache.sysds.runtime.transform.encode.EncoderRecode
-
- mergeBinary(PrivacyConstraint, PrivacyConstraint) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
- mergeByKey(JavaPairRDD<Long, FrameBlock>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDAggregateUtils
-
- mergeByKey(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
Merges disjoint data of all blocks per key.
- mergeByKey(JavaPairRDD<MatrixIndexes, MatrixBlock>, boolean) - Static method in class org.apache.sysds.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.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
Merges disjoint data of all blocks per key.
- mergeExplainDedupBlocks(ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageDedupUtils
-
- mergeFunctionCalls(List<StatementBlock>, DMLProgram) - Static method in class org.apache.sysds.parser.StatementBlock
-
- mergeIntoSingleFile(String, String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- mergeNary(PrivacyConstraint[], OperatorType) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
- mergeNary(PrivacyConstraint[]) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
- mergeRowsByKey(JavaPairRDD<MatrixIndexes, RowMatrixBlock>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
Merges disjoint data of all blocks per key.
- mergeSchema(FrameBlock, FrameBlock) - Static method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- mergeSchemas(FrameObject) - Method in class org.apache.sysds.runtime.controlprogram.caching.FrameObject
-
Creates a new collection which contains the schema of the current
frame object concatenated with the schema of the passed frame object.
- mergeStatementBlocks() - Method in class org.apache.sysds.parser.DMLProgram
-
- mergeStatementBlocks() - Method in class org.apache.sysds.parser.ForStatement
-
- mergeStatementBlocks() - Method in class org.apache.sysds.parser.FunctionStatement
-
- mergeStatementBlocks(List<StatementBlock>) - Static method in class org.apache.sysds.parser.StatementBlock
-
- mergeStatementBlocks() - Method in class org.apache.sysds.parser.WhileStatement
-
- mergeStatementBlocksElseBody() - Method in class org.apache.sysds.parser.IfStatement
-
- mergeStatementBlocksIfBody() - Method in class org.apache.sysds.parser.IfStatement
-
- mergeTextcellToMatrixMarket(String, String, long, long, long) - Static method in class org.apache.sysds.runtime.io.WriterMatrixMarket
-
- MergeWithShiftedBlocks(DataCharacteristics, DataCharacteristics, boolean) - Constructor for class org.apache.sysds.runtime.instructions.spark.AppendGSPInstruction.MergeWithShiftedBlocks
-
- Metadata - Class in org.apache.sysds.api.mlcontext
-
Abstract metadata class for MLContext API.
- Metadata() - Constructor for class org.apache.sysds.api.mlcontext.Metadata
-
- metadata - Variable in class org.apache.sysds.runtime.io.InputOutputInfo
-
- MetaData - Class in org.apache.sysds.runtime.meta
-
Class to store metadata associated with a file (e.g., a matrix) on disk.
- MetaData(DataCharacteristics) - Constructor for class org.apache.sysds.runtime.meta.MetaData
-
- MetaDataFormat - Class in org.apache.sysds.runtime.meta
-
- MetaDataFormat(DataCharacteristics, Types.FileFormat) - Constructor for class org.apache.sysds.runtime.meta.MetaDataFormat
-
- metaDataToString(Types.ValueType, Types.ValueType[], Types.DataType, DataCharacteristics, Types.FileFormat, FileFormatProperties, PrivacyConstraint) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- mightHaveEmptyBlocks() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- mightHaveEmptyBlocks() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- min() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Wrapper method for reduceall-min of a matrix.
- MIN_PAR_THRESHOLD - Static variable in class org.apache.sysds.hops.estim.SparsityEstimator
-
- MIN_PREFIX - Static variable in class org.apache.sysds.runtime.transform.encode.EncoderBin
-
- MIN_SPILL_DATA - Static variable in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- MIN_SPILL_TIME_ESTIMATE - Static variable in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- minimumRecommendedSparkVersion() - Method in class org.apache.sysds.api.mlcontext.ProjectInfo
-
Obtain the minimum recommended Spark version from the manifest.
- minimumSize - Static variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCountDistinct
-
The minimum number NonZero of cells in the input before using approximate techniques for counting number of
distinct values.
- minNonZero() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Utility function for computing the min non-zero value.
- minus(VariableSet, VariableSet) - Static method in class org.apache.sysds.parser.VariableSet
-
- Minus - Class in org.apache.sysds.runtime.functionobjects
-
- Minus1Multiply - Class in org.apache.sysds.runtime.functionobjects
-
- MinusMultiply - Class in org.apache.sysds.runtime.functionobjects
-
- MinusNz - Class in org.apache.sysds.runtime.functionobjects
-
- minValForMaxPoolOperations - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- MISC_TIMER_ABS_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ACOS_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ACTIVATION_FORWARD_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ALLOCATE - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ALLOCATE_DENSE_OUTPUT - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ALLOCATE_SPARSE_OUTPUT - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ASIN_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ATAN_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_BIAS_ADD_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CBIND_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CEIL_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_COLUMN_TO_ROW_MAJOR - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_COMPARE_AND_SET_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CONVOLUTION_BACKWARD_DATA_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CONVOLUTION_BACKWARD_FILTER_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CONVOLUTION_FORWARD_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_COS_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_COSH_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CUDA_FREE - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CUDA_SYNC - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CUDNN_CLEANUP - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CUDNN_INIT - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CUMULATIVE_SCAN_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_CUMULATIVE_SUMPROD_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DAXPY_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DAXPY_MV_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DENSE_DGEAM_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DENSE_DOT_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DENSE_IM2COL_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DENSE_MATRIX_DENSE_MATRIX_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DENSE_MATRIX_DENSE_VECTOR_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DENSE_REORG_KNPQ_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DENSE_TO_SPARSE - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DENSE_VECTOR_DENSE_MATRIX_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DEVICE_TO_DEVICE - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_DEVICE_TO_HOST - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_EVICT - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_EXP_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_FILL_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_FLOOR_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_HOST_TO_DEVICE - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_LOG_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_MATRIX_MATRIX_CELLWISE_OP_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_MATRIX_SCALAR_OP_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_MAXPOOLING_BACKWARD_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_MAXPOOLING_FORWARD_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_OBJECT_CLONE - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ORMQR - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_QR - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_QR_BUFFER - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_RBIND_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_REDUCE_ALL_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_REDUCE_COL_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_REDUCE_ROW_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_RELU_BACKWARD_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_RELU_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_REUSE - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_RIX_DENSE_OP - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_RIX_SPARSE_DENSE_OP_NNZ - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_RIX_SPARSE_DENSE_OP_ROWWISE - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ROUND_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_ROW_TO_COLUMN_MAJOR - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SET_ZERO - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SIGMOID_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SIGN_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SIN_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SINH_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SPARSE_ALLOCATE_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SPARSE_DGEAM_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SPARSE_IM2COL_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SPARSE_MATRIX_DENSE_MATRIX_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SPARSE_MATRIX_DENSE_VECTOR_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SPARSE_MATRIX_SPARSE_MATRIX_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SPARSE_TO_DENSE - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SQRT_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_SYRK_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_TAN_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_TANH_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_TRANSPOSE_LIB - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_TRSM - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- MISC_TIMER_UPPER_TO_LOWER_TRIANGLE_KERNEL - Static variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- miss(FrameBlock, double, double) - Static method in class org.apache.sysds.utils.DataAugmentation
-
This function modifies the given, preprocessed frame block to add missing values to some of the rows,
marking them with the label missing.
- ml_type() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- ml_type() - Method in class org.apache.sysds.parser.dml.DmlParser.TypedArgAssignContext
-
- ml_type() - Method in class org.apache.sysds.parser.dml.DmlParser.TypedArgNoAssignContext
-
- Ml_typeContext(ParserRuleContext, int) - Constructor for class org.apache.sysds.parser.dml.DmlParser.Ml_typeContext
-
- MLContext - Class in org.apache.sysds.api.mlcontext
-
The MLContext API offers programmatic access to SystemDS on Spark from
languages such as Scala, Java, and Python.
- MLContext(SparkSession) - Constructor for class org.apache.sysds.api.mlcontext.MLContext
-
Create an MLContext based on a SparkSession for interaction with SystemDS
on Spark.
- MLContext(SparkContext) - Constructor for class org.apache.sysds.api.mlcontext.MLContext
-
Create an MLContext based on a SparkContext for interaction with SystemDS
on Spark.
- MLContext(JavaSparkContext) - Constructor for class org.apache.sysds.api.mlcontext.MLContext
-
Create an MLContext based on a JavaSparkContext for interaction with
SystemDS on Spark.
- MLContext.ExecutionType - Enum in org.apache.sysds.api.mlcontext
-
The different types of execution environments supported by SystemDS.
- MLContext.ExplainLevel - Enum in org.apache.sysds.api.mlcontext
-
The different explain levels supported by SystemDS.
- MLContext.InternalProxy - Class in org.apache.sysds.api.mlcontext
-
Used internally by MLContextProxy.
- MLContextConversionUtil - Class in org.apache.sysds.api.mlcontext
-
Utility class containing methods to perform data conversions.
- MLContextConversionUtil() - Constructor for class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
- MLContextException - Exception in org.apache.sysds.api.mlcontext
-
Uncaught exception representing SystemDS exceptions that occur through the
MLContext API.
- MLContextException() - Constructor for exception org.apache.sysds.api.mlcontext.MLContextException
-
- MLContextException(String, Throwable) - Constructor for exception org.apache.sysds.api.mlcontext.MLContextException
-
- MLContextException(String) - Constructor for exception org.apache.sysds.api.mlcontext.MLContextException
-
- MLContextException(Throwable) - Constructor for exception org.apache.sysds.api.mlcontext.MLContextException
-
- MLContextException(String, boolean) - Constructor for exception org.apache.sysds.api.mlcontext.MLContextException
-
Generate an exception and optionally suppress the stacktrace.
- MLContextProxy - Class in org.apache.sysds.utils
-
The purpose of this proxy is to shield systemds 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.sysds.utils.MLContextProxy
-
- MLContextUtil - Class in org.apache.sysds.api.mlcontext
-
Utility class containing methods for working with the MLContext API.
- MLContextUtil() - Constructor for class org.apache.sysds.api.mlcontext.MLContextUtil
-
- MLResults - Class in org.apache.sysds.api.mlcontext
-
MLResults handles the results returned from executing a Script using the
MLContext API.
- MLResults() - Constructor for class org.apache.sysds.api.mlcontext.MLResults
-
- MLResults(LocalVariableMap) - Constructor for class org.apache.sysds.api.mlcontext.MLResults
-
- MLResults(Script) - Constructor for class org.apache.sysds.api.mlcontext.MLResults
-
- MMChainCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- MMChainFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
-
- MMChainFEDInstruction(CPOperand, CPOperand, CPOperand, CPOperand, MapMultChain.ChainType, int, String, String) - Constructor for class org.apache.sysds.runtime.instructions.fed.MMChainFEDInstruction
-
- MMCJ - Class in org.apache.sysds.lops
-
Lop to perform cross product operation
- MMCJ(Lop, Lop, Types.DataType, Types.ValueType, MMCJ.MMCJType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.MMCJ
-
Constructor to perform a cross product operation.
- MMCJ(Lop, Lop, Types.DataType, Types.ValueType, boolean, AggBinaryOp.SparkAggType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.MMCJ
-
- MMCJ.MMCJType - Enum in org.apache.sysds.lops
-
- MMNode - Class in org.apache.sysds.hops.estim
-
Helper class to represent matrix multiply operators in a DAG
along with references to its abstract data handles.
- MMNode(MatrixBlock) - Constructor for class org.apache.sysds.hops.estim.MMNode
-
- MMNode(MMNode, MMNode, SparsityEstimator.OpCode, long[]) - Constructor for class org.apache.sysds.hops.estim.MMNode
-
- MMNode(MMNode, MMNode, SparsityEstimator.OpCode) - Constructor for class org.apache.sysds.hops.estim.MMNode
-
- MMNode(MMNode, SparsityEstimator.OpCode) - Constructor for class org.apache.sysds.hops.estim.MMNode
-
- MMNode(MMNode, SparsityEstimator.OpCode, long[]) - Constructor for class org.apache.sysds.hops.estim.MMNode
-
- MMRJ - Class in org.apache.sysds.lops
-
Lop to perform cross product operation
- MMRJ(Lop, Lop, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.MMRJ
-
Constructor to perform a cross product operation.
- MMTSJ - Class in org.apache.sysds.lops
-
Lop to perform transpose-identity operation (t(X)%*%X or X%*%t(X)),
used to represent CP and MR instruction but in case of MR there is
an additional Aggregate at the reducers.
- MMTSJ(Lop, Types.DataType, Types.ValueType, LopProperties.ExecType, MMTSJ.MMTSJType) - Constructor for class org.apache.sysds.lops.MMTSJ
-
- MMTSJ(Lop, Types.DataType, Types.ValueType, LopProperties.ExecType, MMTSJ.MMTSJType, boolean) - Constructor for class org.apache.sysds.lops.MMTSJ
-
- MMTSJ(Lop, Types.DataType, Types.ValueType, LopProperties.ExecType, MMTSJ.MMTSJType, boolean, int) - Constructor for class org.apache.sysds.lops.MMTSJ
-
- MMTSJ.MMTSJType - Enum in org.apache.sysds.lops
-
- MMTSJCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- MMTSJGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
- MMZip - Class in org.apache.sysds.lops
-
Lop to perform zip matrix multiplication
- MMZip(Lop, Lop, Types.DataType, Types.ValueType, boolean, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.MMZip
-
- mod(double, double) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- modeNames - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- ModIntDivExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.ModIntDivExpressionContext
-
- Modulus - Class in org.apache.sysds.runtime.functionobjects
-
Integer modulus, where we adhere to the defined R semantics:
("%% indicates x mod y and %/% indicates integer division.
- moveData(String, String) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- moveFromDevice(String) - Method in class org.apache.sysds.runtime.instructions.gpu.context.ShadowBuffer
-
Move the data from GPU to shadow buffer
- moveToDevice() - Method in class org.apache.sysds.runtime.instructions.gpu.context.ShadowBuffer
-
Move the data from shadow buffer to GPU
- moveToHost() - Method in class org.apache.sysds.runtime.instructions.gpu.context.ShadowBuffer
-
Move the data from shadow buffer to Matrix object
- MR_FRAMEWORK_NAME - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
- MR_JOBTRACKER_ADDRESS - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
- multBias(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNN
-
- MultDivExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.MultDivExpressionContext
-
- MULTI_THREADED_BUILD - Static variable in class org.apache.sysds.hops.estim.SparsityEstimator
-
- MULTI_THREADED_ESTIM - Static variable in class org.apache.sysds.hops.estim.SparsityEstimator
-
- MultiAssignmentStatement - Class in org.apache.sysds.parser
-
- MultiAssignmentStatement(ArrayList<DataIdentifier>, Expression) - Constructor for class org.apache.sysds.parser.MultiAssignmentStatement
-
- MultiIdExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.MultiIdExpressionContext
-
- MULTILINE_BLOCK_COMMENT - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- MULTILINE_BLOCK_COMMENT - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- multipleReturns() - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- multipleReturns() - Method in class org.apache.sysds.parser.DataIdentifier
-
Method to specify if an expression returns multiple outputs.
- multipleReturns() - Method in class org.apache.sysds.parser.FunctionCallIdentifier
-
- multipleReturns() - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- multipleReturns() - Method in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- Multiply - Class in org.apache.sysds.runtime.functionobjects
-
- Multiply2 - Class in org.apache.sysds.runtime.functionobjects
-
- multiplyByMinusOne() - Method in class org.apache.sysds.parser.DoubleIdentifier
-
- multiplyByMinusOne() - Method in class org.apache.sysds.parser.IntIdentifier
-
- MultiReturnBuiltinCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- multiReturnOperations(MatrixBlock, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibCommonsMath
-
- MultiReturnParameterizedBuiltinCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- MultiReturnParameterizedBuiltinFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
-
- MultiReturnParameterizedBuiltinFEDInstruction.CreateFrameEncoder - Class in org.apache.sysds.runtime.instructions.fed
-
- MultiReturnParameterizedBuiltinFEDInstruction.ExecuteFrameEncoder - Class in org.apache.sysds.runtime.instructions.fed
-
- MultiReturnParameterizedBuiltinSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeBuild2Function - Class in org.apache.sysds.runtime.instructions.spark
-
- MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeBuildFunction - Class in org.apache.sysds.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.sysds.runtime.instructions.spark
-
- MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeGroupFunction - Class in org.apache.sysds.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.
- MultiThreadedHop - Class in org.apache.sysds.hops
-
Optional hop interface, to be implemented by multi-threaded hops.
- MultiThreadedHop() - Constructor for class org.apache.sysds.hops.MultiThreadedHop
-
- MultiThreadedHop(String, Types.DataType, Types.ValueType) - Constructor for class org.apache.sysds.hops.MultiThreadedHop
-
- P - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- pad_h - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- pad_w - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- PadBlocksFunction(DataCharacteristics) - Constructor for class org.apache.sysds.runtime.instructions.spark.BuiltinNarySPInstruction.PadBlocksFunction
-
- PageCache - Class in org.apache.sysds.runtime.controlprogram.caching
-
- PageCache() - Constructor for class org.apache.sysds.runtime.controlprogram.caching.PageCache
-
- Pair<K,V> - Class in org.apache.sysds.runtime.matrix.data
-
- Pair() - Constructor for class org.apache.sysds.runtime.matrix.data.Pair
-
- Pair(K, V) - Constructor for class org.apache.sysds.runtime.matrix.data.Pair
-
- PairWritableBlock - Class in org.apache.sysds.runtime.controlprogram.parfor.util
-
Custom writable for a pair of matrix indexes and matrix block
as required for binaryblock in remote data partitioning.
- PairWritableBlock() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.util.PairWritableBlock
-
- PairWritableBlock(MatrixIndexes, MatrixBlock) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.util.PairWritableBlock
-
- PairWritableCell - Class in org.apache.sysds.runtime.controlprogram.parfor.util
-
Custom writable for a pair of matrix indexes and matrix cell
as required for binarycell in remote data partitioning.
- PairWritableCell() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.util.PairWritableCell
-
- PAR - Static variable in class org.apache.sysds.parser.ParForStatementBlock
-
- PAR_FACTOR_INFRASTRUCTURE - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizationWrapper
-
- PAR_K_FACTOR - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerRuleBased
-
- PAR_K_MR_FACTOR - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerRuleBased
-
- PAR_NUMCELL_THRESHOLD - Static variable in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
- PAR_NUMCELL_THRESHOLD_SORT - Static variable in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
- PARALLEL_CP_READ_PARALLELISM_MULTIPLIER - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Specifies a multiplier computing the degree of parallelism of parallel
text read/write out of the available degree of parallelism.
- PARALLEL_CP_WRITE_PARALLELISM_MULTIPLIER - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
- ParameterBuilder - Class in org.apache.sysds.utils
-
Class to help setting variables in a script.
- ParameterBuilder() - Constructor for class org.apache.sysds.utils.ParameterBuilder
-
- ParameterExpression - Class in org.apache.sysds.parser
-
- ParameterExpression(String, Expression) - Constructor for class org.apache.sysds.parser.ParameterExpression
-
- ParameterizedBuiltin - Class in org.apache.sysds.lops
-
Defines a LOP for functions.
- ParameterizedBuiltin(HashMap<String, Lop>, Types.ParamBuiltinOp, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.ParameterizedBuiltin
-
- ParameterizedBuiltin(HashMap<String, Lop>, Types.ParamBuiltinOp, Types.DataType, Types.ValueType, LopProperties.ExecType, int) - Constructor for class org.apache.sysds.lops.ParameterizedBuiltin
-
- ParameterizedBuiltin(HashMap<String, Lop>, Types.ParamBuiltinOp, Types.DataType, Types.ValueType, LopProperties.ExecType, boolean) - Constructor for class org.apache.sysds.lops.ParameterizedBuiltin
-
- ParameterizedBuiltin - Class in org.apache.sysds.runtime.functionobjects
-
Function object for builtin function that takes a list of name=value parameters.
- ParameterizedBuiltin.ParameterizedBuiltinCode - Enum in org.apache.sysds.runtime.functionobjects
-
- ParameterizedBuiltin.ProbabilityDistributionCode - Enum in org.apache.sysds.runtime.functionobjects
-
- ParameterizedBuiltinCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- ParameterizedBuiltinFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
-
- ParameterizedBuiltinFEDInstruction.DecodeMatrix - Class in org.apache.sysds.runtime.instructions.fed
-
- ParameterizedBuiltinFunctionExpression - Class in org.apache.sysds.parser
-
- ParameterizedBuiltinFunctionExpression(ParserRuleContext, Builtins, LinkedHashMap<String, Expression>, String) - Constructor for class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- ParameterizedBuiltinFunctionExpression(Builtins, LinkedHashMap<String, Expression>, ParseInfo) - Constructor for class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- ParameterizedBuiltinOp - Class in org.apache.sysds.hops
-
Defines the HOP for calling an internal function (with custom parameters) from a DML script.
- ParameterizedBuiltinOp(String, Types.DataType, Types.ValueType, Types.ParamBuiltinOp, LinkedHashMap<String, Hop>) - Constructor for class org.apache.sysds.hops.ParameterizedBuiltinOp
-
Creates a new HOP for a function call
- ParameterizedBuiltinSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- ParameterizedBuiltinSPInstruction.CreateMatrixCell - Class in org.apache.sysds.runtime.instructions.spark
-
- ParameterizedBuiltinSPInstruction.RDDMapGroupedAggFunction - Class in org.apache.sysds.runtime.instructions.spark
-
- ParameterizedBuiltinSPInstruction.RDDMapGroupedAggFunction2 - Class in org.apache.sysds.runtime.instructions.spark
-
Similar to RDDMapGroupedAggFunction but single output block.
- ParameterizedBuiltinSPInstruction.RDDRemoveEmptyFunction - Class in org.apache.sysds.runtime.instructions.spark
-
- ParameterizedBuiltinSPInstruction.RDDRemoveEmptyFunctionInMem - Class in org.apache.sysds.runtime.instructions.spark
-
- ParameterizedBuiltinSPInstruction.RDDReplaceFunction - Class in org.apache.sysds.runtime.instructions.spark
-
- ParameterizedBuiltinSPInstruction.RDDRExpandFunction - Class in org.apache.sysds.runtime.instructions.spark
-
- ParameterizedBuiltinSPInstruction.RDDTransformApplyFunction - Class in org.apache.sysds.runtime.instructions.spark
-
- ParameterizedBuiltinSPInstruction.RDDTransformApplyOffsetFunction - Class in org.apache.sysds.runtime.instructions.spark
-
- ParameterizedBuiltinSPInstruction.RDDTransformDecodeExpandFunction - Class in org.apache.sysds.runtime.instructions.spark
-
- ParameterizedBuiltinSPInstruction.RDDTransformDecodeFunction - Class in org.apache.sysds.runtime.instructions.spark
-
- parameterizedExpression - Variable in class org.apache.sysds.parser.dml.DmlParser.BuiltinFunctionExpressionContext
-
- parameterizedExpression() - Method in class org.apache.sysds.parser.dml.DmlParser.BuiltinFunctionExpressionContext
-
- parameterizedExpression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.BuiltinFunctionExpressionContext
-
- parameterizedExpression - Variable in class org.apache.sysds.parser.dml.DmlParser.FunctionCallAssignmentStatementContext
-
- parameterizedExpression() - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionCallAssignmentStatementContext
-
- parameterizedExpression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionCallAssignmentStatementContext
-
- parameterizedExpression - Variable in class org.apache.sysds.parser.dml.DmlParser.FunctionCallMultiAssignmentStatementContext
-
- parameterizedExpression() - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionCallMultiAssignmentStatementContext
-
- parameterizedExpression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionCallMultiAssignmentStatementContext
-
- parameterizedExpression() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- ParameterizedExpressionContext(ParserRuleContext, int) - Constructor for class org.apache.sysds.parser.dml.DmlParser.ParameterizedExpressionContext
-
- paramExpression - Variable in class org.apache.sysds.parser.dml.DmlSyntacticValidator.ConvertedDMLSyntax
-
- paramExprs - Variable in class org.apache.sysds.parser.dml.DmlParser.BuiltinFunctionExpressionContext
-
- paramExprs - Variable in class org.apache.sysds.parser.dml.DmlParser.FunctionCallAssignmentStatementContext
-
- paramExprs - Variable in class org.apache.sysds.parser.dml.DmlParser.FunctionCallMultiAssignmentStatementContext
-
- paramName - Variable in class org.apache.sysds.parser.dml.DmlParser.ParameterizedExpressionContext
-
- paramName - Variable in class org.apache.sysds.parser.dml.DmlParser.StrictParameterizedExpressionContext
-
- paramName - Variable in class org.apache.sysds.parser.dml.DmlParser.StrictParameterizedKeyValueStringContext
-
- paramName - Variable in class org.apache.sysds.parser.dml.DmlParser.TypedArgAssignContext
-
- paramName - Variable in class org.apache.sysds.parser.dml.DmlParser.TypedArgNoAssignContext
-
- ParamservBuiltinCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- ParamservBuiltinCPInstruction(Operator, LinkedHashMap<String, String>, CPOperand, String, String) - Constructor for class org.apache.sysds.runtime.instructions.cp.ParamservBuiltinCPInstruction
-
- ParamServer - Class in org.apache.sysds.runtime.controlprogram.paramserv
-
- ParamservUtils - Class in org.apache.sysds.runtime.controlprogram.paramserv
-
- ParamservUtils() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
- paramType - Variable in class org.apache.sysds.parser.dml.DmlParser.TypedArgAssignContext
-
- paramType - Variable in class org.apache.sysds.parser.dml.DmlParser.TypedArgNoAssignContext
-
- paramVal - Variable in class org.apache.sysds.parser.dml.DmlParser.ParameterizedExpressionContext
-
- paramVal - Variable in class org.apache.sysds.parser.dml.DmlParser.StrictParameterizedExpressionContext
-
- paramVal - Variable in class org.apache.sysds.parser.dml.DmlParser.StrictParameterizedKeyValueStringContext
-
- paramVal - Variable in class org.apache.sysds.parser.dml.DmlParser.TypedArgAssignContext
-
- PARFOR_COUNTER_GROUP_NAME - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- PARFOR_DATAPARTITIONS_FNAME - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- PARFOR_FNAME_PREFIX - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- PARFOR_MR_RESULT_TMP_FNAME - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- PARFOR_MR_RESULTMERGE_FNAME - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- PARFOR_MR_TASKS_TMP_FNAME - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- ParForBody - Class in org.apache.sysds.runtime.controlprogram.parfor
-
Wrapper for exchanging parfor body data structures.
- ParForBody() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.ParForBody
-
- ParForBody(ArrayList<ProgramBlock>, ArrayList<ParForStatementBlock.ResultVar>, ExecutionContext) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.ParForBody
-
- PARFORBODY_BEGIN - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- PARFORBODY_END - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- parForParams - Variable in class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
-
- parForParams - Variable in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
-
- ParForProgramBlock - Class in org.apache.sysds.runtime.controlprogram
-
The ParForProgramBlock has the same execution semantics as a ForProgamBlock but executes
the independent iterations in parallel.
- ParForProgramBlock(Program, String, HashMap<String, String>, ArrayList<ParForStatementBlock.ResultVar>) - Constructor for class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- ParForProgramBlock(int, Program, String, HashMap<String, String>, ArrayList<ParForStatementBlock.ResultVar>) - Constructor for class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
ParForProgramBlock constructor.
- ParForProgramBlock.PartitionFormat - Class in org.apache.sysds.runtime.controlprogram
-
Convenience class to package PDataPartitionFormat and its parameters.
- ParForProgramBlock.PDataPartitioner - Enum in org.apache.sysds.runtime.controlprogram
-
- ParForProgramBlock.PDataPartitionFormat - Enum in org.apache.sysds.runtime.controlprogram
-
- ParForProgramBlock.PExecMode - Enum in org.apache.sysds.runtime.controlprogram
-
- ParForProgramBlock.POptMode - Enum in org.apache.sysds.runtime.controlprogram
-
- ParForProgramBlock.PResultMerge - Enum in org.apache.sysds.runtime.controlprogram
-
- ParForProgramBlock.PTaskPartitioner - Enum in org.apache.sysds.runtime.controlprogram
-
- ParForStatement - Class in org.apache.sysds.parser
-
This ParForStatement is essentially identical to a ForStatement, except an extended
toString method for printing the 'parfor' keyword.
- ParForStatement() - Constructor for class org.apache.sysds.parser.ParForStatement
-
- ParForStatementBlock - Class in org.apache.sysds.parser
-
This ParForStatementBlock is essentially identical to a ForStatementBlock, except an extended validate
for checking/setting optional parfor parameters and running the loop dependency analysis.
- ParForStatementBlock() - Constructor for class org.apache.sysds.parser.ParForStatementBlock
-
- ParForStatementBlock.ResultVar - Class in org.apache.sysds.parser
-
- ParForStatementContext(DmlParser.StatementContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
-
- parse(String, String, Map<String, String>) - Method in class org.apache.sysds.parser.dml.DMLParserWrapper
-
Parses the passed file with command line parameters.
- parse(String, String, Map<String, String>) - Method in class org.apache.sysds.parser.ParserWrapper
-
- parse(String) - Static method in class org.apache.sysds.runtime.io.FileFormatPropertiesMM
-
- parse(Reader) - Static method in class org.apache.sysds.utils.JSONHelper
-
- parseAggregateOperator(String, String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- parseAggregateTernaryOperator(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- parseAggregateTernaryOperator(String, int) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- parseAndSetPrivacyConstraint(Data, JSONObject) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
- parseBasicAggregateUnaryOperator(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- parseBasicAggregateUnaryOperator(String, int) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- parseBasicCumulativeAggregateUnaryOperator(UnaryOperator) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- parseBinaryOperator(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- parseBinaryOrBuiltinOperator(String, CPOperand, CPOperand) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- parseBinningColIDs(String, String[], int, int) - Static method in class org.apache.sysds.runtime.transform.meta.TfMetaUtils
-
- parseBinningColIDs(JSONObject, String[], int, int) - Static method in class org.apache.sysds.runtime.transform.meta.TfMetaUtils
-
- parseCLArguments(String[]) - Static method in class org.apache.sysds.api.DMLOptions
-
Parses command line arguments to create a
DMLOptions
instance with the correct options
- parseCompactString(String) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.Task
-
- parseCumulativeAggregateUnaryOperator(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- parseDataObject(String) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
NOTE: MRJobConfiguration cannot be used for the general case because program blocks and
related symbol tables can be hierarchically structured.
- parseDMLConfig(String) - Static method in class org.apache.sysds.conf.DMLConfig
-
- ParseException - Exception in org.apache.sysds.parser
-
This exception is thrown when parse issues are encountered.
- ParseException() - Constructor for exception org.apache.sysds.parser.ParseException
-
- ParseException(String) - Constructor for exception org.apache.sysds.parser.ParseException
-
- ParseException(String, Exception) - Constructor for exception org.apache.sysds.parser.ParseException
-
- ParseException(List<CustomErrorListener.ParseIssue>, String) - Constructor for exception org.apache.sysds.parser.ParseException
-
This constructor takes a list of parse issues that were generated during
script parsing and the original DML/PyDML script String.
- parseExtendedBinaryOperator(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- parseExtendedBinaryOrBuiltinOperator(String, CPOperand, CPOperand) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- parseGroupedAggOperator(String, String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- ParseInfo - Interface in org.apache.sysds.parser
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.AggregateBinaryCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.AggregateTernaryCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.AggregateUnaryCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.AppendCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.BinaryCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.BuiltinNaryCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.CentralMomentCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.CompressionCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.CovarianceCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.CtableCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.DnnCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.FunctionCallCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.IndexingCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.MMChainCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.MMTSJCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.MultiReturnBuiltinCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.MultiReturnParameterizedBuiltinCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.ParameterizedBuiltinCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.PMMJCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.QuantilePickCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.QuantileSortCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.QuaternaryCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.ReorgCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.ReshapeCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.SpoofCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.SqlCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.StringInitCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.TernaryCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.UaggOuterChainCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.UnaryCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.cpfile.MatrixIndexingCPFileInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.AggregateBinaryFEDInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.AggregateUnaryFEDInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.AppendFEDInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.BinaryFEDInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.InitFEDInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.MMChainFEDInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.ParameterizedBuiltinFEDInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.ReorgFEDInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.TsmmFEDInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.gpu.AggregateBinaryGPUInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.gpu.AggregateUnaryGPUInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.gpu.ArithmeticBinaryGPUInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.gpu.BuiltinBinaryGPUInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.gpu.BuiltinUnaryGPUInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.gpu.DnnGPUInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.gpu.MatrixAppendGPUInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.gpu.MatrixIndexingGPUInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.gpu.MatrixMatrixAxpyGPUInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.gpu.MatrixReshapeGPUInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.gpu.MMTSJGPUInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.gpu.RelationalBinaryGPUInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.gpu.ReorgGPUInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.AggregateTernarySPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.AggregateUnarySPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.AppendGAlignedSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.AppendGSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.AppendMSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.AppendRSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.BinarySPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.BinUaggChainSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.BuiltinNarySPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.CastSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.CentralMomentSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.CheckpointSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.CompressionSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.CovarianceSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.CpmmSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.CSVReblockSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.CtableSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.CumulativeAggregateSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.CumulativeOffsetSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.DnnSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.IndexingSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.MapmmChainSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.MapmmSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.MatrixReshapeSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.PMapmmSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.PmmSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.QuantilePickSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.QuantileSortSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.QuaternarySPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.RandSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.ReblockSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.ReorgSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.RmmSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.SpoofSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.TernarySPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.Tsmm2SPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.TsmmSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.UaggOuterChainSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.UnaryFrameSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.UnaryMatrixSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.WriteSPInstruction
-
- parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.spark.ZipmmSPInstruction
-
- ParseIssue(int, int, String, String, CustomErrorListener.ParseIssueType) - Constructor for class org.apache.sysds.parser.dml.CustomErrorListener.ParseIssue
-
- parseJsonIDList(String, String[], String) - Static method in class org.apache.sysds.runtime.transform.meta.TfMetaUtils
-
- parseJsonIDList(JSONObject, String[], String) - Static method in class org.apache.sysds.runtime.transform.meta.TfMetaUtils
-
TODO consolidate external and internal json spec definitions
- parseJsonIDList(JSONObject, String[], String, int, int) - Static method in class org.apache.sysds.runtime.transform.meta.TfMetaUtils
-
- parseJsonObjectIDList(JSONObject, String[], String, int, int) - Static method in class org.apache.sysds.runtime.transform.meta.TfMetaUtils
-
- parseLineageTrace(String) - Static method in class org.apache.sysds.runtime.lineage.LineageParser
-
- parseLineageTrace(String, String) - Static method in class org.apache.sysds.runtime.lineage.LineageParser
-
- parseListString(String, int) - Static method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContextPool
-
Parses a string into a list.
- parseMemorySize(String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
Parses a memory size with optional g/m/k quantifiers into its
number representation.
- parseMixedInstructions(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionParser
-
- parseNComputeLineageTrace(String, String) - Static method in class org.apache.sysds.runtime.lineage.LineageRecomputeUtils
-
- parseParForBody(String, int) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- parseParForBody(String, int, boolean) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- parsePDataPartitionFormat(String) - Static method in enum org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PDataPartitionFormat
-
Note: Robust version of valueOf in order to return NONE without exception
if misspelled or non-existing and for case-insensitivity.
- parseProgram(String, int) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- parseRecodeMapEntry(String, Pair<String, String>) - Static method in class org.apache.sysds.runtime.transform.decode.DecoderRecode
-
Parses a line of <token, ID, count> into <token, ID> pairs, where
quoted tokens (potentially including separators) are supported.
- ParserFactory - Class in org.apache.sysds.parser
-
- ParserFactory() - Constructor for class org.apache.sysds.parser.ParserFactory
-
- ParserWrapper - Class in org.apache.sysds.parser
-
Base class for all dml parsers in order to make the various compilation chains
independent of the used parser.
- ParserWrapper() - Constructor for class org.apache.sysds.parser.ParserWrapper
-
- parseScalarBinaryOperator(String, boolean) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
scalar-matrix operator
- parseScalarBinaryOperator(String, boolean, double) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
scalar-matrix operator
- parseSingleInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.CPInstructionParser
-
- parseSingleInstruction(CPInstruction.CPType, String) - Static method in class org.apache.sysds.runtime.instructions.CPInstructionParser
-
- parseSingleInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.FEDInstructionParser
-
- parseSingleInstruction(FEDInstruction.FEDType, String) - Static method in class org.apache.sysds.runtime.instructions.FEDInstructionParser
-
- parseSingleInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.GPUInstructionParser
-
- parseSingleInstruction(GPUInstruction.GPUINSTRUCTION_TYPE, String) - Static method in class org.apache.sysds.runtime.instructions.GPUInstructionParser
-
- parseSingleInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionParser
-
- parseSingleInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.SPInstructionParser
-
- parseSingleInstruction(SPInstruction.SPType, String) - Static method in class org.apache.sysds.runtime.instructions.SPInstructionParser
-
- parseSparkPSBody(String, int) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- parseTernaryOperator(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- parseToDouble(String, Set<String>) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
Safe double parsing including handling of NAs.
- parseToInt(String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- parseToLong(String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- parseUnaryOperator(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- parseURL(String) - Static method in class org.apache.sysds.runtime.instructions.fed.InitFEDInstruction
-
- PartialAggregate - Class in org.apache.sysds.lops
-
Lop to perform a partial aggregation.
- PartialAggregate(Lop, Types.AggOp, Types.Direction, Types.DataType, Types.ValueType, LopProperties.ExecType, int) - Constructor for class org.apache.sysds.lops.PartialAggregate
-
- PartialAggregate(Lop, Types.AggOp, Types.Direction, Types.DataType, Types.ValueType, AggBinaryOp.SparkAggType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.PartialAggregate
-
- partition(int, MatrixBlock) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DCLocalScheme
-
- partition(int, MatrixBlock, List<MatrixBlock>) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.ORLocalScheme
-
- partitionColumns(List<Integer>, HashMap<Integer, PlanningCoCoder.GroupableColInfo>, CompressionSettings) - Method in class org.apache.sysds.runtime.compress.cocode.ColumnGroupPartitioner
-
Partitions a list of columns into a list of partitions that contains subsets of columns.
- partitionColumns(List<Integer>, HashMap<Integer, PlanningCoCoder.GroupableColInfo>, CompressionSettings) - Method in class org.apache.sysds.runtime.compress.cocode.ColumnGroupPartitionerBinPacking
-
- partitionColumns(List<Integer>, HashMap<Integer, PlanningCoCoder.GroupableColInfo>, CompressionSettings) - Method in class org.apache.sysds.runtime.compress.cocode.ColumnGroupPartitionerStatic
-
- PartitionedBlock<T extends CacheBlock> - Class in org.apache.sysds.runtime.instructions.spark.data
-
This class is for partitioned matrix/frame blocks, to be used as broadcasts.
- PartitionedBlock() - Constructor for class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- PartitionedBlock(T, int) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- PartitionedBlock(T, long[], int) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- PartitionedBlock(int, int, int) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- PartitionedBroadcast<T extends CacheBlock> - Class in org.apache.sysds.runtime.instructions.spark.data
-
This class is a wrapper around an array of broadcasts of partitioned matrix/frame blocks,
which is required due to 2GB limitations of Spark's broadcast handling.
- PartitionedBroadcast() - Constructor for class org.apache.sysds.runtime.instructions.spark.data.PartitionedBroadcast
-
- PartitionedBroadcast(Broadcast<PartitionedBlock<T>>[], DataCharacteristics) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.PartitionedBroadcast
-
- PartitionFormat(ParForProgramBlock.PDataPartitionFormat, int) - Constructor for class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
-
- ParWorker - Class in org.apache.sysds.runtime.controlprogram.parfor
-
Super class for master/worker pattern implementations.
- ParWorker() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.ParWorker
-
- ParWorker(long, ParForBody, boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.ParWorker
-
- path - Variable in class org.apache.sysds.runtime.io.ReadProperties
-
- pathExists(Long) - Method in class org.apache.sysds.runtime.lineage.LineageDedupBlock
-
- PathStatement - Class in org.apache.sysds.parser
-
- PathStatement(String) - Constructor for class org.apache.sysds.parser.PathStatement
-
- PathStatementContext(DmlParser.StatementContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.PathStatementContext
-
- pathValue - Variable in class org.apache.sysds.parser.dml.DmlParser.PathStatementContext
-
- PB_BEGIN - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- PB_EFC - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- PB_END - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- PB_FC - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- PB_FOR - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- PB_IF - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- PB_PARFOR - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- PB_WHILE - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- pbHopMap - Static variable in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- PBS_BEGIN - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- PBS_END - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- PERFORM_CONVERSION_ON_DEVICE - Static variable in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
-
- performAggregateUnary(MatrixIndexes, MatrixValue, MatrixIndexes, MatrixValue, AggregateUnaryOperator, int) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- performAppend(MatrixValue, MatrixValue, ArrayList<IndexedMatrixValue>, int, boolean, boolean, int) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- performBinaryIgnoreIndexes(MatrixValue, MatrixValue, MatrixValue, BinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- performConstantPropagation(HashMap<String, ConstIdentifier>) - Method in class org.apache.sysds.parser.ForStatementBlock
-
- performCtable(MatrixIndexes, MatrixValue, MatrixIndexes, MatrixValue, MatrixIndexes, MatrixValue, CTableMap, MatrixBlock, Operator) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- performCtable(MatrixIndexes, MatrixValue, MatrixIndexes, MatrixValue, double, CTableMap, MatrixBlock, Operator) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- performCtable(MatrixIndexes, MatrixValue, double, double, CTableMap, MatrixBlock, Operator) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- performCtable(MatrixIndexes, MatrixValue, double, boolean, int, CTableMap, MatrixBlock, Operator) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- performCtable(MatrixIndexes, MatrixValue, double, MatrixIndexes, MatrixValue, CTableMap, MatrixBlock, Operator) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- PerformGroupByAggInCombiner - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- PerformGroupByAggInCombiner(Operator) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.PerformGroupByAggInCombiner
-
- PerformGroupByAggInReducer - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- PerformGroupByAggInReducer(Operator) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.PerformGroupByAggInReducer
-
- performMapGroupedAggregate(Operator, IndexedMatrixValue, MatrixBlock, int, int, ArrayList<IndexedMatrixValue>) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- performReorg(MatrixIndexes, MatrixValue, MatrixIndexes, MatrixValue, ReorgOperator, int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- performShift(IndexedMatrixValue, IndexRange, int, long, long, ArrayList<IndexedMatrixValue>) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- performShift(Pair<Long, FrameBlock>, IndexRange, int, long, long, ArrayList<Pair<Long, FrameBlock>>) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- performSlice(IndexRange, int, int, int, CacheBlock) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- performSlice(IndexRange, int, int, int, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- performSlice(IndexedMatrixValue, IndexRange, int, ArrayList<IndexedMatrixValue>) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- performSlice(IndexRange, int, int, int, FrameBlock) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- performSlice(Pair<Long, FrameBlock>, IndexRange, int, ArrayList<Pair<Long, FrameBlock>>) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
This function will get slice of the input frame block overlapping in overall slice(Range), slice has requested for.
- performZeroOut(MatrixIndexes, MatrixValue, MatrixIndexes, MatrixValue, IndexRange, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- permutationMatrixMultOperations(MatrixValue, MatrixValue, MatrixValue) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- permutationMatrixMultOperations(MatrixValue, MatrixValue, MatrixValue, int) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- permutationMatrixMultOperations(MatrixValue, MatrixValue, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- permutationMatrixMultOperations(MatrixValue, MatrixValue, MatrixValue, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- pFeatures - Variable in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionLocalScheme.Result
-
- PickByCount - Class in org.apache.sysds.lops
-
- PickByCount(Lop, Lop, Types.DataType, Types.ValueType, PickByCount.OperationTypes, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.PickByCount
-
- PickByCount(Lop, Lop, Types.DataType, Types.ValueType, PickByCount.OperationTypes, LopProperties.ExecType, boolean) - Constructor for class org.apache.sysds.lops.PickByCount
-
- PickByCount.OperationTypes - Enum in org.apache.sysds.lops
-
- pickValue(double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- pickValue(double, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- pickValues(MatrixValue, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- pinVariables(List<String>) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
Pin a given list of variables i.e., set the "clean up" state in
corresponding matrix objects, so that the cached data inside these
objects is not cleared and the corresponding HDFS files are not
deleted (through rmvar instructions).
- pLabels - Variable in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionLocalScheme.Result
-
- PLAN_CACHE_POLICY - Static variable in class org.apache.sysds.hops.codegen.SpoofCompiler
-
- PLAN_CACHE_SIZE - Static variable in class org.apache.sysds.hops.codegen.SpoofCompiler
-
- PLAN_CACHING - Static variable in class org.apache.sysds.hops.codegen.opt.PlanSelectionFuseCostBasedV2
-
- PLAN_SEL_POLICY - Static variable in class org.apache.sysds.hops.codegen.SpoofCompiler
-
- PlanAnalyzer - Class in org.apache.sysds.hops.codegen.opt
-
Utility functions to extract structural information from the memo table,
including connected components (aka partitions) of partial fusion plans,
materialization points of partitions, and root nodes of partitions.
- PlanAnalyzer() - Constructor for class org.apache.sysds.hops.codegen.opt.PlanAnalyzer
-
- PlanningCoCoder - Class in org.apache.sysds.runtime.compress.cocode
-
- PlanningCoCoder() - Constructor for class org.apache.sysds.runtime.compress.cocode.PlanningCoCoder
-
- PlanningCoCoder.GroupableColInfo - Class in org.apache.sysds.runtime.compress.cocode
-
- PlanningCoCoder.PartitionerType - Enum in org.apache.sysds.runtime.compress.cocode
-
- PlanningCoCodingGroup - Class in org.apache.sysds.runtime.compress.cocode
-
Class to represent information about co-coding a group of columns.
- PlanningCoCodingGroup(int, PlanningCoCoder.GroupableColInfo) - Constructor for class org.apache.sysds.runtime.compress.cocode.PlanningCoCodingGroup
-
Constructor for a one-column group; i.e.
- PlanningCoCodingGroup(PlanningCoCodingGroup, PlanningCoCodingGroup, CompressedSizeEstimator, int) - Constructor for class org.apache.sysds.runtime.compress.cocode.PlanningCoCodingGroup
-
Constructor for merging two disjoint groups of columns
- PlanningCoCodingGroup.ColIndexes - Class in org.apache.sysds.runtime.compress.cocode
-
- PlanningMemoTable - Class in org.apache.sysds.runtime.compress.cocode
-
- PlanningMemoTable() - Constructor for class org.apache.sysds.runtime.compress.cocode.PlanningMemoTable
-
- PlanPartition - Class in org.apache.sysds.hops.codegen.opt
-
- PlanPartition(HashSet<Long>, HashSet<Long>, HashSet<Long>, HashSet<Long>, ArrayList<Long>, InterestingPoint[], boolean) - Constructor for class org.apache.sysds.hops.codegen.opt.PlanPartition
-
- plans - Variable in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntrySet
-
- PlanSelection - Class in org.apache.sysds.hops.codegen.opt
-
- PlanSelection() - Constructor for class org.apache.sysds.hops.codegen.opt.PlanSelection
-
- PlanSelection.VisitMarkCost - Class in org.apache.sysds.hops.codegen.opt
-
- PlanSelectionFuseAll - Class in org.apache.sysds.hops.codegen.opt
-
This plan selection heuristic aims for maximal fusion, which
potentially leads to overlapping fused operators and thus,
redundant computation but with a minimal number of materialized
intermediate results.
- PlanSelectionFuseAll() - Constructor for class org.apache.sysds.hops.codegen.opt.PlanSelectionFuseAll
-
- PlanSelectionFuseCostBased - Class in org.apache.sysds.hops.codegen.opt
-
This cost-based plan selection algorithm chooses fused operators
based on the DAG structure and resulting overall costs.
- PlanSelectionFuseCostBased() - Constructor for class org.apache.sysds.hops.codegen.opt.PlanSelectionFuseCostBased
-
- PlanSelectionFuseCostBasedV2 - Class in org.apache.sysds.hops.codegen.opt
-
This cost-based plan selection algorithm chooses fused operators
based on the DAG structure and resulting overall costs.
- PlanSelectionFuseCostBasedV2() - Constructor for class org.apache.sysds.hops.codegen.opt.PlanSelectionFuseCostBasedV2
-
- PlanSelectionFuseNoRedundancy - Class in org.apache.sysds.hops.codegen.opt
-
This plan selection heuristic aims for fusion without any redundant
computation, which, however, potentially leads to more materialized
intermediates than the fuse all heuristic.
- PlanSelectionFuseNoRedundancy() - Constructor for class org.apache.sysds.hops.codegen.opt.PlanSelectionFuseNoRedundancy
-
- Plus - Class in org.apache.sysds.runtime.functionobjects
-
- PlusMultiply - Class in org.apache.sysds.runtime.functionobjects
-
- PMapmmSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
This pmapmm matrix multiplication instruction is still experimental
not integrated in automatic operator selection yet.
- PMapMult - Class in org.apache.sysds.lops
-
- PMapMult(Lop, Lop, Types.DataType, Types.ValueType) - Constructor for class org.apache.sysds.lops.PMapMult
-
- PMMJ - Class in org.apache.sysds.lops
-
- PMMJ(Lop, Lop, Lop, Types.DataType, Types.ValueType, boolean, boolean, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.PMMJ
-
Constructor to setup a Permutation Matrix Multiplication
- PMMJ.CacheType - Enum in org.apache.sysds.lops
-
- PMMJCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- PmmSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- PoissonPRNGenerator - Class in org.apache.sysds.runtime.util
-
Class that can generate a stream of random numbers from Poisson
distribution with specified mean.
- PoissonPRNGenerator() - Constructor for class org.apache.sysds.runtime.util.PoissonPRNGenerator
-
- PoissonPRNGenerator(double) - Constructor for class org.apache.sysds.runtime.util.PoissonPRNGenerator
-
- pooling(GPUContext, String, MatrixObject, MatrixObject, int, int, int, int, int, int, int, int, int, int, int, int, int, LibMatrixDNN.PoolingType, double) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNN
-
performs maxpooling on GPU by exploiting cudnnPoolingForward(...)
- pooling(MatrixBlock, MatrixBlock, DnnParameters, LibMatrixDNN.PoolingType) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNN
-
- poolingBackward(GPUContext, String, MatrixObject, MatrixObject, MatrixObject, MatrixObject, int, int, int, int, int, int, int, int, int, int, int, int, int, LibMatrixDNN.PoolingType, double) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNN
-
Performs maxpoolingBackward on GPU by exploiting cudnnPoolingBackward(...)
This method computes the backpropogation errors for previous layer of maxpooling operation
- poolingBackward(MatrixBlock, MatrixBlock, MatrixBlock, DnnParameters, boolean, LibMatrixDNN.PoolingType) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNN
-
This method computes the backpropogation errors for previous layer of pooling operation
- poolingDenseStride1Pad0(LibMatrixDNN.PoolingType, double, double, double[], double[], int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNPooling
-
- poolingDesc - Variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNPoolingDescriptors
-
- pos(int) - Method in class org.apache.sysds.runtime.codegen.SpoofOperator.SideInput
-
- pos(int) - Method in class org.apache.sysds.runtime.codegen.SpoofOperator.SideInputSparseRow
-
- pos(int) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Get the position for a given row within
its associated block.
- pos(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Get the position for a given row and column
within the associated block.
- pos(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Get the position for a given cell
within the associated block.
- pos(int) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
-
- pos(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
-
- pos(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
-
- pos(int) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- pos(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- pos(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
-
- pos(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
-
- pos(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
-
- pos(int) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- pos(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- pos(int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Get the starting position of row r in the indexes/values arrays returned
by indexes(r) and values(r).
- pos(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- pos(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- pos(int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- posFIndexGT(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Get position of first column index greater than column c in row r.
- posFIndexGT(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- posFIndexGT(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- posFIndexGT(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- posFIndexGTE(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Get position of first column index greater than or equal column c
in row r.
- posFIndexGTE(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- posFIndexGTE(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- posFIndexGTE(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- posFIndexLTE(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Get position of first column index lower than or equal column c
in row r.
- posFIndexLTE(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- posFIndexLTE(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- posFIndexLTE(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- postProcessAfterCopying(MatrixBlock) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- postprocessInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.FunctionCallCPInstruction
-
- postprocessInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- postprocessInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.Instruction
-
This method should be used for any tear down after executing this instruction.
- postprocessInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.SPInstruction
-
- postProcessInstruction(Instruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
- postScaling(double[], double[], double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
-
- postScaling(double[], double[], double[], int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
-
- pow(int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- Power - Class in org.apache.sysds.runtime.functionobjects
-
- Power2 - Class in org.apache.sysds.runtime.functionobjects
-
- PowerExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.PowerExpressionContext
-
- PREAD_PREFIX - Static variable in class org.apache.sysds.lops.Data
-
- preAggregate(double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
-
- preAggregate(double[], int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
-
Pre aggregates a specific row from the input a which can be a row or a matrix.
- preallocateSparseOutput(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNIm2Col
-
- PRED_VAR - Static variable in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- predicate - Variable in class org.apache.sysds.parser.dml.DmlParser.IfStatementContext
-
- predicate - Variable in class org.apache.sysds.parser.dml.DmlParser.WhileStatementContext
-
- prepareBuildPartial() - Method in class org.apache.sysds.runtime.transform.encode.EncoderRecode
-
- prepareCopyInstruction(String, String) - Static method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- PreparedScript - Class in org.apache.sysds.api.jmlc
-
Representation of a prepared (precompiled) DML/PyDML script.
- prepareRemoveInstruction(long...) - Static method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- prepareRemoveInstruction(String...) - Static method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- prepareRowIndices(int, double[], BinaryOperator, AggregateUnaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixOuterAgg
-
- prepareRowIndicesMax(int, double[], BinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixOuterAgg
-
This function will return max indices, based on column vector data.
- prepareRowIndicesMin(int, double[], BinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixOuterAgg
-
This function will return min indices, based on column vector data.
- prepareScript(String, String[], String[]) - Method in class org.apache.sysds.api.jmlc.Connection
-
Prepares (precompiles) a script and registers input and output variables.
- prepareScript(String, Map<String, String>, String[], String[]) - Method in class org.apache.sysds.api.jmlc.Connection
-
Prepares (precompiles) a script, sets input parameter values, and registers input and output variables.
- prepareScript(String, Map<String, String>, Map<String, String>, String[], String[]) - Method in class org.apache.sysds.api.jmlc.Connection
-
Prepares (precompiles) a script, sets input parameter values, and registers input and output variables.
- prepCreatevarInstruction(String, String, boolean, String) - Static method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- prepCreatevarInstruction(String, String, boolean, Types.DataType, String, DataCharacteristics, MatrixObject.UpdateType) - Static method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- prepCreatevarInstruction(String, String, boolean, Types.DataType, String, DataCharacteristics, MatrixObject.UpdateType, boolean, String, boolean) - Static method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- prepInputOperand(int) - Method in class org.apache.sysds.lops.Lop
-
- prepInputOperand(String) - Method in class org.apache.sysds.lops.Lop
-
- prepMatrixMultTransposeSelfInput(MatrixBlock, boolean, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- prepMoveInstruction(String, String, String) - Static method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- prepMoveInstruction(String, String) - Static method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- prepOperand(String, Types.DataType, Types.ValueType) - Method in class org.apache.sysds.lops.Lop
-
Method to prepare instruction operand with given parameters.
- prepOperand(String, Types.DataType, Types.ValueType, boolean) - Method in class org.apache.sysds.lops.Lop
-
Method to prepare instruction operand with given parameters.
- prepOutputOperand() - Method in class org.apache.sysds.lops.Lop
-
- prepOutputOperand(int) - Method in class org.apache.sysds.lops.Lop
-
- prepOutputOperand(String) - Method in class org.apache.sysds.lops.Lop
-
- preprocessBinaryCPInstruction(BinaryCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
- preprocessBuiltinNary(BuiltinNaryCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
- preprocessCPInstructionFineGrained(CPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
- preprocessExternal(FunctionCallCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
- preprocessing(FrameBlock, List<Integer>, List<Integer>, List<Integer>) - Static method in class org.apache.sysds.utils.DataAugmentation
-
This function returns a new frame block with a labels column added, and build the lists
with column index of the different types of data.
- preprocessInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.CPInstruction
-
- preprocessInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.FunctionCallCPInstruction
-
- preprocessInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.FEDInstruction
-
- preprocessInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- preprocessInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.Instruction
-
This method should be used for any setup before executing this instruction.
- preprocessInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.SPInstruction
-
- preprocessInstruction(Instruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
- preprocessInstructionSimple(Instruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
Throw exception if privacy constraints are activated or return instruction if privacy is not activated
- preprocessMultiReturn(ComputationCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
- preprocessParameterizedBuiltin(ParameterizedBuiltinCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
- preprocessQuaternary(QuaternaryCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
- preprocessTernaryCPInstruction(ComputationCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
- preprocessUnaryCPInstruction(UnaryCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
- preprocessVariableCPInstruction(VariableCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
- prepScalarInputOperand(LopProperties.ExecType) - Method in class org.apache.sysds.lops.Lop
-
- prepScalarInputOperand(String) - Method in class org.apache.sysds.lops.Lop
-
- prepScalarLabel() - Method in class org.apache.sysds.lops.Lop
-
Function to prepare label for scalar inputs while generating instructions.
- prepScalarOperand(LopProperties.ExecType, String) - Method in class org.apache.sysds.lops.Lop
-
Function to be used in creating instructions for creating scalar
operands.
- PRINT_GPU_MEMORY_INFO - Static variable in class org.apache.sysds.api.DMLScript
-
- PRINT_GPU_MEMORY_INFO - Static variable in class org.apache.sysds.conf.DMLConfig
-
- printBlockErrorLocation() - Method in class org.apache.sysds.parser.StatementBlock
-
- printBlockErrorLocation() - Method in class org.apache.sysds.runtime.controlprogram.ForProgramBlock
-
- printBlockErrorLocation() - Method in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
-
- printBlockErrorLocation() - Method in class org.apache.sysds.runtime.controlprogram.IfProgramBlock
-
- printBlockErrorLocation() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- printBlockErrorLocation() - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- printBlockErrorLocation() - Method in class org.apache.sysds.runtime.controlprogram.WhileProgramBlock
-
- printErrorLocation() - Method in class org.apache.sysds.hops.Hop
-
- printErrorLocation() - Method in class org.apache.sysds.lops.Lop
-
- printErrorLocation() - Method in class org.apache.sysds.parser.Expression
-
- printErrorLocation() - Method in class org.apache.sysds.parser.Statement
-
- printErrorLocation() - Method in class org.apache.sysds.parser.StatementBlock
-
- printInfoLocation() - Method in class org.apache.sysds.parser.Expression
-
Return info message containing the filename, the beginning line position, and the beginning column position.
- printMe() - Method in class org.apache.sysds.runtime.instructions.cp.FunctionCallCPInstruction
-
- printMe() - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- printMemoryInfo(String) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
Print information of memory usage.
- printRScript(String) - Static method in class org.apache.sysds.utils.InstallDependencyForIntegrationTests
-
Prints out an R script.
- PrintStatement - Class in org.apache.sysds.parser
-
- PrintStatement(ParserRuleContext, String, String) - Constructor for class org.apache.sysds.parser.PrintStatement
-
- PrintStatement(ParserRuleContext, String, List<Expression>, String) - Constructor for class org.apache.sysds.parser.PrintStatement
-
- PrintStatement(PrintStatement.PRINTTYPE, List<Expression>) - Constructor for class org.apache.sysds.parser.PrintStatement
-
- PrintStatement.PRINTTYPE - Enum in org.apache.sysds.parser
-
The PRINTTYPE options are: PRINT, PRINTF, and STOP.
- printStatus(String) - Static method in class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
-
Print current status of buffer pool, including all entries.
- printWarningLocation() - Method in class org.apache.sysds.parser.Expression
-
- printWarningLocation() - Method in class org.apache.sysds.parser.Statement
-
- printWarningLocation() - Method in class org.apache.sysds.parser.StatementBlock
-
- PRIVACY - Static variable in class org.apache.sysds.parser.DataExpression
-
- PrivacyConstraint - Class in org.apache.sysds.runtime.privacy
-
PrivacyConstraint holds all privacy constraints for data in the system at
compile time and runtime.
- PrivacyConstraint() - Constructor for class org.apache.sysds.runtime.privacy.PrivacyConstraint
-
Basic Constructor with a fine-grained collection
based on a list implementation.
- PrivacyConstraint(FineGrainedPrivacy) - Constructor for class org.apache.sysds.runtime.privacy.PrivacyConstraint
-
Constructor with the option to choose between
different fine-grained collection implementations.
- PrivacyConstraint(PrivacyConstraint.PrivacyLevel) - Constructor for class org.apache.sysds.runtime.privacy.PrivacyConstraint
-
Constructor with default fine-grained collection implementation
where the entire data object is set to the given privacy level.
- PrivacyConstraint.PrivacyLevel - Enum in org.apache.sysds.runtime.privacy
-
- PrivacyMonitor - Class in org.apache.sysds.runtime.privacy
-
- PrivacyMonitor() - Constructor for class org.apache.sysds.runtime.privacy.PrivacyMonitor
-
- PrivacyPropagator - Class in org.apache.sysds.runtime.privacy.propagation
-
Class with static methods merging privacy constraints of operands
in expressions to generate the privacy constraints of the output.
- PrivacyPropagator() - Constructor for class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
-
- PrivacyUtils - Class in org.apache.sysds.runtime.privacy
-
- PrivacyUtils() - Constructor for class org.apache.sysds.runtime.privacy.PrivacyUtils
-
- PRNGenerator - Class in org.apache.sysds.runtime.util
-
- PRNGenerator() - Constructor for class org.apache.sysds.runtime.util.PRNGenerator
-
- PROB_SIZE_THRESHOLD_MB - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerRuleBased
-
- PROB_SIZE_THRESHOLD_PARTITIONING - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerRuleBased
-
- PROB_SIZE_THRESHOLD_REMOTE - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerRuleBased
-
- probe(LineageItem) - Static method in class org.apache.sysds.runtime.lineage.LineageCache
-
- PROCESS_PREFIX - Static variable in class org.apache.sysds.lops.Lop
-
- processBatchNorm2dBackwardInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.DnnCPInstruction
-
- processBatchNorm2dBackwardInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.DnnGPUInstruction
-
- processBatchNorm2dInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.DnnCPInstruction
-
- processBiasAddInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.DnnCPInstruction
-
- processBiasMultiplyInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.DnnCPInstruction
-
- processDedupItem(LineageMap, Long, LineageItem[], String) - Method in class org.apache.sysds.runtime.lineage.LineageMap
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.AggregateBinaryCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.AggregateTernaryCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.AggregateUnaryCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.BinaryFrameFrameCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.BinaryFrameMatrixCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.BinaryFrameScalarCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.BinaryMatrixMatrixCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.BinaryMatrixScalarCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.BinaryScalarScalarCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.BinaryTensorTensorCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.CentralMomentCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.CompressionCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.CovarianceCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.CPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.CtableCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.DnnCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.EvalNaryCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.FrameAppendCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.FrameIndexingCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.FunctionCallCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.ListAppendRemoveCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.ListIndexingCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.MatrixAppendCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.MatrixBuiltinNaryCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.MatrixIndexingCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.MMChainCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.MMTSJCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.MultiReturnBuiltinCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.MultiReturnParameterizedBuiltinCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.ParameterizedBuiltinCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.ParamservBuiltinCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.PMMJCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.QuantilePickCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.QuantileSortCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.QuaternaryCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.ReorgCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.ReshapeCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.ScalarAppendCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.ScalarBuiltinNaryCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.SpoofCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.SqlCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.StringInitCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.TernaryCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.UaggOuterChainCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.UnaryFrameCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.UnaryMatrixCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.UnaryScalarCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cpfile.MatrixIndexingCPFileInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.AggregateBinaryFEDInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.AggregateUnaryFEDInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.AppendFEDInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.BinaryMatrixMatrixFEDInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.BinaryMatrixScalarFEDInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.InitFEDInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.MMChainFEDInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.ParameterizedBuiltinFEDInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.ReorgFEDInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.TsmmFEDInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.AggregateBinaryGPUInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.AggregateUnaryGPUInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.DnnGPUInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.MatrixAppendGPUInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.MatrixBuiltinGPUInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.MatrixIndexingGPUInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.MatrixMatrixArithmeticGPUInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.MatrixMatrixAxpyGPUInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.MatrixMatrixBuiltinGPUInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.MatrixMatrixRelationalBinaryGPUInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.MatrixReshapeGPUInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.MMTSJGPUInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.ReorgGPUInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.ScalarMatrixArithmeticGPUInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.ScalarMatrixBuiltinGPUInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.ScalarMatrixRelationalBinaryGPUInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.Instruction
-
This method should be used to execute the instruction.
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.AggregateTernarySPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.AggregateUnarySPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.AppendGAlignedSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.AppendGSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.BinaryFrameFrameSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.BinaryFrameMatrixSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.BinaryFrameScalarSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.BinaryMatrixBVectorSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.BinaryMatrixMatrixSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.BinaryMatrixScalarSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.BinaryTensorTensorBroadcastSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.BinaryTensorTensorSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.BinUaggChainSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.BuiltinNarySPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.CastSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.CentralMomentSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.CheckpointSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.CompressionSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.CovarianceSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.CpmmSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.CSVReblockSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.CtableSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.CumulativeAggregateSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.CumulativeOffsetSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.DnnSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.FrameAppendMSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.FrameAppendRSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.FrameIndexingSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.MapmmChainSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.MapmmSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.MatrixAppendMSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.MatrixAppendRSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.MatrixIndexingSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.MatrixReshapeSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.PMapmmSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.PmmSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.QuantilePickSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.QuantileSortSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.QuaternarySPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.RandSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.ReblockSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.ReorgSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.RmmSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.SPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.SpoofSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.TernarySPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.Tsmm2SPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.TsmmSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.UaggOuterChainSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.UnaryFrameSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.UnaryMatrixSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.WriteSPInstruction
-
- processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.ZipmmSPInstruction
-
- processReluBackwardInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.DnnCPInstruction
-
- processReLUBackwardInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.DnnGPUInstruction
-
- processRmvarInstruction(ExecutionContext, String) - Static method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
-
Remove variable instruction externalized as a static function in order to allow various
cleanup procedures to use the same codepath as the actual rmVar instruction
- prod() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Wrapper method for reduceall-product of a matrix.
- prod(long[]) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- prod(int[]) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- prod(int[], int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- PROFILE - Static variable in class org.apache.sysds.parser.ParForStatementBlock
-
- PROG_BEGIN - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- PROG_END - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- Program - Class in org.apache.sysds.runtime.controlprogram
-
- Program() - Constructor for class org.apache.sysds.runtime.controlprogram.Program
-
- Program(DMLProgram) - Constructor for class org.apache.sysds.runtime.controlprogram.Program
-
- ProgramBlock - Class in org.apache.sysds.runtime.controlprogram
-
- ProgramBlock(Program) - Constructor for class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- ProgramConverter - Class in org.apache.sysds.runtime.util
-
Program converter functionalities for
(1) creating deep copies of program blocks, instructions, function program blocks, and
(2) serializing and parsing of programs, program blocks, functions program blocks.
- ProgramConverter() - Constructor for class org.apache.sysds.runtime.util.ProgramConverter
-
- ProgramRecompiler - Class in org.apache.sysds.runtime.controlprogram.parfor.opt
-
- ProgramRecompiler() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.ProgramRecompiler
-
- ProgramRewriter - Class in org.apache.sysds.hops.rewrite
-
This program rewriter applies a variety of rule-based rewrites
on all hop dags of the given program in one pass over the entire
program.
- ProgramRewriter() - Constructor for class org.apache.sysds.hops.rewrite.ProgramRewriter
-
- ProgramRewriter(boolean, boolean) - Constructor for class org.apache.sysds.hops.rewrite.ProgramRewriter
-
- ProgramRewriter(HopRewriteRule...) - Constructor for class org.apache.sysds.hops.rewrite.ProgramRewriter
-
Construct a program rewriter for a given rewrite which is passed from outside.
- ProgramRewriter(StatementBlockRewriteRule...) - Constructor for class org.apache.sysds.hops.rewrite.ProgramRewriter
-
Construct a program rewriter for a given rewrite which is passed from outside.
- ProgramRewriter(ArrayList<HopRewriteRule>, ArrayList<StatementBlockRewriteRule>) - Constructor for class org.apache.sysds.hops.rewrite.ProgramRewriter
-
Construct a program rewriter for the given rewrite sets which are passed from outside.
- ProgramRewriteStatus - Class in org.apache.sysds.hops.rewrite
-
- ProgramRewriteStatus() - Constructor for class org.apache.sysds.hops.rewrite.ProgramRewriteStatus
-
- ProgramRewriteStatus(LocalVariableMap) - Constructor for class org.apache.sysds.hops.rewrite.ProgramRewriteStatus
-
- programroot() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- ProgramrootContext(ParserRuleContext, int) - Constructor for class org.apache.sysds.parser.dml.DmlParser.ProgramrootContext
-
- projectColumns(Dataset<Row>, ArrayList<String>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- ProjectInfo - Class in org.apache.sysds.api.mlcontext
-
Obtains information that is stored in the manifest when the SystemDS jar is
built.
- propagate() - Method in class org.apache.sysds.runtime.privacy.propagation.MatrixMultiplicationPropagator
-
- propagate() - Method in interface org.apache.sysds.runtime.privacy.propagation.Propagator
-
Activates the propagation and returns the output privacy constraint.
- Propagator - Interface in org.apache.sysds.runtime.privacy.propagation
-
Interface for all propagator instances.
- properties() - Method in class org.apache.sysds.api.mlcontext.ProjectInfo
-
Obtain all the properties from the manifest as a sorted map.
- property(String) - Method in class org.apache.sysds.api.mlcontext.ProjectInfo
-
Obtain a manifest property value based on the key.
- PRUNE_REDUNDANT_PLANS - Static variable in class org.apache.sysds.hops.codegen.SpoofCompiler
-
- pruneRedundant(long, boolean, InterestingPoint[]) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- pruneSuboptimal(ArrayList<Hop>) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- PS_AGGREGATION_FUN - Static variable in class org.apache.sysds.parser.Statement
-
- PS_BATCH_SIZE - Static variable in class org.apache.sysds.parser.Statement
-
- PS_CHECKPOINTING - Static variable in class org.apache.sysds.parser.Statement
-
- PS_EPOCHS - Static variable in class org.apache.sysds.parser.Statement
-
- PS_FEATURES - Static variable in class org.apache.sysds.parser.Statement
-
- PS_FREQUENCY - Static variable in class org.apache.sysds.parser.Statement
-
- PS_FUNC_PREFIX - Static variable in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
- PS_GRADIENTS - Static variable in class org.apache.sysds.parser.Statement
-
- PS_HYPER_PARAMS - Static variable in class org.apache.sysds.parser.Statement
-
- PS_LABELS - Static variable in class org.apache.sysds.parser.Statement
-
- PS_MODE - Static variable in class org.apache.sysds.parser.Statement
-
- PS_MODEL - Static variable in class org.apache.sysds.parser.Statement
-
- PS_PARALLELISM - Static variable in class org.apache.sysds.parser.Statement
-
- PS_SCHEME - Static variable in class org.apache.sysds.parser.Statement
-
- PS_UPDATE_FUN - Static variable in class org.apache.sysds.parser.Statement
-
- PS_UPDATE_TYPE - Static variable in class org.apache.sysds.parser.Statement
-
- PS_VAL_FEATURES - Static variable in class org.apache.sysds.parser.Statement
-
- PS_VAL_LABELS - Static variable in class org.apache.sysds.parser.Statement
-
- PSBODY_BEGIN - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- PSBODY_END - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- PSRpcCall - Class in org.apache.sysds.runtime.controlprogram.paramserv.rpc
-
- PSRpcCall(int, int, ListObject) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcCall
-
- PSRpcCall(ByteBuffer) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcCall
-
- PSRpcFactory - Class in org.apache.sysds.runtime.controlprogram.paramserv.rpc
-
- PSRpcFactory() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcFactory
-
- PSRpcHandler - Class in org.apache.sysds.runtime.controlprogram.paramserv.rpc
-
- PSRpcObject - Class in org.apache.sysds.runtime.controlprogram.paramserv.rpc
-
- PSRpcObject() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcObject
-
- PSRpcResponse - Class in org.apache.sysds.runtime.controlprogram.paramserv.rpc
-
- PSRpcResponse(ByteBuffer) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcResponse
-
- PSRpcResponse(PSRpcResponse.Type) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcResponse
-
- PSRpcResponse(PSRpcResponse.Type, Object) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcResponse
-
- PSRpcResponse.Type - Enum in org.apache.sysds.runtime.controlprogram.paramserv.rpc
-
- PSWorker - Class in org.apache.sysds.runtime.controlprogram.paramserv
-
- pull(int) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.LocalParamServer
-
- pull(int) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamServer
-
- PULL - Static variable in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcObject
-
- pull(int) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.SparkPSProxy
-
- push(int, ListObject) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.LocalParamServer
-
- push(int, ListObject) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamServer
-
- PUSH - Static variable in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcObject
-
- push(int, ListObject) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.SparkPSProxy
-
- put(String, Data) - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
-
Adds a new (name, value) pair to the variable map, or replaces an old pair with
the same name.
- put(DataRange, PrivacyConstraint.PrivacyLevel) - Method in interface org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacy
-
Set privacy level of the given data range.
- put(DataRange, PrivacyConstraint.PrivacyLevel) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyList
-
- put(DataRange, PrivacyConstraint.PrivacyLevel) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyMap
-
- putAll(Map<String, Data>) - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
-
- putAll(LocalVariableMap) - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
-
- putCol(int, int, PrivacyConstraint.PrivacyLevel) - Method in interface org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacy
-
- putCol(int, int, PrivacyConstraint.PrivacyLevel) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyList
-
- putCol(int, int, PrivacyConstraint.PrivacyLevel) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyMap
-
- putElement(int, int, PrivacyConstraint.PrivacyLevel) - Method in interface org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacy
-
- putElement(int, int, PrivacyConstraint.PrivacyLevel) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyList
-
- putElement(int, int, PrivacyConstraint.PrivacyLevel) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyMap
-
- putHopMapping(Hop, OptNode) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingAbstract
-
- putMapping(Instruction, OptNode) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingRuntime
-
- putMapping(ProgramBlock, OptNode) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingRuntime
-
- putMatrix(Instruction, ExecutionContext, long) - Static method in class org.apache.sysds.runtime.lineage.LineageCache
-
- putPage(byte[]) - Static method in class org.apache.sysds.runtime.controlprogram.caching.PageCache
-
- putPfPwMapping(long, long) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.StatisticMonitor
-
Register information about parent-child relationships of parworkers and
parfor program blocks, with a parfor can be related to one or many parworkers.
- putPFStat(long, Stat, double) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.StatisticMonitor
-
Puts a specific parfor statistic for future analysis into the repository.
- putProgMapping(StatementBlock, ProgramBlock, OptNode) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingAbstract
-
- putPWStat(long, Stat, double) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.StatisticMonitor
-
Puts a specific parworker statistic for future analysis into the repository.
- putRootProgram(DMLProgram, Program) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingAbstract
-
- putRow(int, int, PrivacyConstraint.PrivacyLevel) - Method in interface org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacy
-
- putRow(int, int, PrivacyConstraint.PrivacyLevel) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyList
-
- putRow(int, int, PrivacyConstraint.PrivacyLevel) - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyMap
-
- putValue(Instruction, ExecutionContext, long) - Static method in class org.apache.sysds.runtime.lineage.LineageCache
-
- putValue(List<DataIdentifier>, LineageItem[], String, ExecutionContext, long) - Static method in class org.apache.sysds.runtime.lineage.LineageCache
-
- Py4jConverterUtils - Class in org.apache.sysds.runtime.util
-
Utils for converting python data to java.
- Py4jConverterUtils() - Constructor for class org.apache.sysds.runtime.util.Py4jConverterUtils
-
- PythonDMLScript - Class in org.apache.sysds.api
-
- R - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- raiseValidateError(String) - Method in class org.apache.sysds.parser.Expression
-
Throw a LanguageException with the message.
- raiseValidateError(String, boolean) - Method in class org.apache.sysds.parser.Expression
-
Throw a LanguageException with the message if conditional is false
;
otherwise log the message as a warning.
- raiseValidateError(String, boolean, String) - Method in class org.apache.sysds.parser.Expression
-
Throw a LanguageException with the message (and optional error code) if conditional is false
;
otherwise log the message as a warning.
- raiseValidateError(String, boolean) - Method in class org.apache.sysds.parser.Statement
-
- raiseValidateError(String, boolean, String) - Method in class org.apache.sysds.parser.Statement
-
- raiseValidateError(String, boolean) - Method in class org.apache.sysds.parser.StatementBlock
-
- raiseValidateError(String, boolean, String) - Method in class org.apache.sysds.parser.StatementBlock
-
- RAND_BY_ROW - Static variable in class org.apache.sysds.parser.DataExpression
-
- RAND_COLS - Static variable in class org.apache.sysds.parser.DataExpression
-
- RAND_DATA - Static variable in class org.apache.sysds.parser.DataExpression
-
- RAND_DIMNAMES - Static variable in class org.apache.sysds.parser.DataExpression
-
- RAND_DIMS - Static variable in class org.apache.sysds.parser.DataExpression
-
- RAND_LAMBDA - Static variable in class org.apache.sysds.parser.DataExpression
-
- RAND_MAX - Static variable in class org.apache.sysds.parser.DataExpression
-
- RAND_MIN - Static variable in class org.apache.sysds.parser.DataExpression
-
- RAND_OPCODE - Static variable in class org.apache.sysds.lops.DataGen
-
- RAND_PDF - Static variable in class org.apache.sysds.parser.DataExpression
-
- RAND_PDF_UNIFORM - Static variable in class org.apache.sysds.parser.DataExpression
-
- RAND_ROWS - Static variable in class org.apache.sysds.parser.DataExpression
-
- RAND_SEED - Static variable in class org.apache.sysds.parser.DataExpression
-
- RAND_SPARSITY - Static variable in class org.apache.sysds.parser.DataExpression
-
- RAND_VALID_PARAM_NAMES - Static variable in class org.apache.sysds.parser.DataExpression
-
- RandNPair - Class in org.apache.sysds.runtime.util
-
Class that generates a pair of random numbers from standard normal
distribution N(0,1).
- RandNPair() - Constructor for class org.apache.sysds.runtime.util.RandNPair
-
- RandomMatrixGenerator - Class in org.apache.sysds.runtime.matrix.data
-
- RandomMatrixGenerator() - Constructor for class org.apache.sysds.runtime.matrix.data.RandomMatrixGenerator
-
- RandomMatrixGenerator(RandomMatrixGenerator.PDF, int, int, int, double) - Constructor for class org.apache.sysds.runtime.matrix.data.RandomMatrixGenerator
-
Instantiates a Random number generator
- RandomMatrixGenerator(String, int, int, int, double, double, double) - Constructor for class org.apache.sysds.runtime.matrix.data.RandomMatrixGenerator
-
Instantiates a Random number generator
- RandomMatrixGenerator(RandomMatrixGenerator.PDF, int, int, int, double, double, double) - Constructor for class org.apache.sysds.runtime.matrix.data.RandomMatrixGenerator
-
Instantiates a Random number generator
- RandomMatrixGenerator(RandomMatrixGenerator.PDF, int, int, int, double, double, double, double) - Constructor for class org.apache.sysds.runtime.matrix.data.RandomMatrixGenerator
-
Instantiates a Random number generator with a specific poisson mean
- randOperations(int, int, double, double, double, String, long) - Static method in class org.apache.sysds.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.sysds.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.sysds.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.sysds.runtime.matrix.data.MatrixBlock
-
Function to generate the random matrix with specified dimensions and block dimensions.
- randOperationsInPlace(RandomMatrixGenerator, Well1024a, long) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- randOperationsInPlace(RandomMatrixGenerator, Well1024a, long, int) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- randOperationsInPlace(RandomMatrixGenerator, Well1024a, long) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Function to generate a matrix of random numbers.
- randOperationsInPlace(RandomMatrixGenerator, Well1024a, long, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Function to generate a matrix of random numbers.
- RandSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- ratio - Variable in class org.apache.sysds.runtime.compress.CompressionStatistics
-
- rbind(EstimatorBitsetMM.BitsetMatrix) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix1
-
- rbind(EstimatorBitsetMM.BitsetMatrix) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix2
-
- rbind(Future<FederatedResponse>[]) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
-
- rbind(ExecutionContext, GPUContext, String, MatrixObject, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
- rcDelete(File) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
Recursively deletes an entire local file system directory
and returns the number of files deleted.
- rCheckCycles(LineageItem, Set<Long>, boolean) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
-
- rCleanupRuntimeProgram(ProgramBlock, HashSet<String>) - Static method in class org.apache.sysds.api.jmlc.JMLCUtils
-
Cleanup program blocks (called recursively).
- rClearLops(Hop) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
Clearing lops for a given hops includes to (1) remove the reference
to constructed lops and (2) clear the exec type (for consistency).
- rConstructLineageFromHops(Hop, Hop[], Map<Long, LineageItem>, HashMap<Long, Hop>) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
-
- rContainsBinary(CNode, CNodeBinary.BinType) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- rContainsInput(CNode, long) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- rContainsMRJobInstruction(ProgramBlock, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
-
- rContainsRead(Hop, String, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- rCreateAbstractOptNode(StatementBlock, ProgramBlock, LocalVariableMap, boolean, Set<String>) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
-
- rCreateAbstractOptNodes(Hop, LocalVariableMap, Set<String>) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
-
- rcreateDeepCopyProgramBlocks(ArrayList<ProgramBlock>, long, int, Set<String>, Set<String>, boolean, boolean) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
This recursively creates a deep copy of program blocks and transparently replaces filenames according to the
specified parallel worker in order to avoid conflicts between parworkers.
- rCreateDeepCopyStatementBlock(StatementBlock) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- rCreateOptNode(ProgramBlock, LocalVariableMap, boolean, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
-
- RDDAggregateUtils - Class in org.apache.sysds.runtime.instructions.spark.utils
-
Collection of utility methods for aggregating binary block rdds.
- RDDAggregateUtils() - Constructor for class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
- RDDBinUaggChainFunction(BinaryOperator, AggregateUnaryOperator) - Constructor for class org.apache.sysds.runtime.instructions.spark.BinUaggChainSPInstruction.RDDBinUaggChainFunction
-
- RDDConverterUtils - Class in org.apache.sysds.runtime.instructions.spark.utils
-
- RDDConverterUtils() - Constructor for class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
-
- RDDConverterUtils.BinaryCellToBinaryBlockFunction - Class in org.apache.sysds.runtime.instructions.spark.utils
-
- RDDConverterUtils.DataFrameExtractIDFunction - Class in org.apache.sysds.runtime.instructions.spark.utils
-
- RDDConverterUtilsExt - Class in org.apache.sysds.runtime.instructions.spark.utils
-
NOTE: These are experimental converter utils.
- RDDConverterUtilsExt() - Constructor for class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
- RDDConverterUtilsExt.AddRowID - Class in org.apache.sysds.runtime.instructions.spark.utils
-
- RDDConverterUtilsExt.RDDConverterTypes - Enum in org.apache.sysds.runtime.instructions.spark.utils
-
- RDDMapGroupedAggFunction(PartitionedBroadcast<MatrixBlock>, Operator, int, int) - Constructor for class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDMapGroupedAggFunction
-
- RDDMapGroupedAggFunction2(PartitionedBroadcast<MatrixBlock>, Operator, int) - Constructor for class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDMapGroupedAggFunction2
-
- RDDObject - Class in org.apache.sysds.runtime.instructions.spark.data
-
- RDDObject(JavaPairRDD<?, ?>) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.RDDObject
-
- RDDRemoveEmptyFunction(boolean, long, long) - Constructor for class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDRemoveEmptyFunction
-
- RDDRemoveEmptyFunctionInMem(boolean, long, long, PartitionedBroadcast<MatrixBlock>) - Constructor for class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDRemoveEmptyFunctionInMem
-
- RDDReplaceFunction(double, double) - Constructor for class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDReplaceFunction
-
- RDDRExpandFunction(double, boolean, boolean, boolean, long) - Constructor for class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDRExpandFunction
-
- RDDSortUtils - Class in org.apache.sysds.runtime.instructions.spark.utils
-
- RDDSortUtils() - Constructor for class org.apache.sysds.runtime.instructions.spark.utils.RDDSortUtils
-
- RDDSortUtils.IndexComparator - Class in org.apache.sysds.runtime.instructions.spark.utils
-
- RDDSortUtils.IndexComparator2 - Class in org.apache.sysds.runtime.instructions.spark.utils
-
- rddStringCSVToFrameObject(RDD<String>) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a RDD<String>
in CSV format to a FrameObject
- rddStringCSVToFrameObject(RDD<String>, FrameMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a RDD<String>
in CSV format to a FrameObject
- rddStringCSVToMatrixObject(RDD<String>) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a RDD<String>
in CSV format to a MatrixObject
- rddStringCSVToMatrixObject(RDD<String>, MatrixMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a RDD<String>
in CSV format to a MatrixObject
- rddStringIJVToFrameObject(RDD<String>, FrameMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a RDD<String>
in IJV format to a FrameObject
.
- rddStringIJVToMatrixObject(RDD<String>, MatrixMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a RDD<String>
in IJV format to a MatrixObject
.
- RDDTransformApplyFunction(Broadcast<Encoder>, Broadcast<TfOffsetMap>) - Constructor for class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTransformApplyFunction
-
- RDDTransformApplyOffsetFunction(String, String[]) - Constructor for class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTransformApplyOffsetFunction
-
- RDDTransformDecodeExpandFunction(int, int) - Constructor for class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTransformDecodeExpandFunction
-
- RDDTransformDecodeFunction(Decoder, int) - Constructor for class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTransformDecodeFunction
-
- RDDUAggFunction2(AggregateUnaryOperator, int) - Constructor for class org.apache.sysds.runtime.instructions.spark.AggregateUnarySPInstruction.RDDUAggFunction2
-
- RDDUTensorAggFunction2(AggregateUnaryOperator) - Constructor for class org.apache.sysds.runtime.instructions.spark.AggregateUnarySPInstruction.RDDUTensorAggFunction2
-
- rDecompress(LineageItem) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
-
Deprecated.
- rDelete(File) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
Recursively deletes an entire local file system directory.
- ReachabilityGraph - Class in org.apache.sysds.hops.codegen.opt
-
- ReachabilityGraph(PlanPartition, CPlanMemoTable) - Constructor for class org.apache.sysds.hops.codegen.opt.ReachabilityGraph
-
- ReachabilityGraph.SubProblem - Class in org.apache.sysds.hops.codegen.opt
-
- read(DataInput, boolean) - Static method in class org.apache.sysds.runtime.compress.colgroup.ADictionary
-
The read function to instantiate the dictionary.
- read(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.Dictionary
-
- read(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.QDictionary
-
- read(DataInput) - Method in class org.apache.sysds.runtime.instructions.cp.KahanObject
-
- READ_VALID_MTD_PARAM_NAMES - Static variable in class org.apache.sysds.parser.DataExpression
-
Valid parameter names in metadata file
- READ_VALID_PARAM_NAMES - Static variable in class org.apache.sysds.parser.DataExpression
-
Valid parameter names in arguments to read instruction
- readAndParseMatrixMarketHeader(String) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- readBlock(String, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
-
- readBlockSequenceFromLocal(String, Pair<MatrixIndexes, MatrixValue>[], HashMap<MatrixIndexes, Integer>) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
- readBoolean() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- readBoolean() - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- readBoolean() - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- readBooleanFromHDFSFile(String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- readByte() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- readByte() - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- readByte() - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- readCacheBlockFromLocal(String, boolean) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
Reads a matrix/frame block from local file system.
- readCellList2BlockFromLocal(String, int) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.util.StagingFileUtils
-
- readCellList2BlockFromLocal(String, int, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.util.StagingFileUtils
-
- readCellListFromLocal(String) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.util.StagingFileUtils
-
- readChar() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- readChar() - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- readChar() - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- READCOLPARAM - Static variable in class org.apache.sysds.parser.DataExpression
-
- readColumnVectorFromHDFS(String, Types.FileFormat, long, long, int) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- readConfigurationFile(String) - Static method in class org.apache.sysds.conf.DMLConfig
-
Start with the internal default settings, then merge in the
settings from any specified configuration file, if available.
- readDMLScript(String, Log) - Static method in class org.apache.sysds.parser.ParserWrapper
-
- readDouble() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- readDouble() - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- readDouble() - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- readDoubleArray(int, double[]) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- readDoubleArray(int, double[]) - Method in interface org.apache.sysds.runtime.matrix.data.MatrixBlockDataInput
-
Reads the double array from the data input into the given dense block
and returns the number of non-zeros.
- readDoubleArray(int, double[]) - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- readDoubleArray(int, double[]) - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- readDoubleFromHDFSFile(String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- readDoubleMatrix(String) - Method in class org.apache.sysds.api.jmlc.Connection
-
Reads an input matrix in arbitrary format from HDFS into a dense double array.
- readDoubleMatrix(String, Types.FileFormat, long, long, int, long) - Method in class org.apache.sysds.api.jmlc.Connection
-
Reads an input matrix in arbitrary format from HDFS into a dense double array.
- ReaderBinaryBlock - Class in org.apache.sysds.runtime.io
-
- ReaderBinaryBlock(boolean) - Constructor for class org.apache.sysds.runtime.io.ReaderBinaryBlock
-
- ReaderBinaryBlockParallel - Class in org.apache.sysds.runtime.io
-
- ReaderBinaryBlockParallel(boolean) - Constructor for class org.apache.sysds.runtime.io.ReaderBinaryBlockParallel
-
- ReaderColumnSelection - Class in org.apache.sysds.runtime.compress
-
Base class for all column selection readers.
- ReaderColumnSelectionDense - Class in org.apache.sysds.runtime.compress
-
- ReaderColumnSelectionDense(MatrixBlock, int[], CompressionSettings) - Constructor for class org.apache.sysds.runtime.compress.ReaderColumnSelectionDense
-
- ReaderColumnSelectionDenseSample - Class in org.apache.sysds.runtime.compress
-
considers only a subset of row indexes
- ReaderColumnSelectionDenseSample(MatrixBlock, int[], int[], CompressionSettings) - Constructor for class org.apache.sysds.runtime.compress.ReaderColumnSelectionDenseSample
-
- ReaderColumnSelectionSparse - Class in org.apache.sysds.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[], CompressionSettings) - Constructor for class org.apache.sysds.runtime.compress.ReaderColumnSelectionSparse
-
- ReaderTextCell - Class in org.apache.sysds.runtime.io
-
- ReaderTextCell(Types.FileFormat) - Constructor for class org.apache.sysds.runtime.io.ReaderTextCell
-
- ReaderTextCell(Types.FileFormat, boolean) - Constructor for class org.apache.sysds.runtime.io.ReaderTextCell
-
- ReaderTextCellParallel - Class in org.apache.sysds.runtime.io
-
Parallel version of ReaderTextCell.java.
- ReaderTextCellParallel(Types.FileFormat) - Constructor for class org.apache.sysds.runtime.io.ReaderTextCellParallel
-
- ReaderTextCellParallel.CellBuffer - Class in org.apache.sysds.runtime.io
-
Useful class for buffering unordered cells before locking target onces and
appending all buffered cells.
- ReaderTextCellParallel.CountNnzTask - Class in org.apache.sysds.runtime.io
-
- ReaderTextCellParallel.ReadTask - Class in org.apache.sysds.runtime.io
-
- ReaderTextCSV - Class in org.apache.sysds.runtime.io
-
- ReaderTextCSV(FileFormatPropertiesCSV) - Constructor for class org.apache.sysds.runtime.io.ReaderTextCSV
-
- ReaderTextCSVParallel - Class in org.apache.sysds.runtime.io
-
Parallel version of ReaderTextCSV.java.
- ReaderTextCSVParallel(FileFormatPropertiesCSV) - Constructor for class org.apache.sysds.runtime.io.ReaderTextCSVParallel
-
- ReaderTextLIBSVM - Class in org.apache.sysds.runtime.io
-
- ReaderTextLIBSVM() - Constructor for class org.apache.sysds.runtime.io.ReaderTextLIBSVM
-
- ReaderTextLIBSVMParallel - Class in org.apache.sysds.runtime.io
-
- ReaderTextLIBSVMParallel() - Constructor for class org.apache.sysds.runtime.io.ReaderTextLIBSVMParallel
-
- readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
Redirects the default java serialization via externalizable to our default hadoop writable serialization for
efficient broadcast/rdd de-serialization.
- readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.data.TensorIndexes
-
Redirects the default java serialization via externalizable to our default
hadoop writable serialization for consistency/maintainability.
- readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.instructions.spark.data.CorrMatrixBlock
-
Redirects the default java serialization via externalizable to our default
hadoop writable serialization for efficient deserialization.
- readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
Redirects the default java serialization via externalizable to our default
hadoop writable serialization for efficient broadcast deserialization.
- readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.instructions.spark.data.RowMatrixBlock
-
Redirects the default java serialization via externalizable to our default
hadoop writable serialization for efficient deserialization.
- readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- readExternal(ObjectInput) - Method in class org.apache.sysds.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.sysds.runtime.matrix.data.MatrixIndexes
-
Redirects the default java serialization via externalizable to our default
hadoop writable serialization for consistency/maintainability.
- readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.privacy.PrivacyConstraint
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Deserialize column group from data input.
- readFields(DataInput) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC1
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC2
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOffset
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupValue
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeTaggedMatrixIndexes
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.PairWritableBlock
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.PairWritableCell
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.data.TensorIndexes
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.matrix.data.MatrixIndexes
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.matrix.data.TripleIndexes
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
-
- readFields(DataInput) - Method in class org.apache.sysds.runtime.matrix.data.WeightedPair
-
- readFirstBlock(String) - Method in class org.apache.sysds.runtime.io.FrameReaderBinaryBlock
-
Specific functionality of FrameReaderBinaryBlock, mostly used for testing.
- readFloat() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- readFloat() - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- readFloat() - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- readFrameBlockFromLocal(String) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
Reads a frame block from local file system.
- readFrameBlockFromStream(InputStream) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
Reads a frame block from an input stream, using a fused buffered reader
with special support for matrix blocks.
- readFrameFromHDFS(String, Types.ValueType[], String[], long, long) - Method in class org.apache.sysds.runtime.io.FrameReader
-
- readFrameFromHDFS(String, Types.ValueType[], long, long) - Method in class org.apache.sysds.runtime.io.FrameReader
-
- readFrameFromHDFS(String, long, long) - Method in class org.apache.sysds.runtime.io.FrameReader
-
- readFrameFromHDFS(String, Types.ValueType[], String[], long, long) - Method in class org.apache.sysds.runtime.io.FrameReaderBinaryBlock
-
- readFrameFromHDFS(String, Types.ValueType[], Map<String, Integer>, long, long) - Method in class org.apache.sysds.runtime.io.FrameReaderJSONL
-
- readFrameFromHDFS(String, Types.ValueType[], String[], long, long) - Method in class org.apache.sysds.runtime.io.FrameReaderProto
-
- readFrameFromHDFS(String, Types.ValueType[], String[], long, long) - Method in class org.apache.sysds.runtime.io.FrameReaderTextCell
-
- readFrameFromHDFS(String, Types.ValueType[], String[], long, long) - Method in class org.apache.sysds.runtime.io.FrameReaderTextCSV
-
- readFrameFromInputStream(InputStream, Types.ValueType[], String[], long, long) - Method in class org.apache.sysds.runtime.io.FrameReader
-
- readFrameFromInputStream(InputStream, Types.ValueType[], long, long) - Method in class org.apache.sysds.runtime.io.FrameReader
-
- readFrameFromInputStream(InputStream, long, long) - Method in class org.apache.sysds.runtime.io.FrameReader
-
- readFrameFromInputStream(InputStream, Types.ValueType[], String[], long, long) - Method in class org.apache.sysds.runtime.io.FrameReaderBinaryBlock
-
- readFrameFromInputStream(InputStream, Types.ValueType[], String[], long, long) - Method in class org.apache.sysds.runtime.io.FrameReaderProto
-
- readFrameFromInputStream(InputStream, Types.ValueType[], String[], long, long) - Method in class org.apache.sysds.runtime.io.FrameReaderTextCell
-
- readFrameFromInputStream(InputStream, Types.ValueType[], String[], long, long) - Method in class org.apache.sysds.runtime.io.FrameReaderTextCSV
-
- readFully(byte[]) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- readFully(byte[], int, int) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- readFully(byte[]) - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- readFully(byte[], int, int) - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- readFully(byte[]) - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- readFully(byte[], int, int) - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- readGroups(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupIO
-
Read groups from a file.
- readIndexedMatrixBlocksFromHDFS(String, long, long, int) - Method in class org.apache.sysds.runtime.io.ReaderBinaryBlock
-
- readInt() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- readInt() - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- readInt() - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- readIntegerFromHDFSFile(String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- readLine() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- readLine() - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- readLine() - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- readLong() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- readLong() - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- readLong() - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- readMatrixBlockFromLocal(String) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
Reads a matrix block from local file system.
- readMatrixBlockFromLocal(String, MatrixBlock) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
Reads a matrix block from local file system.
- readMatrixBlockFromStream(InputStream) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
Reads a matrix block from an input stream, using a fused buffered reader
with special support for matrix blocks.
- readMatrixFromHDFS(String, long, long, int, long) - Method in class org.apache.sysds.runtime.io.MatrixReader
-
- readMatrixFromHDFS(String, long, long, int, long) - Method in class org.apache.sysds.runtime.io.ReaderBinaryBlock
-
- readMatrixFromHDFS(String, long, long, int, long) - Method in class org.apache.sysds.runtime.io.ReaderBinaryBlockParallel
-
- readMatrixFromHDFS(String, long, long, int, long) - Method in class org.apache.sysds.runtime.io.ReaderTextCell
-
- readMatrixFromHDFS(String, long, long, int, long) - Method in class org.apache.sysds.runtime.io.ReaderTextCSV
-
- readMatrixFromHDFS(String, long, long, int, long) - Method in class org.apache.sysds.runtime.io.ReaderTextCSVParallel
-
- readMatrixFromHDFS(String, long, long, int, long) - Method in class org.apache.sysds.runtime.io.ReaderTextLIBSVM
-
- readMatrixFromHDFS(String, long, long, int, long) - Method in class org.apache.sysds.runtime.io.ReaderTextLIBSVMParallel
-
- readMatrixFromHDFS(String, Types.FileFormat, long, long, int, boolean) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- readMatrixFromHDFS(String, Types.FileFormat, long, long, int) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- readMatrixFromHDFS(String, Types.FileFormat, long, long, int, long) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- readMatrixFromHDFS(String, Types.FileFormat, long, long, int, long, boolean) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- readMatrixFromHDFS(String, Types.FileFormat, long, long, int, long, FileFormatProperties) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- readMatrixFromHDFS(ReadProperties) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
Core method for reading matrices in format textcell, matrixmarket, binarycell, or binaryblock
from HDFS into main memory.
- readMatrixFromHDFS(String, Types.FileFormat, long, long, int) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- readMatrixFromInputStream(InputStream, long, long, int, long) - Method in class org.apache.sysds.runtime.io.MatrixReader
-
- readMatrixFromInputStream(InputStream, long, long, int, long) - Method in class org.apache.sysds.runtime.io.ReaderBinaryBlock
-
- readMatrixFromInputStream(InputStream, long, long, int, long) - Method in class org.apache.sysds.runtime.io.ReaderTextCell
-
- readMatrixFromInputStream(InputStream, long, long, int, long) - Method in class org.apache.sysds.runtime.io.ReaderTextCSV
-
- readMatrixFromInputStream(InputStream, long, long, int, long) - Method in class org.apache.sysds.runtime.io.ReaderTextCSVParallel
-
- readMatrixFromInputStream(InputStream, long, long, int, long) - Method in class org.apache.sysds.runtime.io.ReaderTextLIBSVM
-
- readMatrixFromInputStream(InputStream, long, long, int, long) - Method in class org.apache.sysds.runtime.io.ReaderTextLIBSVMParallel
-
- readMatrixMarketHeader(String) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- readMatrixPartition(IndexRange) - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
NOTE: for reading matrix partitions, we could cache (in its real sense) the read block
with soft references (no need for eviction, as partitioning only applied for read-only matrices).
- readMetadataFile(String, boolean) - Method in class org.apache.sysds.parser.DataExpression
-
- READNNZPARAM - Static variable in class org.apache.sysds.parser.DataExpression
-
- readObjectFromHDFSFile(String, Types.ValueType) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- ReadProperties - Class in org.apache.sysds.runtime.io
-
- ReadProperties() - Constructor for class org.apache.sysds.runtime.io.ReadProperties
-
- READROWPARAM - Static variable in class org.apache.sysds.parser.DataExpression
-
- readScript(String) - Method in class org.apache.sysds.api.jmlc.Connection
-
Read a DML or PyDML file as a string.
- readShort() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- readShort() - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- readShort() - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- readSparseRows(int, long, SparseBlock) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- readSparseRows(int, long, SparseBlock) - Method in interface org.apache.sysds.runtime.matrix.data.MatrixBlockDataInput
-
Reads the sparse rows array from the data input into a sparse block
and returns the number of non-zeros.
- readSparseRows(int, long, SparseBlock) - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- readSparseRows(int, long, SparseBlock) - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- readStringFrame(String) - Method in class org.apache.sysds.api.jmlc.Connection
-
Reads an input frame in arbitrary format from HDFS into a dense string array.
- readStringFrame(String, Types.FileFormat, long, long) - Method in class org.apache.sysds.api.jmlc.Connection
-
Reads an input frame in arbitrary format from HDFS into a dense string array.
- readStringFromHDFSFile(String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- ReadTask(InputSplit, TextInputFormat, JobConf, FrameBlock) - Constructor for class org.apache.sysds.runtime.io.FrameReaderTextCellParallel.ReadTask
-
- ReadTask(InputSplit, TextInputFormat, JobConf, MatrixBlock, long, long, boolean, FileFormatPropertiesMM) - Constructor for class org.apache.sysds.runtime.io.ReaderTextCellParallel.ReadTask
-
- readTensorFromHDFS(String, long[], int, Types.ValueType[]) - Method in class org.apache.sysds.runtime.io.TensorReader
-
- readTensorFromHDFS(String, long[], int, Types.ValueType[]) - Method in class org.apache.sysds.runtime.io.TensorReaderBinaryBlock
-
- readTensorFromHDFS(String, long[], int, Types.ValueType[]) - Method in class org.apache.sysds.runtime.io.TensorReaderTextCell
-
- readTensorFromHDFS(String, Types.FileFormat, long[], int, Types.ValueType[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- readTransformMetaDataFromFile(String) - Method in class org.apache.sysds.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.sysds.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.sysds.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) - Static method in class org.apache.sysds.runtime.transform.meta.TfMetaUtils
-
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.sysds.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.sysds.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.sysds.api.jmlc.Connection
-
Reads transform meta data from the class path and converts it into an in-memory
FrameBlock object.
- readTransformMetaDataFromPath(String, String, String) - Static method in class org.apache.sysds.runtime.transform.meta.TfMetaUtils
-
Reads transform meta data from the class path and converts it into an in-memory
FrameBlock object.
- readUnsignedByte() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- readUnsignedByte() - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- readUnsignedByte() - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- readUnsignedShort() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- readUnsignedShort() - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- readUnsignedShort() - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- readUTF() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- readUTF() - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- readUTF() - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- readWritableFromLocal(String, Writable) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
Reads an arbitrary writable from local file system, using a fused buffered reader
with special support for matrix blocks.
- readWritableFromStream(InputStream, Writable) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
Reads an arbitrary writable from an input stream, using a fused buffered reader
with special support for matrix blocks.
- ReBlock - Class in org.apache.sysds.lops
-
Lop to perform reblock operation
- ReBlock(Lop, int, Types.DataType, Types.ValueType, boolean, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.ReBlock
-
- ReblockBuffer - Class in org.apache.sysds.runtime.instructions.spark.data
-
- ReblockBuffer(int, long, long, int) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.ReblockBuffer
-
- ReblockSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- ReblockTensorFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- ReblockTensorFunction(int, long) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.ReblockTensorFunction
-
- receive(TransportClient, ByteBuffer, RpcResponseCallback) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcHandler
-
- recodeData(HashMap<Double, Integer>) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC1
-
- RECOMPILE_CODEGEN - Static variable in class org.apache.sysds.hops.codegen.SpoofCompiler
-
- recompileHopsDag(StatementBlock, ArrayList<Hop>, ExecutionContext, RecompileStatus, boolean, boolean, long) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- recompileHopsDag(StatementBlock, ArrayList<Hop>, LocalVariableMap, RecompileStatus, boolean, boolean, long) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- recompileHopsDag(Hop, ExecutionContext, RecompileStatus, boolean, boolean, long) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- recompileHopsDag(Hop, LocalVariableMap, RecompileStatus, boolean, boolean, long) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- recompileHopsDag2Forced(StatementBlock, ArrayList<Hop>, long, LopProperties.ExecType) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- recompileHopsDag2Forced(Hop, long, LopProperties.ExecType) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- recompileHopsDagInstructions(StatementBlock, ArrayList<Hop>) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- recompileHopsDagInstructions(Hop) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- recompileProgramBlockHierarchy(ArrayList<ProgramBlock>, LocalVariableMap, long, Recompiler.ResetType) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- recompileProgramBlockHierarchy2Forced(ArrayList<ProgramBlock>, long, HashSet<String>, LopProperties.ExecType) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
Method to recompile program block hierarchy to forced execution time.
- recompileProgramBlockInstructions(ProgramBlock) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
This method does NO full program block recompile (no stats update, no rewrites, no recursion) but
only regenerates lops and instructions.
- recompileProgramBlocks(int, List<ProgramBlock>) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
- Recompiler - Class in org.apache.sysds.hops.recompile
-
Dynamic recompilation of hop dags to runtime instructions, which includes the
following substeps:
(1) deep copy hop dag, (2) refresh matrix characteristics, (3) apply
dynamic rewrites, (4) refresh memory estimates, (5) construct lops (incl
operator selection), and (6) generate runtime program (incl piggybacking).
- Recompiler() - Constructor for class org.apache.sysds.hops.recompile.Recompiler
-
- Recompiler.ResetType - Enum in org.apache.sysds.hops.recompile
-
- RecompileStatus - Class in org.apache.sysds.hops.recompile
-
- RecompileStatus() - Constructor for class org.apache.sysds.hops.recompile.RecompileStatus
-
- RecompileStatus(boolean) - Constructor for class org.apache.sysds.hops.recompile.RecompileStatus
-
- recomputeColumnCardinality() - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- recomputeIndexes(MatrixBlock, AggregateUnaryOperator, int, MatrixIndexes) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
-
Recompute outputs (e.g., maxindex or minindex) according to block indexes from MR.
- RecomputeNnzFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- RecomputeNnzFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.RecomputeNnzFunction
-
- recomputeNNZTime - Static variable in class org.apache.sysds.utils.Statistics
-
- recomputeNonZeros() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
Recomputes and materializes the number of non-zero values
of the entire basic tensor block.
- recomputeNonZeros() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Recomputes and materializes the number of non-zero values
of the entire matrix block.
- recomputeNonZeros(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- recomputeNonZeros(int, int, int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Recomputes the number of non-zero values of a specified
range of the matrix block.
- reconcileUpdatedCallVarsIf(LocalVariableMap, LocalVariableMap, LocalVariableMap, StatementBlock) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- reconcileUpdatedCallVarsIf(RecompileStatus, RecompileStatus, RecompileStatus, StatementBlock) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- reconcileUpdatedCallVarsLoops(LocalVariableMap, LocalVariableMap, StatementBlock) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- reconcileUpdatedCallVarsLoops(RecompileStatus, RecompileStatus, StatementBlock) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- ReduceAll - Class in org.apache.sysds.runtime.functionobjects
-
- ReduceCol - Class in org.apache.sysds.runtime.functionobjects
-
- ReduceDiag - Class in org.apache.sysds.runtime.functionobjects
-
- ReduceRow - Class in org.apache.sysds.runtime.functionobjects
-
- REF - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- refreshColsParameterInformation(Hop, LocalVariableMap) - Method in class org.apache.sysds.hops.Hop
-
- refreshColsParameterInformation(Hop, LocalVariableMap, HashMap<Long, Long>) - Method in class org.apache.sysds.hops.Hop
-
- refreshMemEstimates(MemoTable) - Method in class org.apache.sysds.hops.Hop
-
Recursively computes memory estimates for all the Hops in the DAG rooted at the
current hop pointed by this
.
- refreshMemEstimates(DMLProgram) - Static method in class org.apache.sysds.parser.DMLTranslator
-
- refreshMemEstimates(StatementBlock) - Static method in class org.apache.sysds.parser.DMLTranslator
-
- refreshMetaData() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- refreshMetaData() - Method in class org.apache.sysds.runtime.controlprogram.caching.FrameObject
-
- refreshMetaData() - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
Make the matrix metadata consistent with the in-memory matrix data
- refreshMetaData() - Method in class org.apache.sysds.runtime.controlprogram.caching.TensorObject
-
- refreshOutputParameters(Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- refreshRowsParameterInformation(Hop, LocalVariableMap) - Method in class org.apache.sysds.hops.Hop
-
- refreshRowsParameterInformation(Hop, LocalVariableMap, HashMap<Long, Long>) - Method in class org.apache.sysds.hops.Hop
-
- refreshSizeInformation() - Method in class org.apache.sysds.hops.AggBinaryOp
-
- refreshSizeInformation() - Method in class org.apache.sysds.hops.AggUnaryOp
-
- refreshSizeInformation() - Method in class org.apache.sysds.hops.BinaryOp
-
- refreshSizeInformation() - Method in class org.apache.sysds.hops.codegen.SpoofFusedOp
-
- refreshSizeInformation() - Method in class org.apache.sysds.hops.DataGenOp
-
- refreshSizeInformation() - Method in class org.apache.sysds.hops.DataOp
-
- refreshSizeInformation() - Method in class org.apache.sysds.hops.DnnOp
-
- refreshSizeInformation() - Method in class org.apache.sysds.hops.FunctionOp
-
- refreshSizeInformation() - Method in class org.apache.sysds.hops.Hop
-
Update the output size information for this hop.
- refreshSizeInformation() - Method in class org.apache.sysds.hops.IndexingOp
-
- refreshSizeInformation() - Method in class org.apache.sysds.hops.LeftIndexingOp
-
- refreshSizeInformation() - Method in class org.apache.sysds.hops.LiteralOp
-
- refreshSizeInformation() - Method in class org.apache.sysds.hops.NaryOp
-
- refreshSizeInformation() - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- refreshSizeInformation() - Method in class org.apache.sysds.hops.QuaternaryOp
-
- refreshSizeInformation() - Method in class org.apache.sysds.hops.ReorgOp
-
- refreshSizeInformation() - Method in class org.apache.sysds.hops.TernaryOp
-
- refreshSizeInformation() - Method in class org.apache.sysds.hops.UnaryOp
-
- REG_ALLOC_POLICY - Static variable in class org.apache.sysds.hops.codegen.SpoofCompiler
-
- ReIndexOperator - Class in org.apache.sysds.runtime.matrix.operators
-
- ReIndexOperator() - Constructor for class org.apache.sysds.runtime.matrix.operators.ReIndexOperator
-
- reinitRecompiler() - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
Re-initializes the recompiler according to the current optimizer flags.
- RelationalBinaryGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
- RelationalExpression - Class in org.apache.sysds.parser
-
- RelationalExpression(Expression.RelationalOp) - Constructor for class org.apache.sysds.parser.RelationalExpression
-
- RelationalExpression(Expression.RelationalOp, ParseInfo) - Constructor for class org.apache.sysds.parser.RelationalExpression
-
- RelationalExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.RelationalExpressionContext
-
- release() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
Releases the shared ("read-only") or exclusive ("write") lock.
- releaseCacheableData(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- releaseFrameInput(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
Unpins a currently pinned frame variable.
- releaseInput() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Releases input allocated on GPU
- releaseMatrixInput(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
Unpins a currently pinned matrix variable and update fine-grained statistics.
- releaseMatrixInput(String...) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- releaseMatrixInputForGPUInstruction(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- releaseMatrixInputs(CPOperand[]) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- releaseMatrixInputs(CPOperand[], boolean) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- releaseMatrixOutputForGPUInstruction(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- releaseOutput() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
releases output allocated on GPU
- releaseReadLock() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
- releaseTensorInput(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- releaseTensorInput(String...) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- releaseWriteLock() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
- relu(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNN
-
Performs the relu operation on the GPU.
- reluBackward(GPUContext, String, MatrixObject, MatrixObject, MatrixObject) - Static method in class org.apache.sysds.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.sysds.runtime.matrix.data.LibMatrixDNN
-
This method computes the backpropagation errors for previous layer of relu operation
- ReluBackward(int, int, DnnParameters) - Constructor for class org.apache.sysds.runtime.matrix.data.LibMatrixDNNRelu.ReluBackward
-
- RemoteDPParForSpark - Class in org.apache.sysds.runtime.controlprogram.parfor
-
TODO heavy hitter maintenance
TODO data partitioning with binarycell
- RemoteDPParForSpark() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.RemoteDPParForSpark
-
- RemoteDPParForSparkWorker - Class in org.apache.sysds.runtime.controlprogram.parfor
-
- RemoteDPParForSparkWorker(String, HashMap<String, byte[]>, String, String, boolean, DataCharacteristics, boolean, ParForProgramBlock.PartitionFormat, Types.FileFormat, LongAccumulator, LongAccumulator) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.RemoteDPParForSparkWorker
-
- RemoteParForJobReturn - Class in org.apache.sysds.runtime.controlprogram.parfor
-
Wrapper for job return of ParFor REMOTE for transferring statistics and result symbol table.
- RemoteParForJobReturn(boolean, int, int, LocalVariableMap[]) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForJobReturn
-
- RemoteParForJobReturn(boolean, int, int, LocalVariableMap[], Lineage[]) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForJobReturn
-
- RemoteParForSpark - Class in org.apache.sysds.runtime.controlprogram.parfor
-
This class serves two purposes: (1) isolating Spark imports to enable running in
environments where no Spark libraries are available, and (2) to follow the same
structure as the parfor remote_mr job submission.
- RemoteParForSpark() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForSpark
-
- RemoteParForSparkWorker - Class in org.apache.sysds.runtime.controlprogram.parfor
-
- RemoteParForSparkWorker(long, String, HashMap<String, byte[]>, boolean, LongAccumulator, LongAccumulator, Map<String, Broadcast<CacheBlock>>, boolean, Map<String, String>) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForSparkWorker
-
- RemoteParForUtils - Class in org.apache.sysds.runtime.controlprogram.parfor
-
Common functionalities for parfor workers in MR jobs.
- RemoteParForUtils() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForUtils
-
- remove(Hop, Set<CPlanMemoTable.MemoTableEntry>) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- remove(Hop, TemplateBase.TemplateType) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- remove(PlanningCoCodingGroup) - Method in class org.apache.sysds.runtime.compress.cocode.PlanningMemoTable
-
- remove(String) - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
-
- remove(int) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- remove() - Method in class org.apache.sysds.runtime.instructions.spark.data.LazyIterableIterator
-
- removeAll() - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
-
- removeAllChildReferences(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- removeAllConstraints() - Method in interface org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacy
-
Remove all fine-grained privacy constraints.
- removeAllConstraints() - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyList
-
- removeAllConstraints() - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyMap
-
- removeAllIn(Set<String>) - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
-
- removeAllNotIn(Set<String>) - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
-
- removeAllRefTo(long) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- removeAllRefTo(long, TemplateBase.TemplateType) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- removeChildReference(Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- removeChildReferenceByPos(Hop, Hop, int) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- removeConsumer() - Method in class org.apache.sysds.lops.Lop
-
- removeCPMemObject(int) - Static method in class org.apache.sysds.utils.Statistics
-
Helper method to remove a memory object which has become unpinned
- removeEmpty(MatrixBlock, int, int) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DRRLocalScheme
-
- removeEmptyOperations(MatrixBlock, boolean, boolean, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- removeEmptyOperations(MatrixBlock, boolean, boolean) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- removeEmptyOperations(MatrixBlock, boolean, boolean, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- removeEmptyOperations(MatrixBlock, boolean, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- removeFunction(String) - Method in class org.apache.sysds.parser.FunctionDictionary
-
- removeFunctionCall(String, FunctionOp, StatementBlock) - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Removes a single function call identified by target function name,
and source function op and statement block.
- removeFunctionCalls(String) - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Removes all calls of the given function.
- removeFunctionProgramBlock(String, String) - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- removeFunctionStatementBlock(String) - Method in class org.apache.sysds.parser.DMLProgram
-
- removeFunctionStatementBlock(String, String) - Method in class org.apache.sysds.parser.DMLProgram
-
- removeGPUObject(GPUObject) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryManager
-
Removes the GPU object from the memory manager
- removeHopRewrite(Class<? extends HopRewriteRule>) - Method in class org.apache.sysds.hops.rewrite.ProgramRewriter
-
- removeIfPresent(long, Pointer) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
-
Remove a specific pointer if present in the internal hashmap
- removeInput(String) - Method in class org.apache.sysds.hops.DataOp
-
Remove an input from the list of inputs and from the parameter index map.
- removeMetaData() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- removeMetaData() - Method in class org.apache.sysds.runtime.instructions.cp.Data
-
- removeStatementBlockRewrite(Class<? extends StatementBlockRewriteRule>) - Method in class org.apache.sysds.hops.rewrite.ProgramRewriter
-
- removeUpdatedScalars(LocalVariableMap, StatementBlock) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
Remove any scalar variables from the variable map if the variable
is updated in this block.
- removeVariable(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- removeVariables(VariableSet) - Method in class org.apache.sysds.parser.VariableSet
-
- removeVarParam(String) - Method in class org.apache.sysds.parser.DataExpression
-
- removeVarParam(String...) - Method in class org.apache.sysds.parser.DataExpression
-
- renameFileOnHDFS(String, String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
-
- renameInputs() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- renameInputs() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
-
- renameInputs() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeOuterProduct
-
- renameInputs() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
-
- renameInputs() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
-
- reorg(MatrixBlock, MatrixBlock, ReorgOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
- reorg(DataCharacteristics, ReorgOperator, DataCharacteristics) - Static method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- ReorgCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- ReorgFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
-
- ReorgFEDInstruction(CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysds.runtime.instructions.fed.ReorgFEDInstruction
-
- ReorgGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
- ReorgMapFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- ReorgMapFunction(String) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.ReorgMapFunction
-
- ReorgOp - Class in org.apache.sysds.hops
-
Reorg (cell) operation: aij
Properties:
Symbol: ', rdiag, rshape, rsort
1 Operand (except sort and reshape take additional arguments)
Semantic: change indices (in mapper or reducer)
NOTE MB: reshape integrated here because (1) ParameterizedBuiltinOp requires name-value pairs for params
and (2) most importantly semantic of reshape is exactly a reorg op.
- ReorgOp(String, Types.DataType, Types.ValueType, Types.ReOrgOp, Hop) - Constructor for class org.apache.sysds.hops.ReorgOp
-
- ReorgOp(String, Types.DataType, Types.ValueType, Types.ReOrgOp, ArrayList<Hop>) - Constructor for class org.apache.sysds.hops.ReorgOp
-
- reorgOperations(ReorgOperator, MatrixValue, int, int, int) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- reorgOperations(ReorgOperator, MatrixValue, int, int, int) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- reorgOperations(ReorgOperator, MatrixValue, int, int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- reorgOperations(ReorgOperator, MatrixValue, int, int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- reorgOperations(ReorgOperator, MatrixValue, int, int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- reorgOperations(ReorgOperator, MatrixValue, int, int, int) - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
-
- ReorgOperator - Class in org.apache.sysds.runtime.matrix.operators
-
- ReorgOperator(IndexFunction) - Constructor for class org.apache.sysds.runtime.matrix.operators.ReorgOperator
-
- ReorgOperator(IndexFunction, int) - Constructor for class org.apache.sysds.runtime.matrix.operators.ReorgOperator
-
- ReorgSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- repartitionAndCacheMatrixObject(String) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- replace(LineageItem, LineageItem, LineageItem) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
-
- replaceChildReference(Hop, Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- replaceChildReference(Hop, Hop, Hop, int) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- replaceChildReference(Hop, Hop, Hop, int, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- replaceConstantScalarVariables(StatementBlock, LocalVariableMap) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.ProgramRecompiler
-
- replaceDagLeaves(ExecutionContext, LineageItem, CPOperand[]) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
-
- replaceFunctionCalls(String, String) - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
-
Replaces a function call to fkeyOld with a call to fkey,
but using the function op and statement block from the old.
- replaceLineage(ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageDedupUtils
-
- replaceMapping(ProgramBlock, OptNode) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingAbstract
-
- replaceMapping(ProgramBlock, OptNode) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingRuntime
-
- replaceOperand(String, int, String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- replaceOperandName(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
-
- replaceOperations(MatrixValue, double, double) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- replaceOperations(MatrixValue, double, double) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- replaceOperations(MatrixValue, double, double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- replaceOperations(MatrixValue, double, double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- replaceOperations(MatrixValue, double, double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- replaceProgramBlock(OptNode, OptNode, ProgramBlock, ProgramBlock, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
-
- replaceProgramBlock(List<ProgramBlock>, ProgramBlock, ProgramBlock) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
-
- ReplicateBlockFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- ReplicateBlockFunction(long, long, boolean) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.ReplicateBlockFunction
-
- ReplicateBlockFunction(long, long, boolean, boolean) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.ReplicateBlockFunction
-
- ReplicateRightFactorFunction(long, long) - Constructor for class org.apache.sysds.runtime.instructions.spark.SpoofSPInstruction.ReplicateRightFactorFunction
-
- ReplicateTensorFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- ReplicateTensorFunction(int, long) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.ReplicateTensorFunction
-
- ReplicateVectorFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- ReplicateVectorFunction(boolean, long) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.ReplicateVectorFunction
-
- requestFederatedData() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- requiredCastDtm() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- requiresCheckpoint() - Method in class org.apache.sysds.hops.Hop
-
- requiresCompression() - Method in class org.apache.sysds.hops.Hop
-
- requiresCorrection() - Method in class org.apache.sysds.runtime.functionobjects.KahanFunction
-
- requiresCorrection() - Method in class org.apache.sysds.runtime.functionobjects.ValueFunction
-
- requiresFromRecompilation() - Method in class org.apache.sysds.parser.ForStatementBlock
-
- requiresIncrementRecompilation() - Method in class org.apache.sysds.parser.ForStatementBlock
-
- requiresLabelUpdate() - Method in class org.apache.sysds.runtime.instructions.cp.CPInstruction
-
- requiresLabelUpdate() - Method in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
-
- requiresLabelUpdate() - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- requiresLabelUpdate() - Method in class org.apache.sysds.runtime.instructions.spark.SPInstruction
-
- requiresLineageCaching() - Method in class org.apache.sysds.hops.Hop
-
- requiresOutputCreateVar() - Method in class org.apache.sysds.lops.FunctionCallCP
-
- requiresPredicateRecompilation() - Method in class org.apache.sysds.parser.IfStatementBlock
-
- requiresPredicateRecompilation() - Method in class org.apache.sysds.parser.WhileStatementBlock
-
- requiresReblock() - Method in class org.apache.sysds.hops.Hop
-
- requiresRecompilation(ArrayList<Hop>) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- requiresRecompilation(Hop) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- requiresRecompilation() - Method in class org.apache.sysds.parser.StatementBlock
-
- requiresRecompile() - Method in class org.apache.sysds.hops.Hop
-
Indicates if dynamic recompilation is required for this hop.
- requiresReplication(Hop, Hop) - Static method in class org.apache.sysds.hops.BinaryOp
-
- requiresToRecompilation() - Method in class org.apache.sysds.parser.ForStatementBlock
-
- reserveAllGPUContexts() - Static method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContextPool
-
Reserves and gets an initialized list of GPUContexts
- reset() - Method in class org.apache.sysds.hops.estim.MMNode
-
- reset() - Method in class org.apache.sysds.runtime.codegen.SpoofOperator.SideInput
-
- reset() - Method in class org.apache.sysds.runtime.codegen.SpoofOperator.SideInputSparseCell
-
- reset() - Method in class org.apache.sysds.runtime.compress.ReaderColumnSelection
-
Resets the reader to the first row.
- reset() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
-
- reset() - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.IDSequence
-
- reset(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.IDSequence
-
- reset() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- reset(int[]) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- reset(int[], long) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- reset(int[], boolean) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- reset(int[], boolean, long) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- reset() - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- reset(int[]) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- reset(int[], Types.ValueType[]) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- reset() - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Resets the dense block by deleting non-zero values.
- reset(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Resets the dense block by deleting non-zero values.
- reset(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Resets the dense block by deleting non-zeros.
- reset(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Resets the dense block by deleting non-zeros.
- reset(int, int[]) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Resets the dense block by deleting non-zeros.
- reset(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Resets the dense block by setting the given value.
- reset(int, int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Resets the dense block by setting the given value.
- reset(int, int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- reset(int, int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
-
- reset(int, int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- reset(int, int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
-
- reset(int, int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
-
- reset() - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Clears the sparse block by deleting non-zero values.
- reset(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Clears the sparse block by deleting non-zero values.
- reset(int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Clears row r of the sparse block by deleting non-zero values.
- reset() - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- reset(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- reset(int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- reset() - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- reset(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- reset(int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- reset() - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- reset(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- reset(int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- reset(int, int) - Method in class org.apache.sysds.runtime.data.SparseRow
-
Resets the sparse row to empty, after this call size and
isEmpty are guaranteed to return 0 and true, respectively.
- reset(int, int) - Method in class org.apache.sysds.runtime.data.SparseRowScalar
-
- reset(int, int) - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- reset() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
Reset all cells to 0.
- reset(int[]) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
Reset data with new dimensions.
- reset() - Method in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
- reset() - Method in class org.apache.sysds.runtime.io.ReaderTextCellParallel.CellBuffer
-
- reset() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
-
- reset() - Static method in class org.apache.sysds.runtime.lineage.LineageCodegenItem
-
- reset() - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- reset(int, int) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- reset(int, int, boolean) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- reset(int, int, boolean, long) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- reset(int, int, double) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- reset(int, boolean) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- reset() - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- reset() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- reset(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- reset(int, int, long) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- reset(int, int, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- reset(int, int, boolean, long) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- reset(int, int, double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- reset() - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- reset(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- reset(int, int, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- reset(int, int, boolean, long) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- reset(int, int, double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- reset() - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- reset(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- reset(int, int, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- reset(int, int, boolean, long) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- reset(int, int, double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- reset() - Static method in class org.apache.sysds.runtime.privacy.CheckedConstraintsLog
-
Remove all elements from checked constraints log and loaded constraints log.
- reset(String) - Method in class org.apache.sysds.runtime.util.FastStringTokenizer
-
- reset() - Static method in class org.apache.sysds.utils.GPUStatistics
-
Resets all the cuda counters and timers, including the misc timers & counters
- reset() - Static method in class org.apache.sysds.utils.Statistics
-
- RESET_RECOMPILATION_FLAGs - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- resetCache() - Static method in class org.apache.sysds.runtime.lineage.LineageCache
-
- resetConfig() - Method in interface org.apache.sysds.api.ConfigurableAPI
-
Reset configuration settings to default settings.
- resetConfig() - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
- resetConfig() - Method in class org.apache.sysds.api.mlcontext.MLContext
-
- resetCPHeavyHitters() - Static method in class org.apache.sysds.utils.Statistics
-
- resetDedupPath() - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- resetDefaultSize() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- resetExecType() - Method in class org.apache.sysds.hops.Hop
-
- resetFedDataID() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
-
- resetFederatedSites() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
-
- resetFloatingPointPrecision() - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Sets the internal state based on the DMLScript.DATA_TYPE
- resetGenerated() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- resetHash() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- resetHopsDAGVisitStatus(DMLProgram) - Static method in class org.apache.sysds.parser.DMLTranslator
-
- resetHopsDAGVisitStatus(StatementBlock) - Static method in class org.apache.sysds.parser.DMLTranslator
-
- resetIDSequence() - Static method in class org.apache.sysds.runtime.lineage.LineageItem
-
- resetInternalState() - Static method in class org.apache.sysds.runtime.lineage.Lineage
-
- resetJITCompileTime() - Static method in class org.apache.sysds.utils.Statistics
-
- resetJVMgcCount() - Static method in class org.apache.sysds.utils.Statistics
-
- resetJVMgcTime() - Static method in class org.apache.sysds.utils.Statistics
-
- resetLineageMaps() - Method in class org.apache.sysds.runtime.lineage.LineageMap
-
- resetLopsDAGVisitStatus(DMLProgram) - Method in class org.apache.sysds.parser.DMLTranslator
-
- resetLopsDAGVisitStatus(StatementBlock) - Method in class org.apache.sysds.parser.DMLTranslator
-
- resetMiscTimers() - Static method in class org.apache.sysds.utils.GPUStatistics
-
Resets the miscellaneous timers & counters
- resetNoOfCompiledJobs(int) - Static method in class org.apache.sysds.utils.Statistics
-
- resetNoOfExecutedJobs() - Static method in class org.apache.sysds.utils.Statistics
-
- resetOutputMatrix(MatrixIndexes, MatrixBlock, MatrixIndexes, MatrixBlock, AggregateUnaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixOuterAgg
-
ReSet output matrix
- resetPath() - Method in class org.apache.sysds.runtime.lineage.LineageDedupBlock
-
- resetReadWriteLock() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
- resetRecompilationFlag(ArrayList<Hop>, LopProperties.ExecType, Recompiler.ResetType) - Static method in class org.apache.sysds.hops.Hop
-
- resetRecompilationFlag(Hop, LopProperties.ExecType, Recompiler.ResetType) - Static method in class org.apache.sysds.hops.Hop
-
- resetReusableOpcodes() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- resetSparkContextStatic() - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- resetStaticCompilerFlags() - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- resetStatistics() - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNN
-
- resetVisitStatus() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- resetVisitStatus(List<CNode>) - Static method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
-
- resetVisitStatus(ArrayList<Hop>) - Static method in class org.apache.sysds.hops.Hop
-
- resetVisitStatus(ArrayList<Hop>, boolean) - Static method in class org.apache.sysds.hops.Hop
-
- resetVisitStatus() - Method in class org.apache.sysds.hops.Hop
-
- resetVisitStatus() - Method in class org.apache.sysds.lops.Lop
-
- resetVisitStatus() - Method in class org.apache.sysds.runtime.lineage.LineageItem
-
Deprecated.
- resetVisitStatus(LineageItem[]) - Static method in class org.apache.sysds.runtime.lineage.LineageItem
-
Deprecated.
- resetVisitStatusForced(HashSet<Long>) - Method in class org.apache.sysds.hops.Hop
-
- resetVisitStatusNR() - Method in class org.apache.sysds.runtime.lineage.LineageItem
-
- resetVisitStatusNR(LineageItem[]) - Static method in class org.apache.sysds.runtime.lineage.LineageItem
-
- resetVisitStatusOutputs() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
-
- resetVisitStatusOutputs() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
-
- resetWorkerIDs() - Static method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- reshape(BasicTensorBlock, BasicTensorBlock, int[]) - Static method in class org.apache.sysds.runtime.data.LibTensorReorg
-
CP reshape operation (single input, single output tensor)
- reshape(IndexedTensorBlock, DataCharacteristics, DataCharacteristics, boolean, boolean) - Static method in class org.apache.sysds.runtime.data.LibTensorReorg
-
MR/SPARK reshape interface - for reshape we cannot view blocks independently, and hence,
there are different CP and MR interfaces.
- reshape(MatrixBlock, MatrixBlock, int, int, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
CP reshape operation (single input, single output matrix)
NOTE: In contrast to R, the rowwise parameter specifies both
the read and write order, with row-wise being the default, while
R uses always a column-wise read, rowwise specifying the write
order and column-wise being the default.
- reshape(IndexedMatrixValue, DataCharacteristics, DataCharacteristics, boolean, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
MR/SPARK reshape interface - for reshape we cannot view blocks independently, and hence,
there are different CP and MR interfaces.
- RESHAPE_VALID_PARAM_NAMES - Static variable in class org.apache.sysds.parser.DataExpression
-
- ReshapeCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- restartReuse(LineageCacheConfig.ReuseCacheType) - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- Result(List<MatrixObject>, List<MatrixObject>) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionLocalScheme.Result
-
- RESULT_MERGE - Static variable in class org.apache.sysds.parser.ParForStatementBlock
-
- ResultMerge - Class in org.apache.sysds.runtime.controlprogram.parfor
-
Due to independence of all iterations, any result has the following properties:
(1) non local var, (2) matrix object, and (3) completely independent.
- ResultMerge(MatrixObject, MatrixObject[], String, boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.ResultMerge
-
- ResultMergeLocalAutomatic - Class in org.apache.sysds.runtime.controlprogram.parfor
-
- ResultMergeLocalAutomatic(MatrixObject, MatrixObject[], String, boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeLocalAutomatic
-
- ResultMergeLocalFile - Class in org.apache.sysds.runtime.controlprogram.parfor
-
TODO potential extension: parallel merge (create individual staging files concurrently)
NOTE: file merge typically used due to memory constraints - parallel merge would increase the memory
consumption again.
- ResultMergeLocalFile(MatrixObject, MatrixObject[], String, boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeLocalFile
-
- ResultMergeLocalMemory - Class in org.apache.sysds.runtime.controlprogram.parfor
-
Local in-memory realization of result merge.
- ResultMergeLocalMemory(MatrixObject, MatrixObject[], String, boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeLocalMemory
-
- ResultMergeRemoteGrouping - Class in org.apache.sysds.runtime.controlprogram.parfor
-
- ResultMergeRemoteSorting - Class in org.apache.sysds.runtime.controlprogram.parfor
-
- ResultMergeRemoteSpark - Class in org.apache.sysds.runtime.controlprogram.parfor
-
- ResultMergeRemoteSpark(MatrixObject, MatrixObject[], String, boolean, ExecutionContext, int, int) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeRemoteSpark
-
- ResultMergeRemoteSparkWCompare - Class in org.apache.sysds.runtime.controlprogram.parfor
-
- ResultMergeRemoteSparkWCompare(boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeRemoteSparkWCompare
-
- ResultMergeTaggedMatrixIndexes - Class in org.apache.sysds.runtime.controlprogram.parfor
-
This class serves as composite key for the remote result merge job
(for any data format) in order to sort on both matrix indexes and tag
but group all blocks according to matrix indexes only.
- ResultMergeTaggedMatrixIndexes() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeTaggedMatrixIndexes
-
- results() - Method in class org.apache.sysds.api.mlcontext.Script
-
Obtain the results of the script execution.
- resultValueType(Types.ValueType, Types.ValueType) - Static method in class org.apache.sysds.runtime.data.TensorBlock
-
- ResultVar(String, boolean) - Constructor for class org.apache.sysds.parser.ParForStatementBlock.ResultVar
-
- ResultVariables - Class in org.apache.sysds.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.sysds.api.jmlc.ResultVariables
-
- reuse(Instruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageCache
-
- reuse(List<String>, List<DataIdentifier>, int, LineageItem[], String, ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageCache
-
- reuseVariables(long, LocalVariableMap, Collection<String>, Map<String, Broadcast<CacheBlock>>, boolean) - Method in class org.apache.sysds.runtime.controlprogram.parfor.CachedReuseVariables
-
- rev(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
- rev(IndexedMatrixValue, long, int, ArrayList<IndexedMatrixValue>) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
- rEvalSimpleDoubleExpression(Hop, HashMap<Long, Double>) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- rEvalSimpleDoubleExpression(Hop, HashMap<Long, Double>, LocalVariableMap) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- rEvalSimpleLongExpression(Hop, HashMap<Long, Long>) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
Function to evaluate simple size expressions over literals and now/ncol.
- rEvalSimpleLongExpression(Hop, HashMap<Long, Long>, LocalVariableMap) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- RevIndex - Class in org.apache.sysds.runtime.functionobjects
-
- rewireAllParentChildReferences(Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
Replace an old Hop with a replacement Hop.
- RewriteAlgebraicSimplificationDynamic - Class in org.apache.sysds.hops.rewrite
-
Rule: Algebraic Simplifications.
- RewriteAlgebraicSimplificationDynamic() - Constructor for class org.apache.sysds.hops.rewrite.RewriteAlgebraicSimplificationDynamic
-
- RewriteAlgebraicSimplificationStatic - Class in org.apache.sysds.hops.rewrite
-
Rule: Algebraic Simplifications.
- RewriteAlgebraicSimplificationStatic() - Constructor for class org.apache.sysds.hops.rewrite.RewriteAlgebraicSimplificationStatic
-
- RewriteBlockSizeAndReblock - Class in org.apache.sysds.hops.rewrite
-
Rule: BlockSizeAndReblock.
- RewriteBlockSizeAndReblock() - Constructor for class org.apache.sysds.hops.rewrite.RewriteBlockSizeAndReblock
-
- RewriteCommonSubexpressionElimination - Class in org.apache.sysds.hops.rewrite
-
Rule: CommonSubexpressionElimination.
- RewriteCommonSubexpressionElimination() - Constructor for class org.apache.sysds.hops.rewrite.RewriteCommonSubexpressionElimination
-
- RewriteCommonSubexpressionElimination(boolean) - Constructor for class org.apache.sysds.hops.rewrite.RewriteCommonSubexpressionElimination
-
- RewriteCompressedReblock - Class in org.apache.sysds.hops.rewrite
-
Rule: CompressedReblock: If config compressed.linalg is enabled, we
inject compression directions after pread of matrices w/ both dims > 1
(i.e., multi-column matrices).
- RewriteCompressedReblock() - Constructor for class org.apache.sysds.hops.rewrite.RewriteCompressedReblock
-
- RewriteConstantFolding - Class in org.apache.sysds.hops.rewrite
-
Rule: Constant Folding.
- RewriteConstantFolding() - Constructor for class org.apache.sysds.hops.rewrite.RewriteConstantFolding
-
- RewriteElementwiseMultChainOptimization - Class in org.apache.sysds.hops.rewrite
-
Prerequisite: RewriteCommonSubexpressionElimination must run before this rule.
- RewriteElementwiseMultChainOptimization() - Constructor for class org.apache.sysds.hops.rewrite.RewriteElementwiseMultChainOptimization
-
- rewriteExpression(String) - Method in class org.apache.sysds.parser.BinaryExpression
-
- rewriteExpression(String) - Method in class org.apache.sysds.parser.BooleanExpression
-
- rewriteExpression(String) - Method in class org.apache.sysds.parser.BooleanIdentifier
-
- rewriteExpression(String) - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- rewriteExpression(String) - Method in class org.apache.sysds.parser.DataExpression
-
- rewriteExpression(String) - Method in class org.apache.sysds.parser.DataIdentifier
-
- rewriteExpression(String) - Method in class org.apache.sysds.parser.DoubleIdentifier
-
- rewriteExpression(String) - Method in class org.apache.sysds.parser.Expression
-
- rewriteExpression(String) - Method in class org.apache.sysds.parser.ExpressionList
-
- rewriteExpression(String) - Method in class org.apache.sysds.parser.FunctionCallIdentifier
-
- rewriteExpression(String) - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- rewriteExpression(String) - Method in class org.apache.sysds.parser.IntIdentifier
-
- rewriteExpression(String) - Method in class org.apache.sysds.parser.IterablePredicate
-
- rewriteExpression(String) - Method in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- rewriteExpression(String) - Method in class org.apache.sysds.parser.RelationalExpression
-
- rewriteExpression(String) - Method in class org.apache.sysds.parser.StringIdentifier
-
- RewriteForLoopVectorization - Class in org.apache.sysds.hops.rewrite
-
Rule: Simplify program structure by pulling if or else statement body out
(removing the if statement block ifself) in order to allow intra-procedure
analysis to propagate exact statistics.
- RewriteForLoopVectorization() - Constructor for class org.apache.sysds.hops.rewrite.RewriteForLoopVectorization
-
- rewriteFunctionCallStatements(DMLProgram, ArrayList<Statement>) - Method in class org.apache.sysds.parser.StatementBlock
-
- RewriteGPUSpecificOps - Class in org.apache.sysds.hops.rewrite
-
- RewriteGPUSpecificOps() - Constructor for class org.apache.sysds.hops.rewrite.RewriteGPUSpecificOps
-
- RewriteHoistLoopInvariantOperations - Class in org.apache.sysds.hops.rewrite
-
Rule: Simplify program structure by hoisting loop-invariant operations
out of while, for, or parfor loops.
- RewriteHoistLoopInvariantOperations() - Constructor for class org.apache.sysds.hops.rewrite.RewriteHoistLoopInvariantOperations
-
- RewriteHoistLoopInvariantOperations(boolean) - Constructor for class org.apache.sysds.hops.rewrite.RewriteHoistLoopInvariantOperations
-
- rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.HopRewriteRule
-
Handle a predicate hop DAG with exactly one root.
- rewriteHopDAG(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.ProgramRewriter
-
- rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.ProgramRewriter
-
- rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteAlgebraicSimplificationDynamic
-
- rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteAlgebraicSimplificationStatic
-
- rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteBlockSizeAndReblock
-
- rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteCommonSubexpressionElimination
-
- rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteConstantFolding
-
- rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteElementwiseMultChainOptimization
-
- rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteGPUSpecificOps
-
- rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteIndexingVectorization
-
- rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteInjectSparkPReadCheckpointing
-
- rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteMatrixMultChainOptimization
-
- rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteRemoveDanglingParentReferences
-
- rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteRemovePersistentReadWrite
-
- rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteRemoveReadAfterWrite
-
- rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteRemoveUnnecessaryCasts
-
- rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteTransientWriteParentHandling
-
- rewriteHopDAGs(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.HopRewriteRule
-
Handle a generic (last-level) hop DAG with multiple roots.
- rewriteHopDAGs(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteAlgebraicSimplificationDynamic
-
- rewriteHopDAGs(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteAlgebraicSimplificationStatic
-
- rewriteHopDAGs(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteBlockSizeAndReblock
-
- rewriteHopDAGs(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteCommonSubexpressionElimination
-
- rewriteHopDAGs(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteConstantFolding
-
- rewriteHopDAGs(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteElementwiseMultChainOptimization
-
- rewriteHopDAGs(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteGPUSpecificOps
-
- rewriteHopDAGs(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteIndexingVectorization
-
- rewriteHopDAGs(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteInjectSparkPReadCheckpointing
-
- rewriteHopDAGs(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteMatrixMultChainOptimization
-
- rewriteHopDAGs(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteRemoveDanglingParentReferences
-
- rewriteHopDAGs(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteRemovePersistentReadWrite
-
- rewriteHopDAGs(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteRemoveReadAfterWrite
-
- rewriteHopDAGs(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteRemoveUnnecessaryCasts
-
- rewriteHopDAGs(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteTransientWriteParentHandling
-
- rewriteHopDAGsFunction(FunctionStatementBlock, boolean) - Method in class org.apache.sysds.hops.rewrite.ProgramRewriter
-
- rewriteHopDAGsFunction(FunctionStatementBlock, ProgramRewriteStatus, boolean) - Method in class org.apache.sysds.hops.rewrite.ProgramRewriter
-
- rewriteHopsDAG(DMLProgram) - Method in class org.apache.sysds.parser.DMLTranslator
-
- RewriteIndexingVectorization - Class in org.apache.sysds.hops.rewrite
-
Rule: Indexing vectorization.
- RewriteIndexingVectorization() - Constructor for class org.apache.sysds.hops.rewrite.RewriteIndexingVectorization
-
- RewriteInjectSparkLoopCheckpointing - Class in org.apache.sysds.hops.rewrite
-
Rule: Insert checkpointing operations for caching purposes.
- RewriteInjectSparkLoopCheckpointing(boolean) - Constructor for class org.apache.sysds.hops.rewrite.RewriteInjectSparkLoopCheckpointing
-
- RewriteInjectSparkPReadCheckpointing - Class in org.apache.sysds.hops.rewrite
-
Rule: BlockSizeAndReblock.
- RewriteInjectSparkPReadCheckpointing() - Constructor for class org.apache.sysds.hops.rewrite.RewriteInjectSparkPReadCheckpointing
-
- RewriteMarkLoopVariablesUpdateInPlace - Class in org.apache.sysds.hops.rewrite
-
Rule: Mark loop variables that are only read/updated through cp left indexing
for update in-place.
- RewriteMarkLoopVariablesUpdateInPlace() - Constructor for class org.apache.sysds.hops.rewrite.RewriteMarkLoopVariablesUpdateInPlace
-
- RewriteMatrixMultChainOptimization - Class in org.apache.sysds.hops.rewrite
-
Rule: Determine the optimal order of execution for a chain of
matrix multiplications
Solution: Classic Dynamic Programming
Approach: Currently, the approach based only on matrix dimensions
Goal: To reduce the number of computations in the run-time
(map-reduce) layer
- RewriteMatrixMultChainOptimization() - Constructor for class org.apache.sysds.hops.rewrite.RewriteMatrixMultChainOptimization
-
- RewriteMatrixMultChainOptimizationSparse - Class in org.apache.sysds.hops.rewrite
-
Rule: Determine the optimal order of execution for a chain of
matrix multiplications
Solution: Classic Dynamic Programming
Approach: Currently, the approach based only on matrix dimensions
and sparsity estimates using the MNC sketch
Goal: To reduce the number of computations in the run-time
(map-reduce) layer
- RewriteMatrixMultChainOptimizationSparse() - Constructor for class org.apache.sysds.hops.rewrite.RewriteMatrixMultChainOptimizationSparse
-
- RewriteMergeBlockSequence - Class in org.apache.sysds.hops.rewrite
-
Rule: Simplify program structure by merging sequences of last-level
statement blocks in order to create optimization opportunities.
- RewriteMergeBlockSequence() - Constructor for class org.apache.sysds.hops.rewrite.RewriteMergeBlockSequence
-
- rewriteProgram(DMLProgram, FunctionCallGraph, FunctionCallSizeInfo) - Method in class org.apache.sysds.hops.ipa.IPAPass
-
Rewrites the given program or its functions in place,
with access to the read-only function call graph.
- rewriteProgram(DMLProgram, FunctionCallGraph, FunctionCallSizeInfo) - Method in class org.apache.sysds.hops.ipa.IPAPassApplyStaticAndDynamicHopRewrites
-
- rewriteProgram(DMLProgram, FunctionCallGraph, FunctionCallSizeInfo) - Method in class org.apache.sysds.hops.ipa.IPAPassEliminateDeadCode
-
- rewriteProgram(DMLProgram, FunctionCallGraph, FunctionCallSizeInfo) - Method in class org.apache.sysds.hops.ipa.IPAPassFlagFunctionsRecompileOnce
-
- rewriteProgram(DMLProgram, FunctionCallGraph, FunctionCallSizeInfo) - Method in class org.apache.sysds.hops.ipa.IPAPassFlagNonDeterminism
-
- rewriteProgram(DMLProgram, FunctionCallGraph, FunctionCallSizeInfo) - Method in class org.apache.sysds.hops.ipa.IPAPassForwardFunctionCalls
-
- rewriteProgram(DMLProgram, FunctionCallGraph, FunctionCallSizeInfo) - Method in class org.apache.sysds.hops.ipa.IPAPassInlineFunctions
-
- rewriteProgram(DMLProgram, FunctionCallGraph, FunctionCallSizeInfo) - Method in class org.apache.sysds.hops.ipa.IPAPassPropagateReplaceLiterals
-
- rewriteProgram(DMLProgram, FunctionCallGraph, FunctionCallSizeInfo) - Method in class org.apache.sysds.hops.ipa.IPAPassRemoveConstantBinaryOps
-
- rewriteProgram(DMLProgram, FunctionCallGraph, FunctionCallSizeInfo) - Method in class org.apache.sysds.hops.ipa.IPAPassRemoveUnnecessaryCheckpoints
-
- rewriteProgram(DMLProgram, FunctionCallGraph, FunctionCallSizeInfo) - Method in class org.apache.sysds.hops.ipa.IPAPassRemoveUnusedFunctions
-
- rewriteProgramHopDAGs(DMLProgram) - Method in class org.apache.sysds.hops.rewrite.ProgramRewriter
-
- rewriteProgramHopDAGs(DMLProgram, boolean) - Method in class org.apache.sysds.hops.rewrite.ProgramRewriter
-
- rewriteProgramHopDAGs(DMLProgram, boolean, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.ProgramRewriter
-
- RewriteRemoveDanglingParentReferences - Class in org.apache.sysds.hops.rewrite
-
This rewrite is a general-purpose cleanup pass that removes any
dangling parent references in one pass through the hop DAG.
- RewriteRemoveDanglingParentReferences() - Constructor for class org.apache.sysds.hops.rewrite.RewriteRemoveDanglingParentReferences
-
- RewriteRemoveEmptyBasicBlocks - Class in org.apache.sysds.hops.rewrite
-
Rule: Simplify program structure by removing empty last-level blocks,
which may originate from the original program or due to a sequence of
rewrites (e.g., checkpoint injection and subsequent IPA).
- RewriteRemoveEmptyBasicBlocks() - Constructor for class org.apache.sysds.hops.rewrite.RewriteRemoveEmptyBasicBlocks
-
- RewriteRemovePersistentReadWrite - Class in org.apache.sysds.hops.rewrite
-
This rewrite is a custom rewrite for JMLC in order to replace all persistent reads
and writes with transient reads and writes from the symbol table.
- RewriteRemovePersistentReadWrite(String[], String[]) - Constructor for class org.apache.sysds.hops.rewrite.RewriteRemovePersistentReadWrite
-
- RewriteRemovePersistentReadWrite(String[], String[], LocalVariableMap) - Constructor for class org.apache.sysds.hops.rewrite.RewriteRemovePersistentReadWrite
-
- RewriteRemoveReadAfterWrite - Class in org.apache.sysds.hops.rewrite
-
Rule: RemoveReadAfterWrite.
- RewriteRemoveReadAfterWrite() - Constructor for class org.apache.sysds.hops.rewrite.RewriteRemoveReadAfterWrite
-
- RewriteRemoveUnnecessaryBranches - Class in org.apache.sysds.hops.rewrite
-
Rule: Simplify program structure by pulling if or else statement body out
(removing the if statement block ifself) in order to allow intra-procedure
analysis to propagate exact statistics.
- RewriteRemoveUnnecessaryBranches() - Constructor for class org.apache.sysds.hops.rewrite.RewriteRemoveUnnecessaryBranches
-
- RewriteRemoveUnnecessaryCasts - Class in org.apache.sysds.hops.rewrite
-
Rule: RemoveUnnecessaryCasts.
- RewriteRemoveUnnecessaryCasts() - Constructor for class org.apache.sysds.hops.rewrite.RewriteRemoveUnnecessaryCasts
-
- RewriteSplitDagDataDependentOperators - Class in org.apache.sysds.hops.rewrite
-
Rule: Split Hop DAG after specific data-dependent operators.
- RewriteSplitDagDataDependentOperators() - Constructor for class org.apache.sysds.hops.rewrite.RewriteSplitDagDataDependentOperators
-
- RewriteSplitDagUnknownCSVRead - Class in org.apache.sysds.hops.rewrite
-
Rule: Split Hop DAG after CSV reads with unknown size.
- RewriteSplitDagUnknownCSVRead() - Constructor for class org.apache.sysds.hops.rewrite.RewriteSplitDagUnknownCSVRead
-
- rewriteStatement(String) - Method in class org.apache.sysds.parser.AssignmentStatement
-
- rewriteStatement(String) - Method in class org.apache.sysds.parser.ForStatement
-
- rewriteStatement(String) - Method in class org.apache.sysds.parser.FunctionStatement
-
- rewriteStatement(String) - Method in class org.apache.sysds.parser.IfStatement
-
- rewriteStatement(String) - Method in class org.apache.sysds.parser.ImportStatement
-
- rewriteStatement(String) - Method in class org.apache.sysds.parser.MultiAssignmentStatement
-
- rewriteStatement(String) - Method in class org.apache.sysds.parser.OutputStatement
-
- rewriteStatement(String) - Method in class org.apache.sysds.parser.PathStatement
-
- rewriteStatement(String) - Method in class org.apache.sysds.parser.PrintStatement
-
- rewriteStatement(String) - Method in class org.apache.sysds.parser.Statement
-
- rewriteStatement(String) - Method in class org.apache.sysds.parser.WhileStatement
-
- rewriteStatementBlock(StatementBlock, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.MarkForLineageReuse
-
- rewriteStatementBlock(StatementBlock, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteCompressedReblock
-
- rewriteStatementBlock(StatementBlock, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteForLoopVectorization
-
- rewriteStatementBlock(StatementBlock, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteHoistLoopInvariantOperations
-
- rewriteStatementBlock(StatementBlock, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteInjectSparkLoopCheckpointing
-
- rewriteStatementBlock(StatementBlock, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteMarkLoopVariablesUpdateInPlace
-
- rewriteStatementBlock(StatementBlock, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteMergeBlockSequence
-
- rewriteStatementBlock(StatementBlock, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteRemoveEmptyBasicBlocks
-
- rewriteStatementBlock(StatementBlock, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteRemoveUnnecessaryBranches
-
- rewriteStatementBlock(StatementBlock, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteSplitDagDataDependentOperators
-
- rewriteStatementBlock(StatementBlock, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteSplitDagUnknownCSVRead
-
- rewriteStatementBlock(StatementBlock, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.StatementBlockRewriteRule
-
Handle an arbitrary statement block.
- rewriteStatementBlocks(List<StatementBlock>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.MarkForLineageReuse
-
- rewriteStatementBlocks(List<StatementBlock>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteCompressedReblock
-
- rewriteStatementBlocks(List<StatementBlock>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteForLoopVectorization
-
- rewriteStatementBlocks(List<StatementBlock>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteHoistLoopInvariantOperations
-
- rewriteStatementBlocks(List<StatementBlock>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteInjectSparkLoopCheckpointing
-
- rewriteStatementBlocks(List<StatementBlock>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteMarkLoopVariablesUpdateInPlace
-
- rewriteStatementBlocks(List<StatementBlock>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteMergeBlockSequence
-
- rewriteStatementBlocks(List<StatementBlock>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteRemoveEmptyBasicBlocks
-
- rewriteStatementBlocks(List<StatementBlock>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteRemoveUnnecessaryBranches
-
- rewriteStatementBlocks(List<StatementBlock>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteSplitDagDataDependentOperators
-
- rewriteStatementBlocks(List<StatementBlock>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.RewriteSplitDagUnknownCSVRead
-
- rewriteStatementBlocks(List<StatementBlock>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.StatementBlockRewriteRule
-
Handle a list of statement blocks.
- RewriteTransientWriteParentHandling - Class in org.apache.sysds.hops.rewrite
-
Rule: Eliminate for Transient Write DataHops to have no parents
Solution: Move parent edges of Transient Write Hop to parent of
its child
Reason: Transient Write not being a root messes up
analysis for Lop's to Instruction translation (according to Amol)
- RewriteTransientWriteParentHandling() - Constructor for class org.apache.sysds.hops.rewrite.RewriteTransientWriteParentHandling
-
- rexpand(MatrixBlock, MatrixBlock, double, boolean, boolean, boolean, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
CP rexpand operation (single input, single output)
- rexpand(IndexedMatrixValue, double, boolean, boolean, boolean, long, ArrayList<IndexedMatrixValue>) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
MR/Spark rexpand operation (single input, multiple outputs incl empty blocks)
- rexpandOperations(MatrixBlock, double, boolean, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- rexpandOperations(MatrixBlock, double, boolean, boolean, boolean, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- rFindAndRecompileIndexingHOP(StatementBlock, ProgramBlock, String, ExecutionContext, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.ProgramRecompiler
-
NOTE: if force is set, we set and recompile the respective indexing hops;
otherwise, we release the forced exec type and recompile again.
- rFlagFunctionForRecompileOnce(StatementBlock, boolean) - Method in class org.apache.sysds.hops.ipa.IPAPassFlagFunctionsRecompileOnce
-
Returns true if this statementblock requires recompilation inside a
loop statement block.
- rFlipVectorLookups(CNode) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- rGetDagLeaves(HashSet<LineageItem>, LineageItem) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
-
- rGetMaxParallelism(List<Hop>) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- rGetMaxParallelism(Hop) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- rHasCheckpointRDDChilds() - Method in class org.apache.sysds.runtime.instructions.spark.data.RDDObject
-
- rHasSimpleReadChain(Hop, String) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- rHoistFunctionCallsFromExpressions(StatementBlock, DMLProgram) - Static method in class org.apache.sysds.parser.StatementBlock
-
- rHoistFunctionCallsFromExpressions(Statement, DMLProgram) - Static method in class org.apache.sysds.parser.StatementBlock
-
- rHoistFunctionCallsFromExpressions(Expression, boolean, ArrayList<Statement>, DMLProgram) - Static method in class org.apache.sysds.parser.StatementBlock
-
- right - Variable in class org.apache.sysds.parser.dml.DmlParser.AddSubExpressionContext
-
- right - Variable in class org.apache.sysds.parser.dml.DmlParser.BooleanAndExpressionContext
-
- right - Variable in class org.apache.sysds.parser.dml.DmlParser.BooleanOrExpressionContext
-
- right - Variable in class org.apache.sysds.parser.dml.DmlParser.MatrixMulExpressionContext
-
- right - Variable in class org.apache.sysds.parser.dml.DmlParser.ModIntDivExpressionContext
-
- right - Variable in class org.apache.sysds.parser.dml.DmlParser.MultDivExpressionContext
-
- right - Variable in class org.apache.sysds.parser.dml.DmlParser.PowerExpressionContext
-
- right - Variable in class org.apache.sysds.parser.dml.DmlParser.RelationalExpressionContext
-
- RightIndex - Class in org.apache.sysds.lops
-
- RightIndex(Lop, Lop, Lop, Lop, Lop, Lop, Lop, Types.DataType, Types.ValueType, LopProperties.ExecType, boolean) - Constructor for class org.apache.sysds.lops.RightIndex
-
- RightIndex(Lop, Lop, Lop, Lop, Lop, Lop, Lop, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.RightIndex
-
- RightIndex(Lop, Lop, Lop, Lop, Lop, Lop, Lop, Types.DataType, Types.ValueType, AggBinaryOp.SparkAggType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.RightIndex
-
- rightMultByMatrix(double[], double[], int, double[], int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
- rightMultByMatrix(double[], double[], int, double[], int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
-
- rightMultByMatrix(double[], double[], int, double[], int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
- rightMultByMatrix(double[], double[], int, double[], int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
-
- rightMultByMatrix(MatrixBlock, MatrixBlock, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- rightMultByMatrix(double[], double[], int, double[], int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- rightMultByVector(double[], double[], int, int, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
Multiply the slice of the matrix that this column group represents by a vector on the right.
- rightMultByVector(double[], double[], int, int, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC1
-
- rightMultByVector(double[], double[], int, int, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC2
-
- rightMultByVector(double[], double[], int, int, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
- rightMultByVector(double[], double[], int, int, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
-
- rightMultByVector(double[], double[], int, int, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- rightMultByVector(MatrixBlock, MatrixBlock, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- RightScalarOperator - Class in org.apache.sysds.runtime.matrix.operators
-
Scalar operator for scalar-matrix operations with scalar
on the right-hand-side.
- RightScalarOperator(ValueFunction, double) - Constructor for class org.apache.sysds.runtime.matrix.operators.RightScalarOperator
-
- RightScalarOperator(ValueFunction, double, int) - Constructor for class org.apache.sysds.runtime.matrix.operators.RightScalarOperator
-
- rIsSparseSafeOnly(CNode, CNodeBinary.BinType...) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- rIsValidNumVectorIntermediates(CNode, CNode, Map<Long, Set<Long>>, Map<Long, Pair<Long, MutableInt>>, Set<Long>, IDSequence) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- rlen - Variable in class org.apache.sysds.runtime.io.ReadProperties
-
- rmempty(MatrixBlock, MatrixBlock, boolean, boolean, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
CP rmempty operation (single input, single output matrix)
- rmempty(IndexedMatrixValue, IndexedMatrixValue, boolean, long, long, ArrayList<IndexedMatrixValue>) - Static method in class org.apache.sysds.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.sysds.runtime.instructions.spark
-
- round(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs an "round" operation on a matrix on the GPU
- roundToNext(int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- row - Variable in class org.apache.sysds.runtime.matrix.data.MatrixValue.CellIndex
-
- ROW_WISE - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
-
- ROWBLOCKCOUNTPARAM - Static variable in class org.apache.sysds.parser.DataExpression
-
- rowEnd - Variable in class org.apache.sysds.runtime.util.IndexRange
-
- rowIndexes() - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
Get raw access to underlying array of row indices
For use in GPU code
- rowLower - Variable in class org.apache.sysds.parser.dml.DmlParser.IndexedExpressionContext
-
- RowMatrixBlock - Class in org.apache.sysds.runtime.instructions.spark.data
-
- RowMatrixBlock() - Constructor for class org.apache.sysds.runtime.instructions.spark.data.RowMatrixBlock
-
- RowMatrixBlock(int, int, MatrixBlock) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.RowMatrixBlock
-
- rowPointers() - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
Get raw access to underlying array of row pointers
For use in GPU code
- rowPtr - Variable in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
integer array of start of all rows and end of last row + 1
- rowsKnown() - Method in class org.apache.sysds.hops.Hop
-
- rowsKnown() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- rowsKnown() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- rowSpan() - Method in class org.apache.sysds.runtime.util.IndexRange
-
- rowStart - Variable in class org.apache.sysds.runtime.util.IndexRange
-
- rowUpper - Variable in class org.apache.sysds.parser.dml.DmlParser.IndexedExpressionContext
-
- rRemoveCheckpointReadWrite(Hop) - Static method in class org.apache.sysds.hops.ipa.IPAPassRemoveUnnecessaryCheckpoints
-
- rReorderCommutativeBinaryOps(CNode, long) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
-
- rReplaceDagLeaves(LineageItem, LineageItem[]) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
-
- rReplaceLiterals(Hop, ExecutionContext, boolean) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
public interface to package local literal replacement
- rReplaceLiterals(Hop, LocalVariableMap, boolean) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- rReplaceNR(LineageItem, LineageItem, LineageItem) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
-
- rRewriteStatementBlock(StatementBlock, ProgramRewriteStatus, boolean) - Method in class org.apache.sysds.hops.rewrite.ProgramRewriter
-
- rRewriteStatementBlockHopDAGs(StatementBlock, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.ProgramRewriter
-
- rRewriteStatementBlocks(ArrayList<StatementBlock>, ProgramRewriteStatus, boolean) - Method in class org.apache.sysds.hops.rewrite.ProgramRewriter
-
- rSetExecType(Hop, LopProperties.ExecType) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- rSetMaxParallelism(List<Hop>, int) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- rSetMaxParallelism(Hop, int) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- RULE_dataIdentifier - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- RULE_dataType - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- RULE_expression - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- RULE_functionStatement - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- RULE_iterablePredicate - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- RULE_ml_type - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- RULE_parameterizedExpression - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- RULE_programroot - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- RULE_statement - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- RULE_strictParameterizedExpression - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- RULE_strictParameterizedKeyValueString - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- RULE_typedArgAssign - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- RULE_typedArgNoAssign - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- RULE_valueType - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- ruleNames - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- ruleNames - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- run() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedWorker
-
- run() - Method in class org.apache.sysds.runtime.controlprogram.parfor.LocalParWorker
-
- runJob(long, String, String, String, HashMap<String, byte[]>, String, MatrixObject, ExecutionContext, ParForProgramBlock.PartitionFormat, Types.FileFormat, boolean, boolean, int) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteDPParForSpark
-
- runJob(long, String, HashMap<String, byte[]>, List<Task>, ExecutionContext, ArrayList<ParForStatementBlock.ResultVar>, boolean, int, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForSpark
-
- rUpdateFunctionNames(Hop, long) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- rUpdateStatistics(Hop, LocalVariableMap) - Static method in class org.apache.sysds.hops.recompile.Recompiler
-
- S - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- SAFE_REP_CHANGE_THRES - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
- safeValueOf(String) - Static method in enum org.apache.sysds.common.Types.FileFormat
-
- SAMPLE_FRACTION - Static variable in class org.apache.sysds.lops.Lop
-
- SAMPLE_OPCODE - Static variable in class org.apache.sysds.lops.DataGen
-
- sampleOperations(long, int, boolean, long) - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- samplingRatio - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
-
The sampling ratio used when choosing ColGroups.
- satisfiesMultiThreadingConstraints(BasicTensorBlock, int) - Static method in class org.apache.sysds.runtime.data.LibTensorAgg
-
Check if a aggregation fulfills the constraints to be split to multiple threads.
- satisfiesMultiThreadingConstraints(MatrixBlock, MatrixBlock, AggregateUnaryOperator, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
-
- satisfiesMultiThreadingConstraints(MatrixBlock, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- satisfiesMultiThreadingConstraints(MatrixBlock, boolean, boolean, long, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- satisfiesMultiThreadingConstraints(MatrixBlock, MatrixBlock, boolean, boolean, long, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- saveReplaceFilenameThreadID(String, String, String) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- sc() - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Obtain SparkContext from MLContextProxy.
- SCALAR_DATA_TYPE - Static variable in class org.apache.sysds.parser.Statement
-
- SCALAR_VAR_NAME_PREFIX - Static variable in class org.apache.sysds.lops.Lop
-
- ScalarAppendCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- ScalarBuiltinNaryCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
The ScalarBuiltinMultipleCPInstruction class is responsible for printf-style
Java-based string formatting.
- ScalarMatrixArithmeticGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
- ScalarMatrixBuiltinGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
- ScalarMatrixRelationalBinaryGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
-
- ScalarObject - Class in org.apache.sysds.runtime.instructions.cp
-
- ScalarObject(Types.ValueType) - Constructor for class org.apache.sysds.runtime.instructions.cp.ScalarObject
-
- ScalarObjectFactory - Class in org.apache.sysds.runtime.instructions.cp
-
- ScalarObjectFactory() - Constructor for class org.apache.sysds.runtime.instructions.cp.ScalarObjectFactory
-
- scalarOperation(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.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.sysds.runtime.compress.colgroup.ColGroupDDC1
-
- scalarOperation(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC2
-
- scalarOperation(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
- scalarOperation(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
-
- scalarOperation(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- scalarOperations(ScalarOperator, MatrixValue) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- scalarOperations(ScalarOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- scalarOperations(ScalarOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- scalarOperations(ScalarOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- scalarOperations(ScalarOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- scalarOperations(ScalarOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
-
- ScalarOperator - Class in org.apache.sysds.runtime.matrix.operators
-
Base class for all scalar operators.
- ScalarOperator(ValueFunction, double) - Constructor for class org.apache.sysds.runtime.matrix.operators.ScalarOperator
-
- SCHEMAPARAM - Static variable in class org.apache.sysds.parser.DataExpression
-
- sconv2dBiasAddDense(FloatBuffer, FloatBuffer, FloatBuffer, FloatBuffer, int, int, int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysds.utils.NativeHelper
-
- SCRATCH_SPACE - Static variable in class org.apache.sysds.conf.DMLConfig
-
- script - Variable in class org.apache.sysds.api.DMLOptions
-
- Script - Class in org.apache.sysds.api.mlcontext
-
A Script object encapsulates a DML or PYDML script.
- Script() - Constructor for class org.apache.sysds.api.mlcontext.Script
-
Script constructor, which by default creates a DML script.
- Script(String) - Constructor for class org.apache.sysds.api.mlcontext.Script
-
Script constructor, specifying the script content.
- ScriptExecutor - Class in org.apache.sysds.api.mlcontext
-
ScriptExecutor executes a DML or PYDML Script object using SystemDS.
- ScriptExecutor() - Constructor for class org.apache.sysds.api.mlcontext.ScriptExecutor
-
ScriptExecutor constructor.
- ScriptExecutor(DMLConfig) - Constructor for class org.apache.sysds.api.mlcontext.ScriptExecutor
-
ScriptExecutor constructor, where the configuration properties are passed
in.
- ScriptExecutorUtils - Class in org.apache.sysds.api
-
- ScriptExecutorUtils() - Constructor for class org.apache.sysds.api.ScriptExecutorUtils
-
- ScriptFactory - Class in org.apache.sysds.api.mlcontext
-
Factory for creating DML and PYDML Script objects from strings, files, URLs,
and input streams.
- ScriptFactory() - Constructor for class org.apache.sysds.api.mlcontext.ScriptFactory
-
- searchIndexesFirstGT(int) - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- searchIndexesFirstGTE(int) - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- searchIndexesFirstLTE(int) - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- seed - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
-
If the seed is -1 then the system used system millisecond time and class hash for seeding.
- SEED - Static variable in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
- selectPlans(CPlanMemoTable, ArrayList<Hop>) - Method in class org.apache.sysds.hops.codegen.opt.PlanSelection
-
Given a HOP DAG G, and a set of partial fusions plans P, find the set of optimal,
non-conflicting fusion plans P' that applied to G minimizes costs C with
P' = \argmin_{p \subseteq P} C(G, p) s.t.
- selectPlans(CPlanMemoTable, ArrayList<Hop>) - Method in class org.apache.sysds.hops.codegen.opt.PlanSelectionFuseAll
-
- selectPlans(CPlanMemoTable, ArrayList<Hop>) - Method in class org.apache.sysds.hops.codegen.opt.PlanSelectionFuseCostBased
-
- selectPlans(CPlanMemoTable, ArrayList<Hop>) - Method in class org.apache.sysds.hops.codegen.opt.PlanSelectionFuseCostBasedV2
-
- selectPlans(CPlanMemoTable, ArrayList<Hop>) - Method in class org.apache.sysds.hops.codegen.opt.PlanSelectionFuseNoRedundancy
-
- sempred(RuleContext, int, int) - Method in class org.apache.sysds.parser.dml.DmlParser
-
- SEQ_FROM - Static variable in class org.apache.sysds.parser.Statement
-
- SEQ_INCR - Static variable in class org.apache.sysds.parser.Statement
-
- SEQ_OPCODE - Static variable in class org.apache.sysds.lops.DataGen
-
- SEQ_TO - Static variable in class org.apache.sysds.parser.Statement
-
- seqOperations(double, double, double) - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Method to generate a sequence according to the given parameters.
- seqOperationsInPlace(double, double, double) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- seqOperationsInPlace(double, double, double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- SER_STORAGE_LEVEL - Static variable in class org.apache.sysds.lops.Checkpoint
-
- serialize() - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
-
- serialize() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcCall
-
- serialize() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcObject
-
- serialize() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcResponse
-
- serialize(MatrixBlock) - Method in class org.apache.sysds.runtime.io.BinaryBlockSerialization.MatrixBlockSerializer
-
- serialize() - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- serializeBlock(CacheBlock) - Method in class org.apache.sysds.runtime.controlprogram.caching.ByteBuffer
-
- serializeDataObject(String, Data) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- serializeDMLConfig() - Method in class org.apache.sysds.conf.DMLConfig
-
- serializeList(List<String>) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- serializeList(List<String>, String) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- serializeParForBody(ParForBody) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- serializeParForBody(ParForBody, HashMap<String, byte[]>) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- serializeResultVariables(List<ParForStatementBlock.ResultVar>) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- serializeSparkPSBody(SparkPSBody, HashMap<String, byte[]>) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
-
- SerLongWritable - Class in org.apache.sysds.runtime.instructions.spark.data
-
Wrapper for LongWritable in order to make it serializable as required for
shuffle in spark instructions.
- SerLongWritable(Long) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.SerLongWritable
-
- SerText - Class in org.apache.sysds.runtime.instructions.spark.data
-
Wrapper for Text in order to make it serializable as required for
shuffle in spark instructions.
- SerText(String) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.SerText
-
- set(CompilerConfig.ConfigType, boolean) - Method in class org.apache.sysds.conf.CompilerConfig
-
- set(CompilerConfig.ConfigType, int) - Method in class org.apache.sysds.conf.CompilerConfig
-
- set(DMLConfig) - Method in class org.apache.sysds.conf.DMLConfig
-
- set(int, int) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix
-
- set(int, int) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix1
-
- set(int, int) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix2
-
- set(int[], Object) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- set(double) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- set(Object) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- set(BasicTensorBlock) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- set(MatrixBlock) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- set(Object) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- set(int[], Object) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
-
- set(double) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Set the given value for the entire dense block (fill).
- set(String) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Set the given string for the entire dense block (fill).
- set(int, int, int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Set the given value for an entire index range of the
dense block (fill).
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Set the given value for a given row and column.
- set(int, double[]) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Copy the given vector into the given row.
- set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Copy the given dense block.
- set(int, int, int, int, DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Copy the given dense block into the specified
index range.
- set(KahanObject) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Copy the given kahan object sum and correction.
- set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Set the specified cell to the given value.
- set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Set the specified cell to the given value.
- set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Set the specified cell to the given value.
- set(int, KahanObject) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Copy the given kahan object sum and correction
into the given row.
- set(String) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- set(int, int, int, int, DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- set(int, double[]) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- set(int, int, int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
-
- set(double) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
-
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- set(int, double[]) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- set(int, int, int, int, DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- set(int, double[]) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- set(int, double[]) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- set(int, double[]) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- set(String) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
-
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
-
- set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
-
- set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
-
- set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
-
- set(double) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
-
- set(int, int, int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
-
- set(int, double[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
-
- set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
-
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
-
- set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
-
- set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
-
- set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
-
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
-
- set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
-
- set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
-
- set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
-
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
-
- set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
-
- set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
-
- set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
-
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
-
- set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
-
- set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
-
- set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
-
- set(String) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
-
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
-
- set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
-
- set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
-
- set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
-
- set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
-
- set(String) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- set(int, double[]) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- set(TensorIndexes, TensorBlock) - Method in class org.apache.sysds.runtime.data.IndexedTensorBlock
-
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Set the value of a matrix cell (r,c).
- set(int, SparseRow, boolean) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Set the values of row r to the given sparse row.
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- set(int, SparseRow, boolean) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- set(int, SparseRow, boolean) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- set(int, SparseRow, boolean) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- set(int, double) - Method in class org.apache.sysds.runtime.data.SparseRow
-
Sets the value of a specified column with awareness of
potential overwrites or deletes (set to value zero).
- set(int, double) - Method in class org.apache.sysds.runtime.data.SparseRowScalar
-
- set(int, double) - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- set(Object) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- set(MatrixBlock) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- set(int[], Object) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
Set a cell to the value given as an `Object`.
- set(int, int, double) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
Set a cell in a 2-dimensional tensor.
- set(CM_COV_Object) - Method in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
- set(KahanObject) - Method in class org.apache.sysds.runtime.instructions.cp.KahanObject
-
- set(double, double) - Method in class org.apache.sysds.runtime.instructions.cp.KahanObject
-
- set(int, Data) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- set(int, int, ListObject) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- set(String, Data) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- set(String, String, ListObject) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- set(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.data.CorrMatrixBlock
-
- set(MatrixIndexes, MatrixValue) - Method in class org.apache.sysds.runtime.instructions.spark.data.IndexedMatrixValue
-
- set(String, LineageItem) - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- set(String, LineageItem) - Method in class org.apache.sysds.runtime.lineage.LineageMap
-
- set(int, int, Object) - Method in class org.apache.sysds.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.sysds.runtime.matrix.data.IJV
-
- set(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue.CellIndex
-
- set(K, V) - Method in class org.apache.sysds.runtime.matrix.data.Pair
-
- set(long, long, int) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- set(long, long, int, long) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- set(long[], int) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- set(long[], int, long) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- set(DataCharacteristics) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- set(long, long, int) - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- set(long, long, int, long) - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- set(DataCharacteristics) - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- set(long[], int) - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- set(long[], int, long) - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- set(DataCharacteristics) - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- set(long, long, long, long) - Method in class org.apache.sysds.runtime.util.IndexRange
-
- setAccumulator(boolean) - Method in class org.apache.sysds.parser.AssignmentStatement
-
- setActive(boolean) - Static method in class org.apache.sysds.utils.MLContextProxy
-
- setActiveAM() - Static method in class org.apache.sysds.api.DMLScript
-
- setAggOp(Types.AggOp) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- setAggOps(ArrayList<Types.AggOp>) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
-
- setAllowSharedDictionary(boolean) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
-
Allow the Dictionaries to be shared between different column groups.
- setAllPositions(String, int, int, int, int) - Method in class org.apache.sysds.lops.Lop
-
- setAppropriateVarsForRead(Expression, String) - Method in class org.apache.sysds.api.mlcontext.MLContext.InternalProxy
-
- setAppropriateVarsForRead(Expression, String) - Static method in class org.apache.sysds.utils.MLContextProxy
-
- setAtLeastOneError(boolean) - Method in class org.apache.sysds.parser.dml.CustomErrorListener
-
- setAtLeastOneWarning(boolean) - Method in class org.apache.sysds.parser.dml.CustomErrorListener
-
- setAutoCreateVars(boolean) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- setBackReference(CacheableData<?>) - Method in class org.apache.sysds.runtime.instructions.spark.data.LineageObject
-
- setBeginColumn(int) - Method in class org.apache.sysds.hops.Hop
-
- setBeginColumn(int) - Method in class org.apache.sysds.lops.Lop
-
- setBeginColumn(int) - Method in class org.apache.sysds.parser.ConditionalPredicate
-
- setBeginColumn(int) - Method in class org.apache.sysds.parser.Expression
-
- setBeginColumn(int) - Method in interface org.apache.sysds.parser.ParseInfo
-
- setBeginColumn(int) - Method in class org.apache.sysds.parser.Statement
-
- setBeginColumn(int) - Method in class org.apache.sysds.parser.StatementBlock
-
- setBeginColumn(int) - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- setBeginDim(int, long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
-
- setBeginLine(int) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
-
- setBeginLine(int) - Method in class org.apache.sysds.hops.Hop
-
- setBeginLine(int) - Method in class org.apache.sysds.lops.Lop
-
- setBeginLine(int) - Method in class org.apache.sysds.parser.ConditionalPredicate
-
- setBeginLine(int) - Method in class org.apache.sysds.parser.Expression
-
- setBeginLine(int) - Method in interface org.apache.sysds.parser.ParseInfo
-
- setBeginLine(int) - Method in class org.apache.sysds.parser.Statement
-
- setBeginLine(int) - Method in class org.apache.sysds.parser.StatementBlock
-
- setBeginLine(int) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- setBeginLine(int) - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- setBlock(int, int, T) - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
-
- setBlocked(boolean) - Method in class org.apache.sysds.lops.OutputParameters
-
- setBlocksize(Integer) - Method in class org.apache.sysds.api.mlcontext.Metadata
-
Set the number of rows per block
- setBlocksize(int) - Method in class org.apache.sysds.hops.Hop
-
- setBlocksize(int) - Method in class org.apache.sysds.hops.rewrite.ProgramRewriteStatus
-
- setBlocksize(long) - Method in class org.apache.sysds.lops.OutputParameters
-
- setBlocksize(int) - Method in class org.apache.sysds.parser.Identifier
-
- setBlockSize(int, int) - Method in class org.apache.sysds.runtime.matrix.data.BinaryBlockToTextCellConverter
-
- setBlockSize(int, int) - Method in interface org.apache.sysds.runtime.matrix.data.Converter
-
- setBlockSize(int, int) - Method in class org.apache.sysds.runtime.matrix.data.TextToBinaryCellConverter
-
- setBlocksize(int) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- setBody(ArrayList<StatementBlock>) - Method in class org.apache.sysds.parser.ForStatement
-
- setBody(ArrayList<StatementBlock>) - Method in class org.apache.sysds.parser.FunctionStatement
-
- setBody(ArrayList<StatementBlock>) - Method in class org.apache.sysds.parser.WhileStatement
-
- setBooleanProperties() - Method in class org.apache.sysds.parser.Identifier
-
- setBroadcastHandle(BroadcastObject) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- setCachedJobConf(JobConf) - Static method in class org.apache.sysds.conf.ConfigurationManager
-
- setCachePolicy(LineageCacheConfig.LineageCachePolicy) - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- setCallOptimized(boolean) - Method in class org.apache.sysds.hops.FunctionOp
-
- setCellType(SpoofCellwise.CellType) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- setCharPositionInLine(int) - Method in class org.apache.sysds.parser.dml.CustomErrorListener.ParseIssue
-
- setCheckedConstraints(Map<PrivacyConstraint.PrivacyLevel, LongAdder>) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedResponse
-
Set checked privacy constraints in response if the provided map is not empty.
- setCheckMetadata(boolean) - Method in class org.apache.sysds.parser.DataExpression
-
- setCheckpointRDD(boolean) - Method in class org.apache.sysds.runtime.instructions.spark.data.RDDObject
-
- setCheckPrivacy(boolean) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
-
- setCheckPrivacy() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
-
- setCheckPrivacy(boolean) - Static method in class org.apache.sysds.runtime.privacy.PrivacyMonitor
-
- setChildBlocks(ArrayList<ProgramBlock>) - Method in class org.apache.sysds.runtime.controlprogram.ForProgramBlock
-
- setChildBlocks(ArrayList<ProgramBlock>) - Method in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
-
- setChildBlocks(ArrayList<ProgramBlock>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ParForBody
-
- setChildBlocks(ArrayList<ProgramBlock>) - Method in class org.apache.sysds.runtime.controlprogram.WhileProgramBlock
-
- setChildBlocksElseBody(ArrayList<ProgramBlock>) - Method in class org.apache.sysds.runtime.controlprogram.IfProgramBlock
-
- setChildBlocksIfBody(ArrayList<ProgramBlock>) - Method in class org.apache.sysds.runtime.controlprogram.IfProgramBlock
-
- setChilds(ArrayList<OptNode>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- setCM_N_COVObject(double, double, double) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- setCM_N_COVObject(CM_COV_Object) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- setCMAggOp(int) - Method in class org.apache.sysds.runtime.matrix.operators.CMOperator
-
- setCodegenLTrace(String, LineageItem) - Static method in class org.apache.sysds.runtime.lineage.LineageCodegenItem
-
- setCol(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.Cell
-
- setColGroupsCounts(List<ColGroup>) - Method in class org.apache.sysds.runtime.compress.CompressionStatistics
-
Set array of counts regarding col group types.
- setColList(int[]) - Method in class org.apache.sysds.runtime.transform.encode.Encoder
-
- setColLowerBound(Expression) - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- setColLowerEqualsUpper(boolean) - Method in class org.apache.sysds.hops.IndexingOp
-
- setColLowerEqualsUpper(boolean) - Method in class org.apache.sysds.hops.LeftIndexingOp
-
- setColLowerEqualsUpper(boolean) - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- setColnames(String[]) - Method in class org.apache.sysds.runtime.transform.decode.Decoder
-
- setCols(long) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- setCols(long) - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- setColumn(int, FrameBlock.Array) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- setColumnMetadata(FrameBlock.ColumnMetadata[]) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- setColumnMetadata(int, FrameBlock.ColumnMetadata) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- setColumnNames(String[]) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- setColumnPartitioner(PlanningCoCoder.PartitionerType) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
-
Set the type of CoCoding Partitioner type to use for combining columns together.
- setColUpperBound(Expression) - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- setCompAssRW(boolean) - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- setCompilerConfig() - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Set SystemDS compiler configuration properties for MLContext
- setCompletePath(String) - Method in class org.apache.sysds.parser.ImportStatement
-
- setConditionalPredicate(ConditionalPredicate) - Method in class org.apache.sysds.parser.IfStatement
-
- setConfig(String) - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Set SystemDS configuration based on a configuration file.
- setConfig(String) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Set SystemDS configuration properties based on a configuration file.
- setConfig(DMLConfig) - Method in class org.apache.sysds.api.mlcontext.ScriptExecutor
-
Set the SystemDS configuration properties.
- setConfig(LineageCacheConfig.ReuseCacheType) - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- setConfig(LineageCacheConfig.ReuseCacheType, LineageCacheConfig.CachedItemHead, LineageCacheConfig.CachedItemTail) - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- setConfigProperty(String, String) - Method in interface org.apache.sysds.api.ConfigurableAPI
-
Set configuration property, such as
setConfigProperty("sysds.localtmpdir", "/tmp/systemds")
.
- setConfigProperty(String, String) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
- setConfigProperty(String, String) - Method in class org.apache.sysds.api.mlcontext.MLContext
-
- setConfigTsmmCbind(LineageCacheConfig.ReuseCacheType) - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- setConfiguredPlanSelector() - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
-
- setConstant(double, int) - Method in class org.apache.sysds.runtime.matrix.operators.LeftScalarOperator
-
- setConstant(double) - Method in class org.apache.sysds.runtime.matrix.operators.LeftScalarOperator
-
- setConstant(double) - Method in class org.apache.sysds.runtime.matrix.operators.RightScalarOperator
-
- setConstant(double, int) - Method in class org.apache.sysds.runtime.matrix.operators.RightScalarOperator
-
- setConstant(double) - Method in class org.apache.sysds.runtime.matrix.operators.ScalarOperator
-
- setConstant(double, int) - Method in class org.apache.sysds.runtime.matrix.operators.ScalarOperator
-
- setConstDim2(long) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
-
- setConstDim2(long) - Method in class org.apache.sysds.hops.codegen.SpoofFusedOp
-
- setConsumerCount(int) - Method in class org.apache.sysds.lops.Lop
-
- setContainsSeq(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- setCPCaching(boolean) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- setCtxValues(ParserRuleContext) - Method in class org.apache.sysds.parser.Expression
-
Set ParserRuleContext values (begin line, begin column, end line, end
column, and text).
- setCtxValues(ParserRuleContext) - Method in class org.apache.sysds.parser.Statement
-
Set ParserRuleContext values (begin line, begin column, end line, end
column, and text).
- setCtxValuesAndFilename(ParserRuleContext, String) - Method in class org.apache.sysds.parser.Expression
-
Set ParserRuleContext values (begin line, begin column, end line, end
column, and text) and file name.
- setCtxValuesAndFilename(ParserRuleContext, String) - Method in class org.apache.sysds.parser.Statement
-
Set ParserRuleContext values (begin line, begin column, end line, end
column, and text) and file name.
- setCurrentFileName(String) - Method in class org.apache.sysds.parser.dml.CustomErrorListener
-
- setData(MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram.MatrixHistogram
-
- setDataCharacteristics(DataCharacteristics) - Method in class org.apache.sysds.hops.estim.MMNode
-
- setDataFormat(CostEstimator.DataFormat) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNodeStatistics
-
- setDataOpType(Types.OpOpData) - Method in class org.apache.sysds.hops.DataOp
-
- setDataPartitioner(ParForProgramBlock.PDataPartitioner) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- setDataType(Types.DataType) - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- setDataType(Types.DataType) - Method in class org.apache.sysds.hops.Hop
-
- setDataType(Types.DataType) - Method in class org.apache.sysds.lops.Lop
-
set data type of the output that is produced by this lop
- setDataType(Types.DataType) - Method in class org.apache.sysds.parser.Identifier
-
- setDedupBlock(LineageDedupBlock) - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- setDedupMap(LineageDedupBlock, long) - Static method in class org.apache.sysds.runtime.lineage.LineageDedupUtils
-
- setDedupPathBranch(int, boolean) - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- setDefaultConfig() - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Set default SystemDS configuration properties.
- setDegreeOfParallelism(int) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- setDelim(String) - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
-
- setDensePointer(Pointer) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Convenience method to directly set the dense matrix pointer on GPU
- setDescription(String) - Method in class org.apache.sysds.runtime.io.FileFormatProperties
-
- setDiag(boolean) - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
- setDim(int, long) - Method in class org.apache.sysds.hops.Hop
-
- setDim(int, long) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- setDim(int, long) - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- setDim1(long) - Method in class org.apache.sysds.hops.Hop
-
- setDim1(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNodeStatistics
-
- setDim2(long) - Method in class org.apache.sysds.hops.Hop
-
- setDim2(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNodeStatistics
-
- setDim3(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNodeStatistics
-
- setDim4(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNodeStatistics
-
- setDimension(long, long) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- setDimension(long, long) - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- setDimensions(DataCharacteristics) - Method in class org.apache.sysds.lops.OutputParameters
-
- setDimensions(long, long, long, long) - Method in class org.apache.sysds.lops.OutputParameters
-
- setDimensions(long, long, long, long, MatrixObject.UpdateType) - Method in class org.apache.sysds.lops.OutputParameters
-
- setDimensions(long, long, long, long, boolean) - Method in class org.apache.sysds.lops.OutputParameters
-
- setDimensions(OutputParameters) - Method in class org.apache.sysds.lops.OutputParameters
-
- setDimensions(long, long) - Method in class org.apache.sysds.parser.Identifier
-
- setDimensionsBasedOnDirection(long, long, long) - Method in class org.apache.sysds.lops.PartialAggregate
-
- setDimensionsBasedOnDirection(Lop, long, long, long, Types.Direction) - Static method in class org.apache.sysds.lops.PartialAggregate
-
- setDimensionValueProperties(Identifier) - Method in class org.apache.sysds.parser.Identifier
-
- setDims(long[]) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- setDims(long[]) - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- setDirection(Types.Direction) - Method in class org.apache.sysds.hops.AggUnaryOp
-
- setDirty(boolean) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- setDisjointInputs(boolean) - Method in class org.apache.sysds.hops.TernaryOp
-
- setDistinct(long, List<CPlanMemoTable.MemoTableEntry>) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- setDMLProg(DMLProgram) - Method in class org.apache.sysds.parser.StatementBlock
-
- setDMLProg(DMLProgram) - Method in class org.apache.sysds.runtime.controlprogram.Program
-
- setEc(ExecutionContext) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.SparkPSBody
-
- setEc(ExecutionContext) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ParForBody
-
- setElseBody(ArrayList<StatementBlock>) - Method in class org.apache.sysds.parser.IfStatement
-
- setEmptyNewLineStatement(boolean) - Method in class org.apache.sysds.parser.Statement
-
- setEmptyStatus() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- setEndColumn(int) - Method in class org.apache.sysds.hops.Hop
-
- setEndColumn(int) - Method in class org.apache.sysds.lops.Lop
-
- setEndColumn(int) - Method in class org.apache.sysds.parser.ConditionalPredicate
-
- setEndColumn(int) - Method in class org.apache.sysds.parser.Expression
-
- setEndColumn(int) - Method in interface org.apache.sysds.parser.ParseInfo
-
- setEndColumn(int) - Method in class org.apache.sysds.parser.Statement
-
- setEndColumn(int) - Method in class org.apache.sysds.parser.StatementBlock
-
- setEndColumn(int) - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- setEndDim(int, long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
-
- setEndLine(int) - Method in class org.apache.sysds.hops.Hop
-
- setEndLine(int) - Method in class org.apache.sysds.lops.Lop
-
- setEndLine(int) - Method in class org.apache.sysds.parser.ConditionalPredicate
-
- setEndLine(int) - Method in class org.apache.sysds.parser.Expression
-
- setEndLine(int) - Method in interface org.apache.sysds.parser.ParseInfo
-
- setEndLine(int) - Method in class org.apache.sysds.parser.Statement
-
- setEndLine(int) - Method in class org.apache.sysds.parser.StatementBlock
-
- setEndLine(int) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- setEndLine(int) - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- setEnv(String, String) - Static method in class org.apache.sysds.utils.EnvironmentHelper
-
- setExecMode(ParForProgramBlock.PExecMode) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- setExecType(LopProperties.ExecType) - Method in class org.apache.sysds.lops.Data
-
Data-Lop-specific method to set the execution type for persistent write.
- setExecType(OptNode.ExecType) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- setExecTypeSpecificJavaCompiler() - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
-
- setExecutionScript(Script) - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Sets the script that is being executed
- setExecutionType(MLContext.ExecutionType) - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Set the execution environment.
- setExecutionType(MLContext.ExecutionType) - Method in class org.apache.sysds.api.mlcontext.ScriptExecutor
-
Set the execution environment.
- setExitInstruction(Instruction) - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- setExplain(boolean) - Method in class org.apache.sysds.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.sysds.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.sysds.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.sysds.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.sysds.api.mlcontext.ScriptExecutor
-
Set the level of program explanation that should be displayed if explain
is set to true.
- setExportReplicationFactor(int) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- setExpr(Expression) - Method in class org.apache.sysds.parser.ParameterExpression
-
- setExpressions(List<Expression>) - Method in class org.apache.sysds.parser.PrintStatement
-
- setExprParams(DataExpression) - Method in class org.apache.sysds.parser.OutputStatement
-
- setFeatures(MatrixObject) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.PSWorker
-
- setFederatedDefault() - Method in class org.apache.sysds.parser.DataExpression
-
- setFedMapping(FederationMap) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
Sets the mapping of indices ranges to federated objects.
- setFields(MatrixBlock, PrivacyConstraint, MatrixBlock, PrivacyConstraint) - Method in class org.apache.sysds.runtime.privacy.propagation.MatrixMultiplicationPropagator
-
Sets all fields of propagator.
- setFile_name(String) - Method in class org.apache.sysds.lops.OutputParameters
-
- setFileFormat(Types.FileFormat) - Method in class org.apache.sysds.parser.Identifier
-
- setFileFormatProperties(FileFormatProperties) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- setFileName(String) - Method in class org.apache.sysds.hops.DataOp
-
- setFilename(String) - Method in class org.apache.sysds.hops.Hop
-
- setFilename(String) - Method in class org.apache.sysds.lops.Lop
-
- setFilename(String) - Method in class org.apache.sysds.parser.ConditionalPredicate
-
- setFileName(String) - Method in class org.apache.sysds.parser.dml.CustomErrorListener.ParseIssue
-
- setFilename(String) - Method in class org.apache.sysds.parser.Expression
-
- setFilename(String) - Method in interface org.apache.sysds.parser.ParseInfo
-
- setFilename(String) - Method in class org.apache.sysds.parser.Statement
-
- setFilename(String) - Method in class org.apache.sysds.parser.StatementBlock
-
- setFileName(String) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- setFilename(String) - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- setFilePath(String) - Method in class org.apache.sysds.parser.ImportStatement
-
- setFill(boolean) - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
-
- setFillValue(double) - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
-
- setFineGrainedPrivacy(PrivacyConstraint, Expression) - Static method in class org.apache.sysds.runtime.privacy.PrivacyUtils
-
- setFineGrainedPrivacyConstraints(FineGrainedPrivacy) - Method in class org.apache.sysds.runtime.privacy.PrivacyConstraint
-
Sets fine-grained privacy for the privacy constraint.
- setFn(IndexFunction) - Method in class org.apache.sysds.runtime.matrix.operators.ReorgOperator
-
- setForcedExecType(LopProperties.ExecType) - Method in class org.apache.sysds.hops.Hop
-
- setForceGPU(boolean) - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Whether or not to explicitly "force" the usage of GPU.
- setForceGPU(boolean) - Method in class org.apache.sysds.api.mlcontext.ScriptExecutor
-
Whether or not to force GPU usage.
- setFormat(Types.FileFormat) - Method in class org.apache.sysds.lops.OutputParameters
-
- setFormatProperties(FileFormatProperties) - Method in class org.apache.sysds.runtime.instructions.spark.WriteSPInstruction
-
- setFrame(String, String[][]) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a frame object to a registered input variable.
- setFrame(String, String[][], List<Types.ValueType>) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a frame object to a registered input variable.
- setFrame(String, String[][], List<Types.ValueType>, List<String>) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a frame object to a registered input variable.
- setFrame(String, String[][], boolean) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a frame object to a registered input variable.
- setFrame(String, String[][], List<Types.ValueType>, boolean) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a frame object to a registered input variable.
- setFrame(String, String[][], List<Types.ValueType>, List<String>, boolean) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a frame object to a registered input variable.
- setFrame(String, FrameBlock, boolean) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a frame object to a registered input variable.
- setFrameFormat(FrameFormat) - Method in class org.apache.sysds.api.mlcontext.FrameMetadata
-
Set the frame format
- setFrameOutput(String, FrameBlock) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- setFrameSchema(FrameSchema) - Method in class org.apache.sysds.api.mlcontext.FrameMetadata
-
Set the frame schema
- setFromExpr(Expression) - Method in class org.apache.sysds.parser.IterablePredicate
-
- setFromHops(Hop) - Method in class org.apache.sysds.parser.ForStatementBlock
-
- setFromInstructions(ArrayList<Instruction>) - Method in class org.apache.sysds.runtime.controlprogram.ForProgramBlock
-
- setFromLops(Lop) - Method in class org.apache.sysds.parser.ForStatementBlock
-
- setFunctionName(String) - Method in class org.apache.sysds.hops.FunctionOp
-
- setFunctionName(String) - Method in class org.apache.sysds.parser.FunctionCallIdentifier
-
sets the function namespace (if specified) and name
- setFunctionNames(Collection<String>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.LocalParWorker
-
- setFunctionNamespace(String) - Method in class org.apache.sysds.hops.FunctionOp
-
- setFunctionNamespace(String) - Method in class org.apache.sysds.parser.FunctionCallIdentifier
-
- setGen(VariableSet) - Method in class org.apache.sysds.parser.LiveVariableAnalysis
-
- setGlobalConfig(DMLConfig) - Static method in class org.apache.sysds.conf.ConfigurationManager
-
Sets a global configuration as a basis for any thread-local configurations.
- setGlobalConfig(CompilerConfig) - Static method in class org.apache.sysds.conf.ConfigurationManager
-
- setGlobalExecMode(Types.ExecMode) - Static method in class org.apache.sysds.api.DMLScript
-
- setGlobalFlags(DMLConfig) - Static method in class org.apache.sysds.api.DMLScript
-
Sets the global flags in DMLScript based on user provided configuration
- setGPU(boolean) - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Whether or not to use (an available) GPU on the driver node.
- setGPU(boolean) - Method in class org.apache.sysds.api.mlcontext.ScriptExecutor
-
Whether or not to enable GPU usage.
- setGPUContexts(List<GPUContext>) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
Sets the list of GPUContexts
- setGPUObject(GPUContext, GPUObject) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- setHasLeftPMInput(boolean) - Method in class org.apache.sysds.hops.AggBinaryOp
-
- setHDFSFile(boolean) - Method in class org.apache.sysds.runtime.instructions.spark.data.RDDObject
-
- setHDFSFileExists(boolean) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- setHDFSFilename(String) - Method in class org.apache.sysds.runtime.instructions.spark.data.RDDObject
-
- setHeader(boolean) - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
-
- setHops(ArrayList<Hop>) - Method in class org.apache.sysds.parser.StatementBlock
-
- setID(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- setIdentifier(DataIdentifier) - Method in class org.apache.sysds.parser.OutputStatement
-
- setIdentifierParams(Hop, Identifier) - Method in class org.apache.sysds.parser.DMLTranslator
-
- setIfBody(ArrayList<StatementBlock>) - Method in class org.apache.sysds.parser.IfStatement
-
- setIfUnknown(Hop, Hop, Hop, Hop, Hop, Hop, Hop, Hop, Hop, Hop, Hop, int) - Method in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- setIncrementExpr(Expression) - Method in class org.apache.sysds.parser.IterablePredicate
-
- setIncrementHops(Hop) - Method in class org.apache.sysds.parser.ForStatementBlock
-
- setIncrementInstructions(ArrayList<Instruction>) - Method in class org.apache.sysds.runtime.controlprogram.ForProgramBlock
-
- setIncrementLops(Lop) - Method in class org.apache.sysds.parser.ForStatementBlock
-
- setIncrementValue(double) - Method in class org.apache.sysds.hops.DataGenOp
-
- setIndexes(int[]) - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- setIndexes(long[]) - Method in class org.apache.sysds.runtime.data.TensorIndexes
-
- setIndexes(TensorIndexes) - Method in class org.apache.sysds.runtime.data.TensorIndexes
-
- setIndexes(long, long) - Method in class org.apache.sysds.runtime.matrix.data.MatrixIndexes
-
- setIndexes(MatrixIndexes) - Method in class org.apache.sysds.runtime.matrix.data.MatrixIndexes
-
- setIndexes(TripleIndexes) - Method in class org.apache.sysds.runtime.matrix.data.TripleIndexes
-
- setIndexes(long, long, long) - Method in class org.apache.sysds.runtime.matrix.data.TripleIndexes
-
- setIndexRange(int, int, int, double[], int, int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Sets a dense array of non-zeros values into the column range [cl,cu)
in row r.
- setIndexRange(int, int, int, double[], int[], int, int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Sets a sparse array of non-zeros values and indexes into the column range [cl,cu)
in row r.
- setIndexRange(int, int, int, double[], int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- setIndexRange(int, int, int, double[], int[], int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- setIndexRange(int, int, int, double[], int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- setIndexRange(int, int, int, double[], int[], int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- setIndexRange(int, int, int, int, double[], int, int) - Method in class org.apache.sysds.runtime.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.sysds.runtime.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.sysds.runtime.data.SparseBlockMCSR
-
- setIndexRange(int, int, int, double[], int[], int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- setIndexRange(int, int, double[], int, int) - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- setIndexRange(int, int, double[], int[], int, int) - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- setIndices(ArrayList<ArrayList<Expression>>) - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- setInit(boolean) - Method in class org.apache.sysds.api.mlcontext.ScriptExecutor
-
Whether or not to initialize the scratch_space, bufferpool, etc.
- setInitBeforeExecution(boolean) - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Whether or not the default ScriptExecutor should be initialized before
execution.
- setInitDedupBlock(LineageDedupBlock) - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- setInjectedCheckpoints() - Method in class org.apache.sysds.hops.rewrite.ProgramRewriteStatus
-
- setInMemoryPartition(MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
- setInParforContext(boolean) - Method in class org.apache.sysds.hops.rewrite.ProgramRewriteStatus
-
- setInput(String, Hop, boolean) - Method in class org.apache.sysds.hops.DataGenOp
-
- setInput(int, LineageItem) - Method in class org.apache.sysds.runtime.lineage.LineageItem
-
- setInputBlocksize(long) - Method in class org.apache.sysds.hops.DataOp
-
- setInputDefaults(ArrayList<Expression>) - Method in class org.apache.sysds.parser.FunctionStatement
-
- setInputFormatType(Types.FileFormat) - Method in class org.apache.sysds.hops.DataOp
-
- setInputParams(ArrayList<DataIdentifier>) - Method in class org.apache.sysds.parser.FunctionStatement
-
- setInputVariableNames(String[]) - Method in class org.apache.sysds.hops.FunctionOp
-
- setInstID(long) - Method in class org.apache.sysds.runtime.instructions.Instruction
-
Setter for instruction unique identifier
- setInstructions(ArrayList<Instruction>) - Method in class org.apache.sysds.runtime.controlprogram.BasicProgramBlock
-
- setIntProperties() - Method in class org.apache.sysds.parser.Identifier
-
- setInvestigateEstimate(boolean) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
-
Set if the compression should be investigated while compressing.
- setIterVar(DataIdentifier) - Method in class org.apache.sysds.parser.IterablePredicate
-
- setK(int) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- setKey(K) - Method in class org.apache.sysds.runtime.matrix.data.Pair
-
- setKill(VariableSet) - Method in class org.apache.sysds.parser.LiveVariableAnalysis
-
- setLabel(String) - Method in class org.apache.sysds.lops.OutputParameters
-
- setLabels(MatrixObject) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.PSWorker
-
- setLeft(Expression) - Method in class org.apache.sysds.parser.BinaryExpression
-
- setLeft(Expression) - Method in class org.apache.sysds.parser.BooleanExpression
-
- setLeft(Expression) - Method in class org.apache.sysds.parser.RelationalExpression
-
- setLevel(int) - Method in class org.apache.sysds.lops.LopProperties
-
- setLevel(ArrayList<Lop>) - Method in class org.apache.sysds.lops.LopProperties
-
- setLine(int) - Method in class org.apache.sysds.parser.dml.CustomErrorListener.ParseIssue
-
- setLineage(boolean) - Method in class org.apache.sysds.api.jmlc.Connection
-
Sets a boolean flag indicating if lineage trace should be captured
- setLineage(boolean) - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Set whether or not lineage should be traced
- setLineage(LineageCacheConfig.ReuseCacheType) - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Set type of lineage-based reuse caching and enable lineage tracing
- setLineage(Lineage) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- setLineageDedupPathPos(int) - Method in class org.apache.sysds.runtime.controlprogram.IfProgramBlock
-
- setLineNumbers(int, int) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- setLinReuseFull() - Static method in class org.apache.sysds.runtime.lineage.Lineage
-
- setLinReuseFullAndPartial() - Static method in class org.apache.sysds.runtime.lineage.Lineage
-
- setLinReuseNone() - Static method in class org.apache.sysds.runtime.lineage.Lineage
-
- setLinReusePartial() - Static method in class org.apache.sysds.runtime.lineage.Lineage
-
- setLiteral(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- setLiteral(ScalarObject) - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- setLiteral(String, LineageItem) - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- setLiteral(String, LineageItem) - Method in class org.apache.sysds.runtime.lineage.LineageMap
-
- setLiveIn(VariableSet) - Method in class org.apache.sysds.parser.LiveVariableAnalysis
-
- setLiveOut(VariableSet) - Method in class org.apache.sysds.parser.LiveVariableAnalysis
-
- setLocalConfig(DMLConfig) - Static method in class org.apache.sysds.conf.ConfigurationManager
-
Sets the current thread-local dml configuration to the given config.
- setLocalConfig(CompilerConfig) - Static method in class org.apache.sysds.conf.ConfigurationManager
-
Sets the current thread-local compiler configuration to the given config.
- setLocalFilePermissions(File, String) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
-
- setLocalFS(boolean) - Method in class org.apache.sysds.runtime.io.ReaderBinaryBlock
-
- setLocalMaxMemory(long) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
- setLocation(String, int, int, int, int) - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- setLocation(Lop) - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- setLocation(DataIdentifier) - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- setLocation(Instruction) - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- setLops(Lop) - Method in class org.apache.sysds.hops.Hop
-
- setLops(ArrayList<Lop>) - Method in class org.apache.sysds.parser.StatementBlock
-
- setLossy(boolean) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
-
Set the Compression to use Lossy compression.
- setMaintainSymbolTable(boolean) - Method in class org.apache.sysds.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.sysds.api.mlcontext.ScriptExecutor
-
Set whether or not all values should be maintained in the symbol table
after execution.
- setMap(Long, LineageMap) - Method in class org.apache.sysds.runtime.lineage.LineageDedupBlock
-
- setMarkForLinCache(boolean) - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
- setMatPointsExt(InterestingPoint[]) - Method in class org.apache.sysds.hops.codegen.opt.PlanPartition
-
- setMatrix(String, double[][]) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a matrix object to a registered input variable.
- setMatrix(String, double[][], boolean) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a matrix object to a registered input variable.
- setMatrix(String, MatrixBlock, boolean) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a matrix object to a registered input variable.
- setMatrixCharacteristics(MatrixCharacteristics) - Method in class org.apache.sysds.api.mlcontext.FrameMetadata
-
Set the FrameMetadata fields based on a DataCharacteristics object.
- setMatrixCharacteristics(MatrixCharacteristics) - Method in class org.apache.sysds.api.mlcontext.Metadata
-
Set the metadata fields based on a DataCharacteristics object.
- setMatrixDefault() - Method in class org.apache.sysds.parser.DataExpression
-
By default we use rowwise matrix reshape according to our internal dense/sparse matrix representations.
- setMatrixFormat(MatrixFormat) - Method in class org.apache.sysds.api.mlcontext.MatrixMetadata
-
Set the matrix format
- setMatrixOutput(String, MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- setMatrixOutput(String, MatrixBlock, MatrixObject.UpdateType) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- setMaxIndexInPartition(int[], double[]) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixOuterAgg
-
This function will set maximum index in the partition to all cells in partition.
- setMaxMemoryOpt(JobConf, String, long) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
- setMaxNumThreads(int) - Method in class org.apache.sysds.hops.MultiThreadedHop
-
- setmaxStaticColGroupCoCode(int) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
-
Set the maximum number of columns to CoCode together in the static CoCoding strategy.
- setMean(double) - Method in class org.apache.sysds.runtime.util.PoissonPRNGenerator
-
- setMemEstimate(double) - Method in class org.apache.sysds.hops.Hop
-
Sets memory estimate in bytes
- setMessage(String) - Method in class org.apache.sysds.parser.dml.CustomErrorListener.ParseIssue
-
- setMetaData(MetaData) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- setMetaData(String, MetaData) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- setMetaData(String, long, long) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- setMetaData(MetaData) - Method in class org.apache.sysds.runtime.instructions.cp.Data
-
- setMinIndexInPartition(int[], double[]) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixOuterAgg
-
This function will set minimum index in the partition to all cells in partition.
- setMultipleConsumers(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- setMvValue(String) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock.ColumnMetadata
-
- setName(String) - Method in class org.apache.sysds.api.mlcontext.Script
-
Set the script name.
- setName(String) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeData
-
- setName(String) - Method in class org.apache.sysds.hops.Hop
-
- setName(String) - Method in class org.apache.sysds.parser.DataIdentifier
-
- setName(String) - Method in class org.apache.sysds.parser.ExpressionList
-
- setName(String) - Method in class org.apache.sysds.parser.FunctionStatement
-
- setName(String) - Method in class org.apache.sysds.parser.ParameterExpression
-
- setName(String) - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- setNamespace(String) - Method in class org.apache.sysds.parser.ImportStatement
-
- setNAStrings(HashSet<String>) - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
-
- setNewDedupPatch(LineageDedupBlock, ProgramBlock, ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageDedupUtils
-
- setNextTimePhase(double) - Method in class org.apache.sysds.runtime.compress.CompressionStatistics
-
- setNnz(long) - Method in class org.apache.sysds.hops.Hop
-
- setNnz(long) - Method in class org.apache.sysds.lops.OutputParameters
-
- setNnz(long) - Method in class org.apache.sysds.parser.Identifier
-
- setNodeType(OptNode.NodeType) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- setNondeterministic(boolean) - Method in class org.apache.sysds.parser.FunctionStatementBlock
-
- setNondeterministic(boolean) - Method in class org.apache.sysds.parser.StatementBlock
-
- setNondeterministic(boolean) - Method in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
-
- setNonPartitionedBroadcast(Broadcast<T>, long) - Method in class org.apache.sysds.runtime.instructions.spark.data.BroadcastObject
-
- setNonZeros(long) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- setNonZeros(long) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- setNonZeros(long) - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- setNonZeros(long) - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- setNonZerosBound(long) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- setNonZerosBound(long) - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- setNoOfExecutedGPUInst(int) - Static method in class org.apache.sysds.utils.GPUStatistics
-
- setNumCols(long) - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- setNumCols(long) - Method in class org.apache.sysds.lops.OutputParameters
-
- setNumColumns(Long) - Method in class org.apache.sysds.api.mlcontext.Metadata
-
Set the number of columns
- setNumColumns(int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- setNumDistinct(long) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock.ColumnMetadata
-
- setNumNonZeros(Long) - Method in class org.apache.sysds.api.mlcontext.Metadata
-
Set the number of non-zero values
- setNumPathsInPBs(ArrayList<ProgramBlock>, ExecutionContext) - Method in class org.apache.sysds.runtime.lineage.LineageDedupBlock
-
- setNumRows(Long) - Method in class org.apache.sysds.api.mlcontext.Metadata
-
Set the number of rows
- setNumRows(long) - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- setNumRows(long) - Method in class org.apache.sysds.lops.OutputParameters
-
- setNumRows(int) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- setNumRows(int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
NOTE: setNumRows() and setNumColumns() are used only in ternaryInstruction (for contingency tables)
and pmm for meta corrections.
- setNumThreads(int) - Method in class org.apache.sysds.lops.DataGen
-
- setNumThreads(int) - Method in class org.apache.sysds.lops.MapMultChain
-
- setNumThreads(int) - Method in class org.apache.sysds.lops.PMMJ
-
- setNumThreads(int) - Method in class org.apache.sysds.lops.WeightedCrossEntropy
-
- setNumThreads(int) - Method in class org.apache.sysds.lops.WeightedDivMM
-
- setNumThreads(int) - Method in class org.apache.sysds.lops.WeightedSigmoid
-
- setNumThreads(int) - Method in class org.apache.sysds.lops.WeightedSquaredLoss
-
- setNumThreads(int) - Method in class org.apache.sysds.lops.WeightedUnaryMM
-
- setNumVectorIntermediates(int) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
-
- setOffset(int) - Method in class org.apache.sysds.runtime.functionobjects.OffsetColumnIndex
-
- setOp(Types.AggOp) - Method in class org.apache.sysds.hops.AggUnaryOp
-
- setOp(Types.OpOp2) - Method in class org.apache.sysds.hops.BinaryOp
-
- setOp(Types.OpOpDnn) - Method in class org.apache.sysds.hops.DnnOp
-
- setOp2Constant(double) - Method in class org.apache.sysds.runtime.functionobjects.MinusMultiply
-
- setOp2Constant(double) - Method in class org.apache.sysds.runtime.functionobjects.PlusMultiply
-
- setOp2Constant(double) - Method in interface org.apache.sysds.runtime.functionobjects.TernaryValueFunction.ValueFunctionWithConstant
-
- setOpCode(Expression.DataOp) - Method in class org.apache.sysds.parser.DataExpression
-
- setOpcode(Builtins) - Method in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- setOriginalDimensions(long, long) - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- setOtherValue(double) - Method in class org.apache.sysds.runtime.matrix.data.WeightedPair
-
- setOuterProdType(SpoofOuterProduct.OutProdType) - Method in class org.apache.sysds.runtime.codegen.SpoofOuterProduct
-
- setOuterVectorOperation(boolean) - Method in class org.apache.sysds.hops.BinaryOp
-
- setOutProdType(SpoofOuterProduct.OutProdType) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeOuterProduct
-
- setOutput(CNode) - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- setOutput(Identifier) - Method in class org.apache.sysds.parser.Expression
-
- setOutputCharacteristicsForGroupedAgg(DataCharacteristics, DataCharacteristics, JavaPairRDD<MatrixIndexes, MatrixCell>) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction
-
- setOutputDims() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- setOutputDims() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeBinary
-
- setOutputDims() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- setOutputDims() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeData
-
- setOutputDims() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
-
- setOutputDims() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeNary
-
- setOutputDims() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeOuterProduct
-
- setOutputDims() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
-
- setOutputDims() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTernary
-
- setOutputDims() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeUnary
-
- setOutputEmptyBlocks(boolean) - Method in class org.apache.sysds.hops.Hop
-
- setOutputParameters(Hop, long, long, int, long) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- setOutputParametersForScalar(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- setOutputParams(long, long, long, MatrixObject.UpdateType, int) - Method in class org.apache.sysds.hops.DataOp
-
- setOutputParams(ArrayList<DataIdentifier>) - Method in class org.apache.sysds.parser.FunctionStatement
-
- setOutputPermutationMatrix(boolean) - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
-
- setParallelizedRDD(boolean) - Method in class org.apache.sysds.runtime.instructions.spark.data.RDDObject
-
- setParams(HashMap<OptNode.ParamType, String>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
- setParForParams(HashMap<String, String>) - Method in class org.apache.sysds.parser.IterablePredicate
-
- setParseExceptionList(ArrayList<String>) - Method in class org.apache.sysds.parser.Expression
-
- setParseInfo(ParseInfo) - Method in class org.apache.sysds.hops.Hop
-
Set parse information.
- setParseInfo(ParseInfo) - Method in class org.apache.sysds.parser.Expression
-
Set parse information.
- setParseInfo(ParseInfo) - Method in class org.apache.sysds.parser.Statement
-
Set parse information.
- setParseInfo(ParseInfo) - Method in class org.apache.sysds.parser.StatementBlock
-
Set parse information.
- setParseInfo(ParseInfo) - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
Set parse information.
- setParseIssues(List<CustomErrorListener.ParseIssue>) - Method in class org.apache.sysds.parser.dml.CustomErrorListener
-
Set the list of parse issues.
- setParseIssues(List<CustomErrorListener.ParseIssue>) - Method in exception org.apache.sysds.parser.ParseException
-
Set the list of parse issues.
- setParseIssueType(CustomErrorListener.ParseIssueType) - Method in class org.apache.sysds.parser.dml.CustomErrorListener.ParseIssue
-
- setPartitioned(ParForProgramBlock.PDataPartitionFormat, int) - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
- setPartitionedBroadcast(PartitionedBroadcast<T>, long) - Method in class org.apache.sysds.runtime.instructions.spark.data.BroadcastObject
-
- setPartitionReplicationFactor(int) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- setPathBranch(int, boolean) - Method in class org.apache.sysds.runtime.lineage.LineageDedupBlock
-
- setPending(boolean) - Method in class org.apache.sysds.runtime.instructions.spark.data.RDDObject
-
- setPlanInputType(Optimizer.PlanInputType) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTree
-
- setPredicate(Expression) - Method in class org.apache.sysds.parser.ConditionalPredicate
-
- setPredicate(IterablePredicate) - Method in class org.apache.sysds.parser.ForStatement
-
- setPredicate(ConditionalPredicate) - Method in class org.apache.sysds.parser.WhileStatement
-
- setPredicate(ArrayList<Instruction>) - Method in class org.apache.sysds.runtime.controlprogram.IfProgramBlock
-
- setPredicate(ArrayList<Instruction>) - Method in class org.apache.sysds.runtime.controlprogram.WhileProgramBlock
-
- setPredicateHops(Hop) - Method in class org.apache.sysds.parser.IfStatementBlock
-
- setPredicateHops(Hop) - Method in class org.apache.sysds.parser.WhileStatementBlock
-
- setPredicateLops(Lop) - Method in class org.apache.sysds.parser.IfStatementBlock
-
- setPredicateLops(Lop) - Method in class org.apache.sysds.parser.WhileStatementBlock
-
- setPrivacy(PrivacyConstraint) - Method in class org.apache.sysds.hops.Hop
-
- setPrivacy(PrivacyConstraint.PrivacyLevel) - Method in class org.apache.sysds.parser.Identifier
-
- setPrivacy(PrivacyConstraint) - Method in class org.apache.sysds.parser.Identifier
-
- setPrivacyConstraint(PrivacyConstraint) - Method in class org.apache.sysds.lops.Lop
-
Method to set privacy constraint of Lop.
- setPrivacyConstraint(PrivacyConstraint) - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- setPrivacyConstraint(Lop) - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- setPrivacyConstraint(PrivacyConstraint) - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- setPrivacyConstraints(PrivacyConstraint) - Method in class org.apache.sysds.runtime.instructions.cp.Data
-
- setPrivacyLevel(PrivacyConstraint.PrivacyLevel) - Method in class org.apache.sysds.runtime.privacy.PrivacyConstraint
-
- setProducesIntermediateOutput(boolean) - Method in class org.apache.sysds.lops.LopProperties
-
- setProgram(Program) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- setProgram(Program) - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- setProperties(ArrayList<Lop>, LopProperties.ExecType) - Method in class org.apache.sysds.lops.LopProperties
-
- setProperties(Identifier) - Method in class org.apache.sysds.parser.Identifier
-
- setProperties(Identifier) - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- setRandDefault() - Method in class org.apache.sysds.parser.DataExpression
-
- setRDDHandle(RDDObject) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- setRDDHandleForVariable(String, JavaPairRDD<?, ?>) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
Keep the output rdd of spark rdd operations as meta data of matrix/frame
objects in the symbol table.
- setReadVariables(VariableSet) - Method in class org.apache.sysds.parser.LiveVariableAnalysis
-
- setRecompileMemoryBudget(double) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- setRecompileOnce(boolean) - Method in class org.apache.sysds.parser.FunctionStatementBlock
-
- setRecompileOnce(boolean) - Method in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
-
- setRegisteredOutputs(HashSet<String>) - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
-
- setRemoteParallelMapTasks(int) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
- setRemoteParallelReduceTasks(int) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
-
- setRemovedBranches() - Method in class org.apache.sysds.hops.rewrite.ProgramRewriteStatus
-
- setRequiresCastDtm(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- setRequiresCheckpoint(boolean) - Method in class org.apache.sysds.hops.Hop
-
- setRequiresCompression(boolean) - Method in class org.apache.sysds.hops.Hop
-
- setRequiresLineageCaching(boolean) - Method in class org.apache.sysds.hops.Hop
-
- setRequiresReblock(boolean) - Method in class org.apache.sysds.hops.Hop
-
- setRequiresRecompile() - Method in class org.apache.sysds.hops.Hop
-
Marks the hop for dynamic recompilation.
- setResultMerge(ParForProgramBlock.PResultMerge) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- setResults(MLResults) - Method in class org.apache.sysds.api.mlcontext.Script
-
Set the results of the script execution.
- setResultVariables(ArrayList<ParForStatementBlock.ResultVar>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ParForBody
-
- setReusableOpcodes(String...) - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- setRight(Expression) - Method in class org.apache.sysds.parser.BinaryExpression
-
- setRight(Expression) - Method in class org.apache.sysds.parser.BooleanExpression
-
- setRight(Expression) - Method in class org.apache.sysds.parser.RelationalExpression
-
- setRoot(OptNode) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTree
-
- setRootNodes(ArrayList<Hop>) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
-
- setRow(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.Cell
-
- setRowLowerBound(Expression) - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- setRowLowerEqualsUpper(boolean) - Method in class org.apache.sysds.hops.IndexingOp
-
- setRowLowerEqualsUpper(boolean) - Method in class org.apache.sysds.hops.LeftIndexingOp
-
- setRowLowerEqualsUpper(boolean) - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- setRows(long) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
-
- setRows(long) - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- setRowType(SpoofRowwise.RowType) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
-
- setRowUpperBound(Expression) - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- setRuntimePiggybacking(boolean) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- setSamplingRatio(double) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
-
Set the sampling ratio in percent to sample the input matrix.
- setScalar(String, boolean) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a scalar boolean to a registered input variable.
- setScalar(String, boolean, boolean) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a scalar boolean to a registered input variable.
- setScalar(String, long) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a scalar long to a registered input variable.
- setScalar(String, long, boolean) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a scalar long to a registered input variable.
- setScalar(String, double) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a scalar double to a registered input variable.
- setScalar(String, double, boolean) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a scalar double to a registered input variable.
- setScalar(String, String) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a scalar string to a registered input variable.
- setScalar(String, String, boolean) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a scalar string to a registered input variable.
- setScalar(String, ScalarObject, boolean) - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Binds a scalar object to a registered input variable.
- setScalarOutput(String, ScalarObject) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- setSchema(List<Types.ValueType>) - Method in class org.apache.sysds.api.mlcontext.FrameSchema
-
Set the frame schema
- setSchema(String) - Method in class org.apache.sysds.runtime.controlprogram.caching.FrameObject
-
- setSchema(Types.ValueType[]) - Method in class org.apache.sysds.runtime.controlprogram.caching.FrameObject
-
- setSchema(Types.ValueType[]) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Sets the schema of the frame block.
- setSchemaAsString(String) - Method in class org.apache.sysds.api.mlcontext.FrameSchema
-
Set the frame schema, specifying the frame schema as a comma-separated
string
- setScriptExecutor(ScriptExecutor) - Method in class org.apache.sysds.api.mlcontext.Script
-
Set the ScriptExecutor used by this Script.
- setScriptString(String) - Method in class org.apache.sysds.api.mlcontext.Script
-
Set the script string.
- setScriptString(String) - Method in exception org.apache.sysds.parser.ParseException
-
Set the original DML/PyDML script string.
- setSeed(int) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
-
Set the seed for the compression operation.
- setSeed(long) - Method in class org.apache.sysds.runtime.util.NormalPRNGenerator
-
- setSeed(long) - Method in class org.apache.sysds.runtime.util.PoissonPRNGenerator
-
- setSeed(long) - Method in class org.apache.sysds.runtime.util.PRNGenerator
-
- setSeed(long) - Method in class org.apache.sysds.runtime.util.UniformPRNGenerator
-
- setSerialParFor() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
Set the plan to a parallel degree of 1 (serial execution).
- setSize(int) - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- setSkipList(boolean) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
-
Specify if the Offset list encoding should utilize skip lists.
- setSortValuesByLength(boolean) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
-
Set the sortValuesByLength flag.
- setSource(Expression) - Method in class org.apache.sysds.parser.AssignmentStatement
-
- setSource(FunctionCallIdentifier) - Method in class org.apache.sysds.parser.MultiAssignmentStatement
-
- setSparkCtxCreateTime(long) - Static method in class org.apache.sysds.utils.Statistics
-
- setSparkEagerCacheVariables(Collection<String>) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- setSparkRepartitionVariables(Collection<String>) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- setSparse(boolean) - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
-
- setSparseBlock(SparseBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- setSparseMatrixCudaPointer(CSRPointer) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Convenience method to directly set the sparse matrix on GPU
Needed for operations like cusparseDcsrgemm(cusparseHandle, int, int, int, int, int, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, int, Pointer, Pointer, Pointer, cusparseMatDescr, Pointer, Pointer, Pointer)
- setSparseSafe(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
-
- setSparseSafe(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
-
- setSparsity(double) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNodeStatistics
-
- setSpill(boolean) - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- setSplitDag(boolean) - Method in class org.apache.sysds.parser.StatementBlock
-
- setStatementBlock(StatementBlock) - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- setStatementBlocks(ArrayList<StatementBlock>) - Method in class org.apache.sysds.parser.DMLProgram
-
- setStatementFormatType(OutputStatement, boolean) - Method in class org.apache.sysds.parser.StatementBlock
-
- setStatementFormatType(AssignmentStatement, boolean) - Method in class org.apache.sysds.parser.StatementBlock
-
- setStatements(ArrayList<Statement>) - Method in class org.apache.sysds.parser.StatementBlock
-
- setStatistics(boolean) - Method in class org.apache.sysds.api.jmlc.Connection
-
Sets a boolean flag indicating if runtime statistics should be gathered
Same behavior as in "MLContext.setStatistics()"
- setStatistics(boolean) - Method in class org.apache.sysds.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.sysds.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.sysds.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.sysds.api.mlcontext.ScriptExecutor
-
Set the maximum number of heavy hitters to display with statistics.
- setStatus(boolean[]) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- setStorageLevel(StorageLevel) - Method in class org.apache.sysds.lops.Checkpoint
-
- setStrictEquals(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeData
-
- setSynopsis(Object) - Method in class org.apache.sysds.hops.estim.MMNode
-
- setTag(byte) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeTaggedMatrixIndexes
-
- setTarget(DataIdentifier) - Method in class org.apache.sysds.parser.AssignmentStatement
-
- setTargetList(List<DataIdentifier>) - Method in class org.apache.sysds.parser.MultiAssignmentStatement
-
- setTaskPartitioner(ParForProgramBlock.PTaskPartitioner) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- setTaskSize(long) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- setTensorDefault() - Method in class org.apache.sysds.parser.DataExpression
-
- setTensorOutput(String, TensorBlock) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- setText(String) - Method in class org.apache.sysds.hops.Hop
-
- setText(String) - Method in class org.apache.sysds.parser.ConditionalPredicate
-
- setText(String) - Method in class org.apache.sysds.parser.Expression
-
- setText(String) - Method in interface org.apache.sysds.parser.ParseInfo
-
- setText(String) - Method in class org.apache.sysds.parser.Statement
-
- setText(String) - Method in class org.apache.sysds.parser.StatementBlock
-
- setText(String) - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- setTextValue(String, String) - Method in class org.apache.sysds.conf.DMLConfig
-
Method to update the key value
- setThreadID(long) - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
-
- setThreadLocalSchedulerPool() - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- setTID(long) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- setTID(long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
-
- setTID(long) - Method in class org.apache.sysds.runtime.instructions.fed.FEDInstruction
-
- setToExpr(Expression) - Method in class org.apache.sysds.parser.IterablePredicate
-
- setToHops(Hop) - Method in class org.apache.sysds.parser.ForStatementBlock
-
- setToInstructions(ArrayList<Instruction>) - Method in class org.apache.sysds.runtime.controlprogram.ForProgramBlock
-
- setToLops(Lop) - Method in class org.apache.sysds.parser.ForStatementBlock
-
- setTransposeInput(boolean) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
-
Specify if the input matrix should be transposed before compression.
- setTransposeOutput(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeOuterProduct
-
- setTransposeSparseColumnVector(boolean) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
-
- setType(CNodeUnary.UnaryType) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeUnary
-
- setType(FederationMap.FType) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- setUnoptimizedFunctionCalls(StatementBlock) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
-
- setup(double, long) - Method in class org.apache.sysds.runtime.util.PoissonPRNGenerator
-
- setupBufferPool(long) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForUtils
-
Init and register-cleanup of buffer pool
- setUpdatedVariables(VariableSet) - Method in class org.apache.sysds.parser.LiveVariableAnalysis
-
- setUpdateInPlaceVars(ArrayList<String>) - Method in class org.apache.sysds.parser.StatementBlock
-
- setUpdateType(MatrixObject.UpdateType) - Method in class org.apache.sysds.hops.Hop
-
- setUpdateType(MatrixObject.UpdateType) - Method in class org.apache.sysds.lops.OutputParameters
-
- setUpdateType(MatrixObject.UpdateType) - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
-
- setupSeedsForRand(long) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDatagen
-
A matrix of random numbers is generated by using multiple seeds, one for each
block.
- setupThreadLocalMemory(int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- setupThreadLocalMemory(int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- setupThreadLocalMemory(int) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupValue
-
- setUUID(String) - Static method in class org.apache.sysds.api.DMLScript
-
Used to set master UUID on all nodes (in parfor remote, where DMLScript passed)
in order to simplify cleanup of scratch_space and local working dirs.
- setValidCompressions(EnumSet<ColGroup.CompressionType>) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
-
Set the valid compression strategies used for the compression.
- setValue(double) - Method in class org.apache.sysds.parser.DoubleIdentifier
-
- setValue(ArrayList<Expression>) - Method in class org.apache.sysds.parser.ExpressionList
-
- setValue(double) - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.Cell
-
- setValue(MatrixBlock, long) - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
-
- setValue(MatrixBlock) - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
-
- setValue(ScalarObject, long) - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
-
- setValue(int, int, double) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- setValue(int, int, double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- setValue(double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- setValue(int, int, double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- setValue(int, int, double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- setValue(V) - Method in class org.apache.sysds.runtime.matrix.data.Pair
-
- setValues(double[]) - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- setValueType(Types.ValueType) - Method in class org.apache.sysds.hops.Hop
-
- setValueType(Types.ValueType) - Method in class org.apache.sysds.lops.Lop
-
set value type of the output that is produced by this lop
- setValueType(Types.ValueType) - Method in class org.apache.sysds.parser.Identifier
-
- setVariable(String, Data) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- setVariables(LocalVariableMap) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- setVariablesInScript(String, HashMap<String, String>) - Static method in class org.apache.sysds.utils.ParameterBuilder
-
Replaces variables in a DML or R script with the specified values.
- setVariablesInScript(String, String, HashMap<String, String>) - Static method in class org.apache.sysds.utils.ParameterBuilder
-
Replaces variables in a DML or R script with the specified values.
- setVarID(long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
-
- setVarParams(HashMap<String, Expression>) - Method in class org.apache.sysds.parser.DataExpression
-
- setVisited() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- setVisited(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNode
-
- setVisited() - Method in class org.apache.sysds.hops.Hop
-
- setVisited(boolean) - Method in class org.apache.sysds.hops.Hop
-
- setVisited(Lop.VisitStatus) - Method in class org.apache.sysds.lops.Lop
-
set visit status of node
- setVisited() - Method in class org.apache.sysds.runtime.lineage.LineageItem
-
- setVisited(boolean) - Method in class org.apache.sysds.runtime.lineage.LineageItem
-
- SETWD - Static variable in class org.apache.sysds.parser.Statement
-
- setWeight(double) - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
-
- ShadowBuffer - Class in org.apache.sysds.runtime.instructions.gpu.context
-
- ShadowBuffer(GPUObject) - Constructor for class org.apache.sysds.runtime.instructions.gpu.context.ShadowBuffer
-
- SHALLOW_COPY_REORG - Static variable in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
- sharedMemBytes - Variable in class org.apache.sysds.runtime.instructions.gpu.context.ExecutionConfig
-
- shift(long, long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
-
- shiftColIndices(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroup
-
- ShiftColumnIndex(long, boolean) - Constructor for class org.apache.sysds.runtime.instructions.spark.AppendGAlignedSPInstruction.ShiftColumnIndex
-
- shiftLeft(int[], double[]) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixOuterAgg
-
This function will shift indices from one partition to next in left direction.
- ShiftMatrix(DataCharacteristics, DataCharacteristics, boolean) - Constructor for class org.apache.sysds.runtime.instructions.spark.AppendGSPInstruction.ShiftMatrix
-
- shiftRight(int[], double[]) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixOuterAgg
-
This function will shift indices from one partition to next in right direction.
- ShlosserEstimator - Class in org.apache.sysds.runtime.compress.estim.sample
-
- ShlosserEstimator() - Constructor for class org.apache.sysds.runtime.compress.estim.sample.ShlosserEstimator
-
- ShlosserJackknifeEstimator - Class in org.apache.sysds.runtime.compress.estim.sample
-
- ShlosserJackknifeEstimator() - Constructor for class org.apache.sysds.runtime.compress.estim.sample.ShlosserJackknifeEstimator
-
- shortToBa(int, byte[], int) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- shutdown() - Method in class org.apache.sysds.runtime.util.CommonThreadPool
-
- shutdownNow() - Method in class org.apache.sysds.runtime.util.CommonThreadPool
-
- shutdownReuse() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
-
- shutdownShared() - Static method in class org.apache.sysds.runtime.util.CommonThreadPool
-
- SideInput(DenseBlock, MatrixBlock, int) - Constructor for class org.apache.sysds.runtime.codegen.SpoofOperator.SideInput
-
- SideInputSparseCell(SpoofOperator.SideInput) - Constructor for class org.apache.sysds.runtime.codegen.SpoofOperator.SideInputSparseCell
-
- SideInputSparseRow(SpoofOperator.SideInput) - Constructor for class org.apache.sysds.runtime.codegen.SpoofOperator.SideInputSparseRow
-
- sigmoid(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs an "sigmoid" operation on a matrix on the GPU
- sign(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs an "sign" operation on a matrix on the GPU
- SimpleDataIdentifierExpressionContext(DmlParser.DataIdentifierContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.SimpleDataIdentifierExpressionContext
-
- SimpleOperator - Class in org.apache.sysds.runtime.matrix.operators
-
- SimpleOperator(FunctionObject) - Constructor for class org.apache.sysds.runtime.matrix.operators.SimpleOperator
-
- simplifyCPlan(CNodeTpl) - Method in class org.apache.sysds.hops.codegen.template.CPlanOpRewriter
-
- sin(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs an "sin" operation on a matrix on the GPU
- SinglePrecisionCudaSupportFunctions - Class in org.apache.sysds.runtime.matrix.data
-
- SinglePrecisionCudaSupportFunctions() - Constructor for class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
-
- sinh(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs an "sinh" operation on a matrix on the GPU
- SINIT_OPCODE - Static variable in class org.apache.sysds.lops.DataGen
-
- size() - Method in class org.apache.sysds.api.jmlc.ResultVariables
-
Obtain the number of output data held by this ResultVariables object.
- size - Variable in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- size() - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- size - Variable in class org.apache.sysds.runtime.compress.cocode.PlanningCoCoder.GroupableColInfo
-
- size - Variable in class org.apache.sysds.runtime.compress.CompressionStatistics
-
- size() - Method in class org.apache.sysds.runtime.compress.utils.CustomHashMap
-
- size() - Method in class org.apache.sysds.runtime.compress.utils.IntArrayList
-
- size() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
-
Gets the number of plan nodes.
- size() - Method in class org.apache.sysds.runtime.controlprogram.parfor.Task
-
- size() - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Get the length of the dense block as the product
of all dimensions.
- size(int) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Get the length of the given block.
- size(int) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
-
- size(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
-
- size() - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Get the number of non-zero values in the sparse block.
- size(int) - Method in class org.apache.sysds.runtime.data.SparseBlock
-
Get the number of non-zero values in row r.
- size(int, int) - Method in class org.apache.sysds.runtime.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.sysds.runtime.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.sysds.runtime.data.SparseBlockCOO
-
- size(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- size(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- size(int, int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- size() - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- size(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- size(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- size(int, int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- size() - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- size(int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- size(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- size(int, int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- size() - Method in class org.apache.sysds.runtime.data.SparseRow
-
Get the number of non-zero values of the sparse row.
- size() - Method in class org.apache.sysds.runtime.data.SparseRowScalar
-
- size() - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- size() - Method in class org.apache.sysds.runtime.io.ReaderTextCellParallel.CellBuffer
-
- size() - Method in class org.apache.sysds.runtime.matrix.data.CTableMap
-
- size() - Method in class org.apache.sysds.runtime.util.LongLongDoubleHashMap
-
- sizeInBytes - Variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNConvolutionAlgorithm
-
- sizeOfDataType - Static variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
- skipBytes(int) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
-
- skipBytes(int) - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
-
- skipBytes(int) - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
-
- skipConditionalInOuterProduct(Hop, HashMap<Long, CNode>, HashSet<Hop>) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- skipList - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
-
Boolean specifying if the OLE and RLE should construct skip to enable skipping large amounts of rows.
- skipTranspose(CNode, Hop, HashMap<Long, CNode>, boolean) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- slice(int, int, int, int, boolean, CacheBlock) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- slice(ArrayList<IndexedMatrixValue>, IndexRange, int, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- slice(int, int, int, int, CacheBlock) - Method in interface org.apache.sysds.runtime.controlprogram.caching.CacheBlock
-
Slice a sub block out of the current block and write into the given output block.
- slice(int, int, int, int, CacheBlock) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- slice(int[], TensorBlock) - Method in class org.apache.sysds.runtime.data.TensorBlock
-
Slice the current block and write into the outBlock.
- slice(int) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- slice(int, int) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- slice(String) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- slice(String, String) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- slice(long, long, long, long, T) - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBroadcast
-
Utility for slice operations over partitioned matrices, where the index range can cover
multiple blocks.
- slice(ArrayList<IndexedMatrixValue>, IndexRange, int, int, int, int, int) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- slice(IndexRange, FrameBlock) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- slice(int, int, int, int, CacheBlock) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
Right indexing operations to slice a subframe out of this frame block.
- slice(ArrayList<Pair<Long, FrameBlock>>, IndexRange, int) - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- slice(IndexRange, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- slice(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- slice(int, int, int, int, CacheBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- slice(int, int, int, int, boolean, CacheBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Method to perform rightIndex operation for a given lower and upper bounds in row and column dimensions.
- slice(ArrayList<IndexedMatrixValue>, IndexRange, int, int, int, int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- slice(ArrayList<IndexedMatrixValue>, IndexRange, int, int, int, int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- slice(ArrayList<IndexedMatrixValue>, IndexRange, int, int, int, int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
-
- sliceMatrix(MatrixObject, long, long) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
Slice the matrix
- sliceMatrixBlock(MatrixBlock, long, long) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
-
Slice the matrix block and return a matrix block
(used in spark)
- sliceOperations(ExecutionContext, GPUContext, String, MatrixObject, IndexRange, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Method to perform rightIndex operation for a given lower and upper bounds in row and column dimensions.
- smmdd(FloatBuffer, FloatBuffer, FloatBuffer, int, int, int, int) - Static method in class org.apache.sysds.utils.NativeHelper
-
- SmoothedJackknifeEstimator - Class in org.apache.sysds.runtime.compress.estim.sample
-
- SmoothedJackknifeEstimator() - Constructor for class org.apache.sysds.runtime.compress.estim.sample.SmoothedJackknifeEstimator
-
- softmax(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNN
-
Performs an "softmax" operation on a matrix on the GPU
- solve(ExecutionContext, GPUContext, String, MatrixObject, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Implements the "solve" function for systemds Ax = B (A is of size m*n, B is of size m*1, x is of size n*1)
- sort() - Method in class org.apache.sysds.runtime.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.sysds.runtime.data.SparseBlock
-
Sort all non-zero value/index pairs of row r column index.
- sort() - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- sort(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- sort() - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- sort(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- sort() - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- sort(int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- sort() - Method in class org.apache.sysds.runtime.data.SparseRow
-
In-place sort of column-index value pairs in order to allow binary search
after constant-time append was used for reading unordered sparse rows.
- sort() - Method in class org.apache.sysds.runtime.data.SparseRowScalar
-
- sort() - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- sort(MatrixBlock, MatrixBlock, int[], boolean, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
- sort(MatrixBlock, MatrixBlock, int[], boolean, boolean, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
- sortAndTruncate(ArrayList<Double>) - Method in class org.apache.sysds.hops.estim.EstimatorSampleRa
-
- sortByIndex(int, int, int[], double[]) - Static method in class org.apache.sysds.runtime.util.SortUtils
-
In-place sort of two arrays, only indexes is used for comparison and values
of same position are sorted accordingly.
- sortByIndex(int, int, int[], int[], double[]) - Static method in class org.apache.sysds.runtime.util.SortUtils
-
In-place sort of three arrays, only first indexes is used for comparison and second
indexes as well as values of same position are sorted accordingly.
- sortByVal(JavaPairRDD<MatrixIndexes, MatrixBlock>, long, int) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDSortUtils
-
- sortByVal(JavaPairRDD<MatrixIndexes, MatrixBlock>, JavaPairRDD<MatrixIndexes, MatrixBlock>, long, int) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDSortUtils
-
- sortByVals(JavaPairRDD<MatrixIndexes, MatrixBlock>, long, long, int) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDSortUtils
-
- sortByValue(int, int, double[], int[]) - Static method in class org.apache.sysds.runtime.util.SortUtils
-
- sortByValueStable(int, int, double[], int[]) - Static method in class org.apache.sysds.runtime.util.SortUtils
-
In-place sort of two arrays, only indexes is used for comparison and values
of same position are sorted accordingly.
- sortDataByIx(JavaPairRDD<MatrixIndexes, MatrixBlock>, JavaPairRDD<MatrixIndexes, MatrixBlock>, long, long, int) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDSortUtils
-
- sortDataByVal(JavaPairRDD<MatrixIndexes, MatrixBlock>, JavaPairRDD<MatrixIndexes, MatrixBlock>, boolean, long, long, int) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDSortUtils
-
- sortDataByValMemSort(JavaPairRDD<MatrixIndexes, MatrixBlock>, JavaPairRDD<MatrixIndexes, MatrixBlock>, boolean, long, long, int, SparkExecutionContext, ReorgOperator) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDSortUtils
-
This function collects and sorts value column in memory and then broadcasts it.
- sortDataByVals(JavaPairRDD<MatrixIndexes, MatrixBlock>, JavaPairRDD<MatrixIndexes, MatrixBlock>, boolean, long, long, long, int) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDSortUtils
-
- SortIndex - Class in org.apache.sysds.runtime.functionobjects
-
This index function is NOT used for actual sorting but just as a reference
in ReorgOperator in order to identify sort operations.
- SortIndex(int, boolean, boolean) - Constructor for class org.apache.sysds.runtime.functionobjects.SortIndex
-
- SortIndex(int[], boolean, boolean) - Constructor for class org.apache.sysds.runtime.functionobjects.SortIndex
-
- sortIndexesByVal(JavaPairRDD<MatrixIndexes, MatrixBlock>, boolean, long, int) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDSortUtils
-
- sortIndexesByVals(JavaPairRDD<MatrixIndexes, MatrixBlock>, boolean, long, long, int) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDSortUtils
-
- sortInputSplits(InputSplit[]) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- SortKeys - Class in org.apache.sysds.lops
-
- SortKeys(Lop, SortKeys.OperationTypes, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.SortKeys
-
- SortKeys(Lop, boolean, SortKeys.OperationTypes, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.SortKeys
-
- SortKeys(Lop, Lop, SortKeys.OperationTypes, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.SortKeys
-
- SortKeys.OperationTypes - Enum in org.apache.sysds.lops
-
- sortOperations(MatrixValue, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- sortOperations(MatrixValue, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- sortSparseRows() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Sorts all existing sparse rows by column indexes.
- sortSparseRows(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Sorts all existing sparse rows in range [rl,ru) by
column indexes.
- SortUtils - Class in org.apache.sysds.runtime.util
-
Utilities for sorting, primarily used for SparseRows.
- SortUtils() - Constructor for class org.apache.sysds.runtime.util.SortUtils
-
- sortValuesByFrequency() - Method in class org.apache.sysds.runtime.compress.utils.ABitmap
-
- sortValuesByFrequency() - Method in class org.apache.sysds.runtime.compress.utils.Bitmap
-
- sortValuesByFrequency() - Method in class org.apache.sysds.runtime.compress.utils.BitmapLossy
-
- sortValuesByLength - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
-
Sorting of values by physical length helps by 10-20%, especially for serial, while slight performance decrease
for parallel incl multi-threaded, hence not applied for distributed operations (also because compression time +
garbage collection increases)
- source - Variable in class org.apache.sysds.parser.dml.DmlParser.AccumulatorAssignmentStatementContext
-
- source - Variable in class org.apache.sysds.parser.dml.DmlParser.AssignmentStatementContext
-
- source - Variable in class org.apache.sysds.parser.dml.DmlParser.IfdefAssignmentStatementContext
-
- SOURCE - Static variable in class org.apache.sysds.parser.Statement
-
- SP_INST_PREFIX - Static variable in class org.apache.sysds.runtime.instructions.Instruction
-
- spark() - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Obtain SparkSession from MLContextProxy.
- SparkClusterConfig() - Constructor for class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext.SparkClusterConfig
-
- SparkDataPartitioner - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
-
- SparkExecutionContext - Class in org.apache.sysds.runtime.controlprogram.context
-
- SparkExecutionContext.SparkClusterConfig - Class in org.apache.sysds.runtime.controlprogram.context
-
Captures relevant spark cluster configuration properties, e.g., memory budgets and
degree of parallelism.
- SparkPSBody - Class in org.apache.sysds.runtime.controlprogram.paramserv
-
Wrapper class containing all needed for launching spark remote worker
- SparkPSBody() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.SparkPSBody
-
- SparkPSBody(ExecutionContext) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.SparkPSBody
-
- SparkPSProxy - Class in org.apache.sysds.runtime.controlprogram.paramserv
-
- SparkPSProxy(TransportClient, long, LongAccumulator) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.SparkPSProxy
-
- SparkPSWorker - Class in org.apache.sysds.runtime.controlprogram.paramserv
-
- SparkPSWorker(String, String, Statement.PSFrequency, int, long, String, HashMap<String, byte[]>, SparkConf, int, LongAccumulator, LongAccumulator, LongAccumulator, LongAccumulator, LongAccumulator, LongAccumulator, LongAccumulator, LongAccumulator) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.SparkPSWorker
-
- SparkUtils - Class in org.apache.sysds.runtime.instructions.spark.utils
-
- SparkUtils() - Constructor for class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- sparse - Variable in class org.apache.sysds.runtime.matrix.data.MatrixBlock.SparsityEstimate
-
- SPARSE_OUTPUTS_IN_CSR - Static variable in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
- SparseBlock - Class in org.apache.sysds.runtime.data
-
This SparseBlock is an abstraction for different sparse matrix formats.
- SparseBlock() - Constructor for class org.apache.sysds.runtime.data.SparseBlock
-
- SparseBlock.Type - Enum in org.apache.sysds.runtime.data
-
- SparseBlockCOO - Class in org.apache.sysds.runtime.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.sysds.runtime.data.SparseBlockCOO
-
- SparseBlockCOO(int, int) - Constructor for class org.apache.sysds.runtime.data.SparseBlockCOO
-
- SparseBlockCOO(SparseBlock) - Constructor for class org.apache.sysds.runtime.data.SparseBlockCOO
-
Copy constructor sparse block abstraction.
- SparseBlockCOO(SparseRow[], int) - Constructor for class org.apache.sysds.runtime.data.SparseBlockCOO
-
Copy constructor old sparse row representation.
- SparseBlockCSR - Class in org.apache.sysds.runtime.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.sysds.runtime.data.SparseBlockCSR
-
- SparseBlockCSR(int, int) - Constructor for class org.apache.sysds.runtime.data.SparseBlockCSR
-
- SparseBlockCSR(int[], int[], double[], int) - Constructor for class org.apache.sysds.runtime.data.SparseBlockCSR
-
- SparseBlockCSR(SparseBlock) - Constructor for class org.apache.sysds.runtime.data.SparseBlockCSR
-
Copy constructor sparse block abstraction.
- SparseBlockCSR(SparseRow[], int) - Constructor for class org.apache.sysds.runtime.data.SparseBlockCSR
-
Copy constructor old sparse row representation.
- SparseBlockCSR(int, int[], int[], double[]) - Constructor for class org.apache.sysds.runtime.data.SparseBlockCSR
-
Copy constructor for COO representation
- SparseBlockCSR(int, int, int[]) - Constructor for class org.apache.sysds.runtime.data.SparseBlockCSR
-
Copy constructor for given array of column indexes, which
identifies rows by position and implies values of 1.
- SparseBlockFactory - Class in org.apache.sysds.runtime.data
-
- SparseBlockFactory() - Constructor for class org.apache.sysds.runtime.data.SparseBlockFactory
-
- SparseBlockMCSR - Class in org.apache.sysds.runtime.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.sysds.runtime.data.SparseBlockMCSR
-
Copy constructor sparse block abstraction.
- SparseBlockMCSR(SparseRow[], boolean) - Constructor for class org.apache.sysds.runtime.data.SparseBlockMCSR
-
Copy constructor old sparse row representation.
- SparseBlockMCSR(int, int) - Constructor for class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- SparseRow - Class in org.apache.sysds.runtime.data
-
Base class for sparse row implementations such as sparse
row vectors and sparse scalars (single value per row).
- SparseRow() - Constructor for class org.apache.sysds.runtime.data.SparseRow
-
- SparseRowIterator - Class in org.apache.sysds.runtime.compress.colgroup
-
- SparseRowIterator(int, int, List<ColGroup>, int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.SparseRowIterator
-
- SparseRowScalar - Class in org.apache.sysds.runtime.data
-
- SparseRowScalar() - Constructor for class org.apache.sysds.runtime.data.SparseRowScalar
-
- SparseRowScalar(int, double) - Constructor for class org.apache.sysds.runtime.data.SparseRowScalar
-
- SparseRowVector - Class in org.apache.sysds.runtime.data
-
- SparseRowVector() - Constructor for class org.apache.sysds.runtime.data.SparseRowVector
-
- SparseRowVector(int) - Constructor for class org.apache.sysds.runtime.data.SparseRowVector
-
- SparseRowVector(int, int) - Constructor for class org.apache.sysds.runtime.data.SparseRowVector
-
- SparseRowVector(SparseRow) - Constructor for class org.apache.sysds.runtime.data.SparseRowVector
-
- sparseSafe - Variable in class org.apache.sysds.runtime.matrix.operators.Operator
-
- sparseScalarOperationsInPlace(ScalarOperator) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- sparseScalarOperationsInPlace(ScalarOperator) - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
-
- sparseToColumnMajorDense() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
More efficient method to convert sparse to dense but returns dense in column major format
- sparseToDense() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Convert sparse to dense (Performs transpose, use sparseToColumnMajorDense if the kernel can deal with column major format)
- sparseToDense(String) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Convert sparse to dense (Performs transpose, use sparseToColumnMajorDense if the kernel can deal with column major format)
Also records per instruction invokation of sparseToDense.
- sparseToDense() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- sparseUnaryOperationsInPlace(UnaryOperator) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
-
- sparseUnaryOperationsInPlace(UnaryOperator) - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
-
- SPARSITY_TURN_POINT - Static variable in class org.apache.sysds.runtime.data.BasicTensorBlock
-
- SPARSITY_TURN_POINT - Static variable in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- SparsityEstimate(boolean, long) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixBlock.SparsityEstimate
-
- SparsityEstimate() - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixBlock.SparsityEstimate
-
- SparsityEstimator - Class in org.apache.sysds.hops.estim
-
- SparsityEstimator() - Constructor for class org.apache.sysds.hops.estim.SparsityEstimator
-
- SparsityEstimator.OpCode - Enum in org.apache.sysds.hops.estim
-
- SPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- SPInstruction.SPType - Enum in org.apache.sysds.runtime.instructions.spark
-
- SPInstructionParser - Class in org.apache.sysds.runtime.instructions
-
- SPInstructionParser() - Constructor for class org.apache.sysds.runtime.instructions.SPInstructionParser
-
- split(String) - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- split(String, String) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
Splits a string by a specified delimiter into all tokens, including empty.
- splitByFirst(String, String) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- splitCSV(String, String) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
Splits a string by a specified delimiter into all tokens, including empty
while respecting the rules for quotes and escapes defined in RFC4180,
with robustness for various special cases.
- splitCSV(String, String, String[], Set<String>) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
Splits a string by a specified delimiter into all tokens, including empty
while respecting the rules for quotes and escapes defined in RFC4180,
with robustness for various special cases.
- splitFunctionKey(String) - Static method in class org.apache.sysds.parser.DMLProgram
-
- splitRecodeMapEntry(String) - Static method in class org.apache.sysds.runtime.transform.encode.EncoderRecode
-
Splits a Recode map entry into its token and code.
- SpoofCellwise - Class in org.apache.sysds.runtime.codegen
-
- SpoofCellwise(SpoofCellwise.CellType, boolean, boolean, SpoofCellwise.AggOp) - Constructor for class org.apache.sysds.runtime.codegen.SpoofCellwise
-
- SpoofCellwise.AggOp - Enum in org.apache.sysds.runtime.codegen
-
- SpoofCellwise.CellType - Enum in org.apache.sysds.runtime.codegen
-
- SpoofCompiler - Class in org.apache.sysds.hops.codegen
-
- SpoofCompiler() - Constructor for class org.apache.sysds.hops.codegen.SpoofCompiler
-
- SpoofCompiler.CompilerType - Enum in org.apache.sysds.hops.codegen
-
- SpoofCompiler.IntegrationType - Enum in org.apache.sysds.hops.codegen
-
- SpoofCompiler.PlanCachePolicy - Enum in org.apache.sysds.hops.codegen
-
- SpoofCompiler.PlanSelector - Enum in org.apache.sysds.hops.codegen
-
- SpoofCompiler.RegisterAlloc - Enum in org.apache.sysds.hops.codegen
-
- SpoofCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- SpoofFused - Class in org.apache.sysds.lops
-
- SpoofFused(ArrayList<Lop>, Types.DataType, Types.ValueType, Class<?>, int, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.SpoofFused
-
- SpoofFusedOp - Class in org.apache.sysds.hops.codegen
-
- SpoofFusedOp() - Constructor for class org.apache.sysds.hops.codegen.SpoofFusedOp
-
- SpoofFusedOp(String, Types.DataType, Types.ValueType, Class<?>, boolean, SpoofFusedOp.SpoofOutputDimsType) - Constructor for class org.apache.sysds.hops.codegen.SpoofFusedOp
-
- SpoofFusedOp.SpoofOutputDimsType - Enum in org.apache.sysds.hops.codegen
-
- SpoofMultiAggregate - Class in org.apache.sysds.runtime.codegen
-
- SpoofMultiAggregate(boolean, SpoofCellwise.AggOp...) - Constructor for class org.apache.sysds.runtime.codegen.SpoofMultiAggregate
-
- SpoofOperator - Class in org.apache.sysds.runtime.codegen
-
- SpoofOperator() - Constructor for class org.apache.sysds.runtime.codegen.SpoofOperator
-
- SpoofOperator.SideInput - Class in org.apache.sysds.runtime.codegen
-
- SpoofOperator.SideInputSparseCell - Class in org.apache.sysds.runtime.codegen
-
- SpoofOperator.SideInputSparseRow - Class in org.apache.sysds.runtime.codegen
-
- SpoofOuterProduct - Class in org.apache.sysds.runtime.codegen
-
- SpoofOuterProduct(SpoofOuterProduct.OutProdType) - Constructor for class org.apache.sysds.runtime.codegen.SpoofOuterProduct
-
- SpoofOuterProduct.OutProdType - Enum in org.apache.sysds.runtime.codegen
-
- SpoofRowwise - Class in org.apache.sysds.runtime.codegen
-
- SpoofRowwise(SpoofRowwise.RowType, long, boolean, int) - Constructor for class org.apache.sysds.runtime.codegen.SpoofRowwise
-
- SpoofRowwise.RowType - Enum in org.apache.sysds.runtime.codegen
-
- SpoofSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- SpoofSPInstruction.ReplicateRightFactorFunction - Class in org.apache.sysds.runtime.instructions.spark
-
- Sql - Class in org.apache.sysds.lops
-
- Sql(HashMap<String, Lop>, Types.DataType, Types.ValueType) - Constructor for class org.apache.sysds.lops.Sql
-
- SQL_CONN - Static variable in class org.apache.sysds.parser.DataExpression
-
- SQL_PASS - Static variable in class org.apache.sysds.parser.DataExpression
-
- SQL_QUERY - Static variable in class org.apache.sysds.parser.DataExpression
-
- SQL_USER - Static variable in class org.apache.sysds.parser.DataExpression
-
- SQL_VALID_PARAM_NAMES - Static variable in class org.apache.sysds.parser.DataExpression
-
- SqlCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- SqlCPInstruction(CPOperand, CPOperand, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysds.runtime.instructions.cp.SqlCPInstruction
-
- sqrt(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs an "sqrt" operation on a matrix on the GPU
- StagingFileUtils - Class in org.apache.sysds.runtime.controlprogram.parfor.util
-
- StagingFileUtils() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.util.StagingFileUtils
-
- start() - Method in class org.apache.sysds.runtime.controlprogram.parfor.stat.Timing
-
Starts the time measurement.
- start_indexes_h - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- start_indexes_w - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- startAggregation(MatrixValue, MatrixValue, AggregateOperator, int, int, boolean, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
-
- startCompileTimer() - Static method in class org.apache.sysds.utils.Statistics
-
- startRunTimer() - Static method in class org.apache.sysds.utils.Statistics
-
Starts the timer, should be invoked immediately before invoking
Program.execute()
- Stat - Enum in org.apache.sysds.runtime.controlprogram.parfor.stat
-
Collection of all ParFor statistic types.
- statement - Variable in class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
-
- statement() - Method in class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
-
- statement(int) - Method in class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
-
- statement - Variable in class org.apache.sysds.parser.dml.DmlParser.IfStatementContext
-
- statement() - Method in class org.apache.sysds.parser.dml.DmlParser.IfStatementContext
-
- statement(int) - Method in class org.apache.sysds.parser.dml.DmlParser.IfStatementContext
-
- statement - Variable in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
-
- statement() - Method in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
-
- statement(int) - Method in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
-
- statement - Variable in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
-
- statement() - Method in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
-
- statement(int) - Method in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
-
- statement - Variable in class org.apache.sysds.parser.dml.DmlParser.ProgramrootContext
-
- statement() - Method in class org.apache.sysds.parser.dml.DmlParser.ProgramrootContext
-
- statement(int) - Method in class org.apache.sysds.parser.dml.DmlParser.ProgramrootContext
-
- statement() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- statement - Variable in class org.apache.sysds.parser.dml.DmlParser.WhileStatementContext
-
- statement() - Method in class org.apache.sysds.parser.dml.DmlParser.WhileStatementContext
-
- statement(int) - Method in class org.apache.sysds.parser.dml.DmlParser.WhileStatementContext
-
- Statement - Class in org.apache.sysds.parser
-
- Statement() - Constructor for class org.apache.sysds.parser.Statement
-
- Statement.PSCheckpointing - Enum in org.apache.sysds.parser
-
- Statement.PSFrequency - Enum in org.apache.sysds.parser
-
- Statement.PSModeType - Enum in org.apache.sysds.parser
-
- Statement.PSScheme - Enum in org.apache.sysds.parser
-
- Statement.PSUpdateType - Enum in org.apache.sysds.parser
-
- StatementBlock - Class in org.apache.sysds.parser
-
- StatementBlock() - Constructor for class org.apache.sysds.parser.StatementBlock
-
- StatementBlock(StatementBlock) - Constructor for class org.apache.sysds.parser.StatementBlock
-
- StatementBlockRewriteRule - Class in org.apache.sysds.hops.rewrite
-
Base class for all hop rewrites in order to enable generic
application of all rules.
- StatementBlockRewriteRule() - Constructor for class org.apache.sysds.hops.rewrite.StatementBlockRewriteRule
-
- StatementContext(ParserRuleContext, int) - Constructor for class org.apache.sysds.parser.dml.DmlParser.StatementContext
-
- StatementContext() - Constructor for class org.apache.sysds.parser.dml.DmlParser.StatementContext
-
- StatementInfo - Class in org.apache.sysds.parser.dml
-
This class exists solely to prevent compiler warnings.
- StatementInfo() - Constructor for class org.apache.sysds.parser.dml.StatementInfo
-
- StatisticMonitor - Class in org.apache.sysds.runtime.controlprogram.parfor.stat
-
This singleton statistic monitor is used to consolidate all parfor runtime statistics.
- StatisticMonitor() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.stat.StatisticMonitor
-
- STATISTICS - Static variable in class org.apache.sysds.api.DMLScript
-
- statistics() - Method in class org.apache.sysds.api.jmlc.PreparedScript
-
Return a string containing runtime statistics.
- Statistics - Class in org.apache.sysds.utils
-
This class captures all statistics.
- Statistics() - Constructor for class org.apache.sysds.utils.Statistics
-
- STATISTICS_COUNT - Static variable in class org.apache.sysds.api.DMLScript
-
- STATISTICS_MAX_WRAP_LEN - Static variable in class org.apache.sysds.api.DMLScript
-
- stats - Variable in class org.apache.sysds.api.DMLOptions
-
- STATS_MAX_WRAP_LEN - Static variable in class org.apache.sysds.conf.DMLConfig
-
- statsCount - Variable in class org.apache.sysds.api.DMLOptions
-
- stmt - Variable in class org.apache.sysds.parser.dml.StatementInfo
-
- stop() - Method in class org.apache.sysds.runtime.controlprogram.parfor.stat.Timing
-
Measures and returns the time since the last start() or stop() invocation and
restarts the measurement.
- stopAndPrint() - Method in class org.apache.sysds.runtime.controlprogram.parfor.stat.Timing
-
Measures and returns the time since the last start() or stop() invocation,
restarts the measurement, and prints the last measurement to STDOUT.
- stopCompileTimer() - Static method in class org.apache.sysds.utils.Statistics
-
- stopRunTimer() - Static method in class org.apache.sysds.utils.Statistics
-
Stops the timer, should be invoked immediately after invoking
Program.execute()
- stream - Variable in class org.apache.sysds.runtime.instructions.gpu.context.ExecutionConfig
-
- strictParameterizedExpression - Variable in class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
-
- strictParameterizedExpression() - Method in class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
-
- strictParameterizedExpression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
-
- strictParameterizedExpression - Variable in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
-
- strictParameterizedExpression() - Method in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
-
- strictParameterizedExpression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
-
- strictParameterizedExpression() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- StrictParameterizedExpressionContext(ParserRuleContext, int) - Constructor for class org.apache.sysds.parser.dml.DmlParser.StrictParameterizedExpressionContext
-
- strictParameterizedKeyValueString - Variable in class org.apache.sysds.parser.dml.DmlParser.ExternalFunctionDefExpressionContext
-
- strictParameterizedKeyValueString() - Method in class org.apache.sysds.parser.dml.DmlParser.ExternalFunctionDefExpressionContext
-
- strictParameterizedKeyValueString(int) - Method in class org.apache.sysds.parser.dml.DmlParser.ExternalFunctionDefExpressionContext
-
- strictParameterizedKeyValueString() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- StrictParameterizedKeyValueStringContext(ParserRuleContext, int) - Constructor for class org.apache.sysds.parser.dml.DmlParser.StrictParameterizedKeyValueStringContext
-
- stride_h - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- stride_w - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- STRING - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- STRING() - Method in class org.apache.sysds.parser.dml.DmlParser.ConstStringIdExpressionContext
-
- STRING() - Method in class org.apache.sysds.parser.dml.DmlParser.ImportStatementContext
-
- STRING() - Method in class org.apache.sysds.parser.dml.DmlParser.PathStatementContext
-
- STRING() - Method in class org.apache.sysds.parser.dml.DmlParser.StrictParameterizedKeyValueStringContext
-
- STRING - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- String2BuiltinCode - Static variable in class org.apache.sysds.runtime.functionobjects.Builtin
-
- String2CPInstructionType - Static variable in class org.apache.sysds.runtime.instructions.CPInstructionParser
-
- String2DistCode - Static variable in class org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin
-
- String2FEDInstructionType - Static variable in class org.apache.sysds.runtime.instructions.FEDInstructionParser
-
- String2ParameterizedBuiltinCode - Static variable in class org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin
-
- String2SPInstructionType - Static variable in class org.apache.sysds.runtime.instructions.SPInstructionParser
-
- STRING_VALUE_TYPE - Static variable in class org.apache.sysds.parser.Statement
-
- stringDataFrameToVectorDataFrame(SparkSession, Dataset<Row>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtilsExt
-
Convert a dataframe of comma-separated string rows to a dataframe of
ml.linalg.Vector rows.
- StringIdentifier - Class in org.apache.sysds.parser
-
- StringIdentifier(String, ParseInfo) - Constructor for class org.apache.sysds.parser.StringIdentifier
-
- StringIdentifier(ParserRuleContext, String, String) - Constructor for class org.apache.sysds.parser.StringIdentifier
-
- StringInitCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- StringObject - Class in org.apache.sysds.runtime.instructions.cp
-
- StringObject(String) - Constructor for class org.apache.sysds.runtime.instructions.cp.StringObject
-
- stringToObject(Types.ValueType, String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- stringToSerializableText(JavaPairRDD<Long, String>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
-
- STRUCTURAL_PRUNING - Static variable in class org.apache.sysds.hops.codegen.opt.PlanSelectionFuseCostBasedV2
-
- submit(Callable<T>) - Method in class org.apache.sysds.runtime.util.CommonThreadPool
-
- submit(Runnable, T) - Method in class org.apache.sysds.runtime.util.CommonThreadPool
-
- submit(Runnable) - Method in class org.apache.sysds.runtime.util.CommonThreadPool
-
- SubProblem(int, int[], InterestingPoint[]) - Constructor for class org.apache.sysds.hops.codegen.opt.ReachabilityGraph.SubProblem
-
- subRangeDecoder(int, int, int) - Method in class org.apache.sysds.runtime.transform.decode.Decoder
-
Returns a new Decoder that only handles a sub range of columns.
- subRangeDecoder(int, int, int) - Method in class org.apache.sysds.runtime.transform.decode.DecoderComposite
-
- subRangeDecoder(int, int, int) - Method in class org.apache.sysds.runtime.transform.decode.DecoderDummycode
-
- subRangeDecoder(int, int, int) - Method in class org.apache.sysds.runtime.transform.decode.DecoderPassThrough
-
- subRangeDecoder(int, int, int) - Method in class org.apache.sysds.runtime.transform.decode.DecoderRecode
-
- subRangeEncoder(IndexRange) - Method in class org.apache.sysds.runtime.transform.encode.Encoder
-
Returns a new Encoder that only handles a sub range of columns.
- subRangeEncoder(IndexRange) - Method in class org.apache.sysds.runtime.transform.encode.EncoderBin
-
- subRangeEncoder(IndexRange) - Method in class org.apache.sysds.runtime.transform.encode.EncoderComposite
-
- subRangeEncoder(IndexRange) - Method in class org.apache.sysds.runtime.transform.encode.EncoderDummycode
-
- subRangeEncoder(IndexRange) - Method in class org.apache.sysds.runtime.transform.encode.EncoderFeatureHash
-
- subRangeEncoder(IndexRange) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
-
- subRangeEncoder(IndexRange) - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
-
- subRangeEncoder(IndexRange) - Method in class org.apache.sysds.runtime.transform.encode.EncoderPassThrough
-
- subRangeEncoder(IndexRange) - Method in class org.apache.sysds.runtime.transform.encode.EncoderRecode
-
- subsumes(CPlanMemoTable.MemoTableEntry) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- sum() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Wrapper method for reduceall-sum of a matrix.
- sumByKeyStable(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
- sumByKeyStable(JavaPairRDD<MatrixIndexes, MatrixBlock>, boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
- sumByKeyStable(JavaPairRDD<MatrixIndexes, MatrixBlock>, int, boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
- sumCellsByKeyStable(JavaPairRDD<MatrixIndexes, Double>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
- sumCellsByKeyStable(JavaPairRDD<MatrixIndexes, Double>, int) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
- sumSq() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
Wrapper method for reduceall-sumSq of a matrix.
- sumStable(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
- sumStable(JavaRDD<MatrixBlock>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
-
- sumWeightForQuantile() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
In a given two column matrix, the second column denotes weights.
- supportsMatrixScalarOperations() - Method in class org.apache.sysds.hops.BinaryOp
-
- suppressPrint2Stdout() - Static method in class org.apache.sysds.api.DMLScript
-
- swap(FrameBlock, List<Integer>, double) - Static method in class org.apache.sysds.utils.DataAugmentation
-
This function modifies the given, preprocessed frame block to add swapped fields of the same ValueType
that are consecutive, marking them with the label swap.
- SwapIndex - Class in org.apache.sysds.runtime.functionobjects
-
- SYNCHRONIZE_GPU - Static variable in class org.apache.sysds.api.DMLScript
-
- SYNCHRONIZE_GPU - Static variable in class org.apache.sysds.conf.DMLConfig
-
- syntaxError(Recognizer<?, ?>, Object, int, int, String, RecognitionException) - Method in class org.apache.sysds.parser.dml.CustomErrorListener
-
Syntax error occurred.
- SystemDSLoaderUtils - Class in org.apache.sysds.utils
-
- SystemDSLoaderUtils() - Constructor for class org.apache.sysds.utils.SystemDSLoaderUtils
-
- T__0 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__0 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__1 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__1 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__10 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__10 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__11 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__11 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__12 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__12 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__13 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__13 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__14 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__14 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__15 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__15 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__16 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__16 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__17 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__17 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__18 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__18 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__19 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__19 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__2 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__2 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__20 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__20 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__21 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__21 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__22 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__22 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__23 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__23 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__24 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__24 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__25 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__25 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__26 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__26 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__27 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__27 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__28 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__28 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__29 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__29 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__3 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__3 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__30 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__30 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__31 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__31 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__32 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__32 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__33 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__33 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__34 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__34 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__35 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__35 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__36 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__36 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__37 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__37 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__38 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__38 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__39 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__39 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__4 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__4 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__40 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__40 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__41 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__41 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__42 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__42 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__43 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__43 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__44 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__44 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__45 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__45 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__46 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__46 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__47 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__47 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__48 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__48 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__49 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__49 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__5 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__5 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__50 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__50 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__51 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__51 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__52 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__52 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__53 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__53 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__54 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__54 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__55 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__55 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__56 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__56 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__57 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__57 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__58 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__58 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__6 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__6 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__7 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__7 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__8 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__8 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- T__9 - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- T__9 - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- tan(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs an "tan" operation on a matrix on the GPU
- tanh(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Performs an "tanh" operation on a matrix on the GPU
- targetList - Variable in class org.apache.sysds.parser.dml.DmlParser.AccumulatorAssignmentStatementContext
-
- targetList - Variable in class org.apache.sysds.parser.dml.DmlParser.AssignmentStatementContext
-
- targetList - Variable in class org.apache.sysds.parser.dml.DmlParser.FunctionCallAssignmentStatementContext
-
- targetList - Variable in class org.apache.sysds.parser.dml.DmlParser.FunctionCallMultiAssignmentStatementContext
-
- targetList - Variable in class org.apache.sysds.parser.dml.DmlParser.IfdefAssignmentStatementContext
-
- targetList - Variable in class org.apache.sysds.parser.dml.DmlParser.MultiIdExpressionContext
-
- Task - Class in org.apache.sysds.runtime.controlprogram.parfor
-
A task is a logical group of one or multiple iterations (each iteration is assigned to exactly one task).
- Task() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.Task
-
- Task(String, Task.TaskType) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.Task
-
- Task.TaskType - Enum in org.apache.sysds.runtime.controlprogram.parfor
-
- TASK_PARTITIONER - Static variable in class org.apache.sysds.parser.ParForStatementBlock
-
- TASK_SIZE - Static variable in class org.apache.sysds.parser.ParForStatementBlock
-
- TaskPartitioner - Class in org.apache.sysds.runtime.controlprogram.parfor
-
This is the base class for all task partitioner.
- TaskPartitionerFactoring - Class in org.apache.sysds.runtime.controlprogram.parfor
-
This factoring task partitioner virtually iterates over the given FOR loop (from, to, incr),
creates iterations and group them to tasks.
- TaskPartitionerFactoring(long, int, String, IntObject, IntObject, IntObject) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.TaskPartitionerFactoring
-
- TaskPartitionerFactoringCmax - Class in org.apache.sysds.runtime.controlprogram.parfor
-
Factoring with maximum constraint (e.g., if LIX matrix out-of-core and we need
to bound the maximum number of iterations per map task -> memory bounds)
- TaskPartitionerFactoringCmax(long, int, long, String, IntObject, IntObject, IntObject) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.TaskPartitionerFactoringCmax
-
- TaskPartitionerFactoringCmin - Class in org.apache.sysds.runtime.controlprogram.parfor
-
Factoring with minimum constraint (e.g., if communication is expensive)
- TaskPartitionerFactoringCmin(long, int, long, String, IntObject, IntObject, IntObject) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.TaskPartitionerFactoringCmin
-
- TaskPartitionerFixedsize - Class in org.apache.sysds.runtime.controlprogram.parfor
-
This naive task partitioner virtually iterates over the given FOR loop (from, to, incr),
creates iterations and group them to tasks according to the given task size.
- TaskPartitionerFixedsize(long, String, IntObject, IntObject, IntObject) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.TaskPartitionerFixedsize
-
- TaskPartitionerNaive - Class in org.apache.sysds.runtime.controlprogram.parfor
-
This static task partitioner virtually iterates over the given FOR loop (from, to, incr),
creates iterations and group them to tasks according to a task size of numIterations/numWorkers.
- TaskPartitionerNaive(long, String, IntObject, IntObject, IntObject) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.TaskPartitionerNaive
-
- TaskPartitionerStatic - Class in org.apache.sysds.runtime.controlprogram.parfor
-
This static task partitioner virtually iterates over the given FOR loop (from, to, incr),
creates iterations and group them to tasks according to a task size of numIterations/numWorkers.
- TaskPartitionerStatic(long, int, String, IntObject, IntObject, IntObject) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.TaskPartitionerStatic
-
- TemplateBase - Class in org.apache.sysds.hops.codegen.template
-
- TemplateBase.CloseType - Enum in org.apache.sysds.hops.codegen.template
-
- TemplateBase.TemplateType - Enum in org.apache.sysds.hops.codegen.template
-
- TemplateCell - Class in org.apache.sysds.hops.codegen.template
-
- TemplateCell() - Constructor for class org.apache.sysds.hops.codegen.template.TemplateCell
-
- TemplateCell(TemplateBase.CloseType) - Constructor for class org.apache.sysds.hops.codegen.template.TemplateCell
-
- TemplateCell(TemplateBase.TemplateType, TemplateBase.CloseType) - Constructor for class org.apache.sysds.hops.codegen.template.TemplateCell
-
- TemplateCell.HopInputComparator - Class in org.apache.sysds.hops.codegen.template
-
Comparator to order input hops of the cell template.
- TemplateMultiAgg - Class in org.apache.sysds.hops.codegen.template
-
- TemplateMultiAgg() - Constructor for class org.apache.sysds.hops.codegen.template.TemplateMultiAgg
-
- TemplateMultiAgg(TemplateBase.CloseType) - Constructor for class org.apache.sysds.hops.codegen.template.TemplateMultiAgg
-
- TemplateOuterProduct - Class in org.apache.sysds.hops.codegen.template
-
- TemplateOuterProduct() - Constructor for class org.apache.sysds.hops.codegen.template.TemplateOuterProduct
-
- TemplateOuterProduct(TemplateBase.CloseType) - Constructor for class org.apache.sysds.hops.codegen.template.TemplateOuterProduct
-
- TemplateRow - Class in org.apache.sysds.hops.codegen.template
-
- TemplateRow() - Constructor for class org.apache.sysds.hops.codegen.template.TemplateRow
-
- TemplateRow(TemplateBase.CloseType) - Constructor for class org.apache.sysds.hops.codegen.template.TemplateRow
-
- TemplateRow.HopInputComparator - Class in org.apache.sysds.hops.codegen.template
-
Comparator to order input hops of the row aggregate template.
- TEMPLATES - Static variable in class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- TemplateUtils - Class in org.apache.sysds.hops.codegen.template
-
- TemplateUtils() - Constructor for class org.apache.sysds.hops.codegen.template.TemplateUtils
-
- TensorBlock - Class in org.apache.sysds.runtime.data
-
A TensorBlock
is the most top level representation of a tensor.
- TensorBlock() - Constructor for class org.apache.sysds.runtime.data.TensorBlock
-
Create a TensorBlock
with [0,0] dimension and homogeneous representation (aka.
- TensorBlock(int[], boolean) - Constructor for class org.apache.sysds.runtime.data.TensorBlock
-
Create a TensorBlock
with the given dimensions and the given data representation (basic/data).
- TensorBlock(Types.ValueType, int[]) - Constructor for class org.apache.sysds.runtime.data.TensorBlock
-
Create a basic TensorBlock
with the given ValueType
and the given dimensions.
- TensorBlock(Types.ValueType[], int[]) - Constructor for class org.apache.sysds.runtime.data.TensorBlock
-
Create a data TensorBlock
with the given schema and the given dimensions.
- TensorBlock(double) - Constructor for class org.apache.sysds.runtime.data.TensorBlock
-
Create a [1,1] basic FP64 TensorBlock
containing the given value.
- TensorBlock(BasicTensorBlock) - Constructor for class org.apache.sysds.runtime.data.TensorBlock
-
Wrap the given BasicTensorBlock
inside a TensorBlock
.
- TensorBlock(DataTensorBlock) - Constructor for class org.apache.sysds.runtime.data.TensorBlock
-
Wrap the given DataTensorBlock
inside a TensorBlock
.
- TensorBlock(TensorBlock) - Constructor for class org.apache.sysds.runtime.data.TensorBlock
-
Copy constructor
- TensorCharacteristics - Class in org.apache.sysds.runtime.meta
-
- TensorCharacteristics() - Constructor for class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- TensorCharacteristics(long[], long) - Constructor for class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- TensorCharacteristics(long[], int) - Constructor for class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- TensorCharacteristics(long[], int, long) - Constructor for class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- TensorCharacteristics(DataCharacteristics) - Constructor for class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- TensorIndexes - Class in org.apache.sysds.runtime.data
-
This represent the indexes to the blocks of the tensor.
- TensorIndexes() - Constructor for class org.apache.sysds.runtime.data.TensorIndexes
-
- TensorIndexes(long[]) - Constructor for class org.apache.sysds.runtime.data.TensorIndexes
-
- TensorIndexes(TensorIndexes) - Constructor for class org.apache.sysds.runtime.data.TensorIndexes
-
- TensorObject - Class in org.apache.sysds.runtime.controlprogram.caching
-
- TensorObject(String) - Constructor for class org.apache.sysds.runtime.controlprogram.caching.TensorObject
-
- TensorObject(Types.ValueType, String) - Constructor for class org.apache.sysds.runtime.controlprogram.caching.TensorObject
-
- TensorObject(String, MetaData) - Constructor for class org.apache.sysds.runtime.controlprogram.caching.TensorObject
-
- TensorObject(TensorObject) - Constructor for class org.apache.sysds.runtime.controlprogram.caching.TensorObject
-
Copy constructor that copies meta data but NO data.
- TensorReader - Class in org.apache.sysds.runtime.io
-
- TensorReader() - Constructor for class org.apache.sysds.runtime.io.TensorReader
-
- TensorReaderBinaryBlock - Class in org.apache.sysds.runtime.io
-
- TensorReaderBinaryBlock() - Constructor for class org.apache.sysds.runtime.io.TensorReaderBinaryBlock
-
- TensorReaderBinaryBlockParallel - Class in org.apache.sysds.runtime.io
-
- TensorReaderBinaryBlockParallel() - Constructor for class org.apache.sysds.runtime.io.TensorReaderBinaryBlockParallel
-
- TensorReaderFactory - Class in org.apache.sysds.runtime.io
-
- TensorReaderFactory() - Constructor for class org.apache.sysds.runtime.io.TensorReaderFactory
-
- TensorReaderTextCell - Class in org.apache.sysds.runtime.io
-
- TensorReaderTextCell() - Constructor for class org.apache.sysds.runtime.io.TensorReaderTextCell
-
- TensorReaderTextCellParallel - Class in org.apache.sysds.runtime.io
-
- TensorReaderTextCellParallel() - Constructor for class org.apache.sysds.runtime.io.TensorReaderTextCellParallel
-
- TensorTensorBinaryOpFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- TensorTensorBinaryOpFunction(BinaryOperator) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.TensorTensorBinaryOpFunction
-
- TensorTensorBinaryOpPartitionFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
-
- TensorTensorBinaryOpPartitionFunction(BinaryOperator, PartitionedBroadcast<TensorBlock>, boolean[]) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.TensorTensorBinaryOpPartitionFunction
-
- TensorWriter - Class in org.apache.sysds.runtime.io
-
- TensorWriter() - Constructor for class org.apache.sysds.runtime.io.TensorWriter
-
- TensorWriterBinaryBlock - Class in org.apache.sysds.runtime.io
-
- TensorWriterBinaryBlock() - Constructor for class org.apache.sysds.runtime.io.TensorWriterBinaryBlock
-
- TensorWriterBinaryBlockParallel - Class in org.apache.sysds.runtime.io
-
- TensorWriterBinaryBlockParallel() - Constructor for class org.apache.sysds.runtime.io.TensorWriterBinaryBlockParallel
-
- TensorWriterBinaryBlockParallel.WriteFileTask - Class in org.apache.sysds.runtime.io
-
- TensorWriterFactory - Class in org.apache.sysds.runtime.io
-
- TensorWriterFactory() - Constructor for class org.apache.sysds.runtime.io.TensorWriterFactory
-
- TensorWriterTextCell - Class in org.apache.sysds.runtime.io
-
- TensorWriterTextCell() - Constructor for class org.apache.sysds.runtime.io.TensorWriterTextCell
-
- TensorWriterTextCellParallel - Class in org.apache.sysds.runtime.io
-
- TensorWriterTextCellParallel() - Constructor for class org.apache.sysds.runtime.io.TensorWriterTextCellParallel
-
- Ternary - Class in org.apache.sysds.lops
-
Lop to perform Sum of a matrix with another matrix multiplied by Scalar.
- Ternary(Types.OpOp3, Lop, Lop, Lop, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.Ternary
-
- TernaryAggregate - Class in org.apache.sysds.lops
-
- TernaryAggregate(Lop, Lop, Lop, Types.AggOp, Types.OpOp2, Types.Direction, Types.DataType, Types.ValueType, LopProperties.ExecType, int) - Constructor for class org.apache.sysds.lops.TernaryAggregate
-
- TernaryCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- TernaryOp - Class in org.apache.sysds.hops
-
Primary use cases for now, are
quantile (<n-1-matrix>, <n-1-matrix>, <literal>): quantile (A, w, 0.5)
quantile (<n-1-matrix>, <n-1-matrix>, <scalar>): quantile (A, w, s)
interquantile (<n-1-matrix>, <n-1-matrix>, <scalar>): interquantile (A, w, s)
Keep in mind, that we also have binaries for it w/o weights.
- TernaryOp(String, Types.DataType, Types.ValueType, Types.OpOp3, Hop, Hop, Hop) - Constructor for class org.apache.sysds.hops.TernaryOp
-
- TernaryOp(String, Types.DataType, Types.ValueType, Types.OpOp3, Hop, Hop, Hop, Hop, Hop) - Constructor for class org.apache.sysds.hops.TernaryOp
-
- ternaryOperations(TernaryOperator, MatrixBlock, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- ternaryOperations(TernaryOperator, MatrixBlock, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- TernaryOperator - Class in org.apache.sysds.runtime.matrix.operators
-
- TernaryOperator(TernaryValueFunction) - Constructor for class org.apache.sysds.runtime.matrix.operators.TernaryOperator
-
- TernarySPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- TernaryValueFunction - Class in org.apache.sysds.runtime.functionobjects
-
- TernaryValueFunction() - Constructor for class org.apache.sysds.runtime.functionobjects.TernaryValueFunction
-
- TernaryValueFunction.ValueFunctionWithConstant - Interface in org.apache.sysds.runtime.functionobjects
-
- TextCellInputOutputInfo - Static variable in class org.apache.sysds.runtime.io.InputOutputInfo
-
- textCellToBinaryBlock(JavaSparkContext, JavaPairRDD<LongWritable, Text>, DataCharacteristics, Types.ValueType[]) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- textCellToBinaryBlock(JavaSparkContext, JavaPairRDD<LongWritable, Text>, DataCharacteristics, boolean, FileFormatPropertiesMM) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
-
- textCellToBinaryBlockLongIndex(JavaSparkContext, JavaPairRDD<Long, Text>, DataCharacteristics, Types.ValueType[]) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
-
- TextToBinaryCellConverter - Class in org.apache.sysds.runtime.matrix.data
-
- TextToBinaryCellConverter() - Constructor for class org.apache.sysds.runtime.matrix.data.TextToBinaryCellConverter
-
- TF_FN_PARAM_DATA - Static variable in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- TF_FN_PARAM_MTD - Static variable in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- TF_FN_PARAM_MTD2 - Static variable in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- TF_FN_PARAM_SPEC - Static variable in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- TfMetaUtils - Class in org.apache.sysds.runtime.transform.meta
-
- TfMetaUtils() - Constructor for class org.apache.sysds.runtime.transform.meta.TfMetaUtils
-
- TfOffsetMap - Class in org.apache.sysds.runtime.transform.meta
-
- TfOffsetMap(List<Pair<Long, Long>>) - Constructor for class org.apache.sysds.runtime.transform.meta.TfOffsetMap
-
- TfUtils - Class in org.apache.sysds.runtime.transform
-
- TfUtils() - Constructor for class org.apache.sysds.runtime.transform.TfUtils
-
- TfUtils.TfMethod - Enum in org.apache.sysds.runtime.transform
-
- throwExceptionFromResponse() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedResponse
-
Checks the data object array for exceptions that occurred in the federated worker
during handling of request.
- TIME_OPCODE - Static variable in class org.apache.sysds.lops.DataGen
-
- Timing - Class in org.apache.sysds.runtime.controlprogram.parfor.stat
-
Helper class for encapsulated time measurements.
- Timing() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.stat.Timing
-
- Timing(boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.stat.Timing
-
- to - Variable in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateColonExpressionContext
-
- to - Variable in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateSeqExpressionContext
-
- to - Variable in class org.apache.sysds.parser.dml.ExpressionInfo
-
- to2DDoubleArray() - Method in class org.apache.sysds.api.mlcontext.Matrix
-
Obtain the matrix as a two-dimensional double array
- to2DStringArray() - Method in class org.apache.sysds.api.mlcontext.Frame
-
Obtain the frame as a two-dimensional String array
- toBinaryBlocks() - Method in class org.apache.sysds.api.mlcontext.Frame
-
Obtain the frame as a JavaPairRDD<Long, FrameBlock>
- toBinaryBlocks() - Method in class org.apache.sysds.api.mlcontext.Matrix
-
Obtain the matrix as a JavaPairRDD<MatrixIndexes, MatrixBlock>
- toBitSet(double[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- toColumnMajorDenseMatrix(cusparseHandle, cublasHandle, int, int, String) - Method in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
Copies this CSR matrix on the GPU to a dense column-major matrix
on the GPU.
- toCompactString() - Method in class org.apache.sysds.runtime.controlprogram.parfor.Task
-
- toCompactString(int) - Method in class org.apache.sysds.runtime.controlprogram.parfor.Task
-
- toDF() - Method in class org.apache.sysds.api.mlcontext.Frame
-
Obtain the frame as a DataFrame
- toDF() - Method in class org.apache.sysds.api.mlcontext.Matrix
-
Obtain the matrix as a DataFrame
of doubles with an ID column
- toDFDoubleNoIDColumn() - Method in class org.apache.sysds.api.mlcontext.Matrix
-
Obtain the matrix as a DataFrame
of doubles with no ID column
- toDFDoubleWithIDColumn() - Method in class org.apache.sysds.api.mlcontext.Matrix
-
Obtain the matrix as a DataFrame
of doubles with an ID column
- toDFVectorNoIDColumn() - Method in class org.apache.sysds.api.mlcontext.Matrix
-
Obtain the matrix as a DataFrame
of vectors with no ID column
- toDFVectorWithIDColumn() - Method in class org.apache.sysds.api.mlcontext.Matrix
-
Obtain the matrix as a DataFrame
of vectors with an ID column
- toDouble(float[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- toDouble(long[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- toDouble(int[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- toDouble(BitSet, int) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- toDouble(String[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- toExternalString() - Method in enum org.apache.sysds.common.Types.ValueType
-
- toFloat(double[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- toFormatedString() - Method in class org.apache.sysds.runtime.controlprogram.parfor.Task
-
- toFrameBlock(RDDObject, Types.ValueType[], int, int) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- toFrameBlock(JavaPairRDD<Long, FrameBlock>, Types.ValueType[], int, int) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- toFrameJavaPairRDD(JavaSparkContext, FrameBlock) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- toFrameObject() - Method in class org.apache.sysds.api.mlcontext.Frame
-
Obtain the frame as a SystemDS FrameObject.
- toIndexedFrameBlock(Tuple2<Long, FrameBlock>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- toIndexedLong(List<Tuple2<Long, Long>>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- toIndexedMatrixBlock(Tuple2<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- toIndexedMatrixBlock(MatrixIndexes, MatrixBlock) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- toIndexedTensorBlock(Tuple2<TensorIndexes, TensorBlock>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- toIndexedTensorBlock(TensorIndexes, TensorBlock) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
-
- toInputStream(String) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- toInt(long) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
- toInt(double[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- toInt(double) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- toInt(Object) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- toIntExact(long) - Static method in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
- toIntExact(long) - Static method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
- toJavaRDDStringCSV() - Method in class org.apache.sysds.api.mlcontext.Frame
-
Obtain the frame as a JavaRDD<String>
in CSV format
- toJavaRDDStringCSV() - Method in class org.apache.sysds.api.mlcontext.Matrix
-
Obtain the matrix as a JavaRDD<String>
in CSV format
- toJavaRDDStringIJV() - Method in class org.apache.sysds.api.mlcontext.Frame
-
Obtain the frame as a JavaRDD<String>
in IJV format
- toJavaRDDStringIJV() - Method in class org.apache.sysds.api.mlcontext.Matrix
-
Obtain the matrix as a JavaRDD<String>
in IJV format
- toJson(JSONObject) - Method in class org.apache.sysds.runtime.privacy.PrivacyConstraint
-
Get privacy constraints and put them into JSON object.
- tokenize(String) - Method in class org.apache.sysds.runtime.lineage.LineageTokenizer
-
- tokenNames - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- tokenNames - Static variable in class org.apache.sysds.parser.dml.DmlParser
-
- toLong(double[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- toLong(double) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- toMatrixBlock() - Method in class org.apache.sysds.api.mlcontext.Matrix
-
Obtain the matrix as a MatrixBlock
- toMatrixBlock(RDDObject, int, int, int, long) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
This method is a generic abstraction for calls from the buffer pool.
- toMatrixBlock(JavaPairRDD<MatrixIndexes, MatrixBlock>, int, int, int, long) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
Utility method for creating a single matrix block out of a binary block RDD.
- toMatrixBlock(RDDObject, int, int, long) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- toMatrixBlock(JavaPairRDD<MatrixIndexes, MatrixCell>, int, int, long) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
Utility method for creating a single matrix block out of a binary cell RDD.
- toMatrixBlock(int, int) - Method in class org.apache.sysds.runtime.matrix.data.CTableMap
-
- toMatrixJavaPairRDD(JavaSparkContext, MatrixBlock, int) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- toMatrixJavaPairRDD(JavaSparkContext, MatrixBlock, int, int, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- toMatrixObject() - Method in class org.apache.sysds.api.mlcontext.Matrix
-
Obtain the matrix as a SystemDS MatrixObject.
- toMB(double) - Static method in class org.apache.sysds.hops.OptimizerUtils
-
- toMB(double) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerRuleBased
-
- toMillis(String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
-
- toNnz() - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap.DensityMap
-
- toParForExecMode() - Method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.ExecType
-
- toPartitionedMatrixBlock(JavaPairRDD<MatrixIndexes, MatrixBlock>, int, int, int, long) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- toRDDStringCSV() - Method in class org.apache.sysds.api.mlcontext.Frame
-
Obtain the frame as a RDD<String>
in CSV format
- toRDDStringCSV() - Method in class org.apache.sysds.api.mlcontext.Matrix
-
Obtain the matrix as a RDD<String>
in CSV format
- toRDDStringIJV() - Method in class org.apache.sysds.api.mlcontext.Frame
-
Obtain the frame as a RDD<String>
in IJV format
- toRDDStringIJV() - Method in class org.apache.sysds.api.mlcontext.Matrix
-
Obtain the matrix as a RDD<String>
in IJV format
- toShallowSerializeBlock() - Method in class org.apache.sysds.runtime.compress.AbstractCompressedMatrixBlock
-
- toShallowSerializeBlock() - Method in interface org.apache.sysds.runtime.controlprogram.caching.CacheBlock
-
Converts a cache block that is not shallow serializable into
a form that is shallow serializable.
- toShallowSerializeBlock() - Method in class org.apache.sysds.runtime.data.TensorBlock
-
- toShallowSerializeBlock() - Method in class org.apache.sysds.runtime.matrix.data.FrameBlock
-
- toShallowSerializeBlock() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- toSparsity() - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap.DensityMap
-
- toString() - Method in class org.apache.sysds.api.DMLOptions
-
- toString() - Method in class org.apache.sysds.api.mlcontext.Frame
-
- toString() - Method in class org.apache.sysds.api.mlcontext.Matrix
-
If MatrixObject
is available, output
MatrixObject.toString()
.
- toString() - Method in class org.apache.sysds.api.mlcontext.Metadata
-
- toString() - Method in exception org.apache.sysds.api.mlcontext.MLContextException
-
- toString() - Method in class org.apache.sysds.api.mlcontext.MLResults
-
- toString() - Method in class org.apache.sysds.api.mlcontext.ProjectInfo
-
- toString() - Method in class org.apache.sysds.api.mlcontext.Script
-
- toString() - Method in enum org.apache.sysds.common.Types.AggOp
-
- toString() - Method in enum org.apache.sysds.common.Types.Direction
-
- toString() - Method in enum org.apache.sysds.common.Types.FileFormat
-
- toString() - Method in enum org.apache.sysds.common.Types.OpOp1
-
- toString() - Method in enum org.apache.sysds.common.Types.OpOp2
-
- toString() - Method in enum org.apache.sysds.common.Types.OpOp3
-
- toString() - Method in enum org.apache.sysds.common.Types.OpOp4
-
- toString() - Method in enum org.apache.sysds.common.Types.OpOpData
-
- toString() - Method in enum org.apache.sysds.common.Types.ReOrgOp
-
- toString() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeBinary
-
- toString() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeData
-
- toString() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeNary
-
- toString() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTernary
-
- toString() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeUnary
-
- toString() - Method in class org.apache.sysds.hops.codegen.opt.InterestingPoint
-
- toString() - Method in class org.apache.sysds.hops.codegen.opt.ReachabilityGraph.SubProblem
-
- toString() - Method in class org.apache.sysds.hops.codegen.opt.ReachabilityGraph
-
- toString() - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- toString() - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntrySet
-
- toString() - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
-
- toString() - Method in class org.apache.sysds.hops.cost.VarStats
-
- toString() - Method in class org.apache.sysds.hops.ipa.FunctionCallSizeInfo
-
- toString() - Method in class org.apache.sysds.hops.LiteralOp
-
- toString() - Method in class org.apache.sysds.lops.Append
-
- toString() - Method in class org.apache.sysds.lops.AppendG
-
- toString() - Method in class org.apache.sysds.lops.AppendGAlignedSP
-
- toString() - Method in class org.apache.sysds.lops.AppendM
-
- toString() - Method in class org.apache.sysds.lops.AppendR
-
- toString() - Method in class org.apache.sysds.lops.Binary
-
- toString() - Method in class org.apache.sysds.lops.BinaryM
-
- toString() - Method in class org.apache.sysds.lops.BinaryScalar
-
- toString() - Method in class org.apache.sysds.lops.BinaryUAggChain
-
- toString() - Method in class org.apache.sysds.lops.CentralMoment
-
- toString() - Method in class org.apache.sysds.lops.Checkpoint
-
- toString() - Method in class org.apache.sysds.lops.Compression
-
- toString() - Method in class org.apache.sysds.lops.CoVariance
-
- toString() - Method in class org.apache.sysds.lops.CSVReBlock
-
- toString() - Method in class org.apache.sysds.lops.Ctable
-
- toString() - Method in class org.apache.sysds.lops.CumulativeOffsetBinary
-
- toString() - Method in class org.apache.sysds.lops.CumulativePartialAggregate
-
- toString() - Method in class org.apache.sysds.lops.Data
-
- toString() - Method in class org.apache.sysds.lops.DataGen
-
- toString() - Method in class org.apache.sysds.lops.DnnTransform
-
- toString() - Method in class org.apache.sysds.lops.Federated
-
- toString() - Method in class org.apache.sysds.lops.FunctionCallCP
-
- toString() - Method in class org.apache.sysds.lops.GroupedAggregate
-
- toString() - Method in class org.apache.sysds.lops.GroupedAggregateM
-
- toString() - Method in class org.apache.sysds.lops.LeftIndex
-
- toString() - Method in class org.apache.sysds.lops.Lop
-
Method to have Lops print their state.
- toString() - Method in class org.apache.sysds.lops.MapMult
-
- toString() - Method in class org.apache.sysds.lops.MapMultChain
-
- toString() - Method in class org.apache.sysds.lops.MatMultCP
-
- toString() - Method in class org.apache.sysds.lops.MMCJ
-
- toString() - Method in class org.apache.sysds.lops.MMRJ
-
- toString() - Method in class org.apache.sysds.lops.MMTSJ
-
- toString() - Method in class org.apache.sysds.lops.MMZip
-
- toString() - Method in class org.apache.sysds.lops.Nary
-
- toString() - Method in class org.apache.sysds.lops.OutputParameters
-
- toString() - Method in class org.apache.sysds.lops.ParameterizedBuiltin
-
- toString() - Method in class org.apache.sysds.lops.PartialAggregate
-
- toString() - Method in class org.apache.sysds.lops.PickByCount
-
- toString() - Method in class org.apache.sysds.lops.PMapMult
-
- toString() - Method in class org.apache.sysds.lops.PMMJ
-
- toString() - Method in class org.apache.sysds.lops.ReBlock
-
- toString() - Method in class org.apache.sysds.lops.RightIndex
-
- toString() - Method in class org.apache.sysds.lops.SortKeys
-
- toString() - Method in class org.apache.sysds.lops.SpoofFused
-
- toString() - Method in class org.apache.sysds.lops.Sql
-
- toString() - Method in class org.apache.sysds.lops.Ternary
-
- toString() - Method in class org.apache.sysds.lops.TernaryAggregate
-
- toString() - Method in class org.apache.sysds.lops.Transform
-
- toString() - Method in class org.apache.sysds.lops.UAggOuterChain
-
- toString() - Method in class org.apache.sysds.lops.Unary
-
- toString() - Method in class org.apache.sysds.lops.UnaryCP
-
- toString() - Method in class org.apache.sysds.lops.WeightedCrossEntropy
-
- toString() - Method in class org.apache.sysds.lops.WeightedCrossEntropyR
-
- toString() - Method in class org.apache.sysds.lops.WeightedDivMM
-
- toString() - Method in class org.apache.sysds.lops.WeightedDivMMR
-
- toString() - Method in class org.apache.sysds.lops.WeightedSigmoid
-
- toString() - Method in class org.apache.sysds.lops.WeightedSigmoidR
-
- toString() - Method in class org.apache.sysds.lops.WeightedSquaredLoss
-
- toString() - Method in class org.apache.sysds.lops.WeightedSquaredLossR
-
- toString() - Method in class org.apache.sysds.lops.WeightedUnaryMM
-
- toString() - Method in class org.apache.sysds.lops.WeightedUnaryMMR
-
- toString() - Method in class org.apache.sysds.parser.AssignmentStatement
-
- toString() - Method in class org.apache.sysds.parser.BinaryExpression
-
- toString() - Method in class org.apache.sysds.parser.BooleanExpression
-
- toString() - Method in class org.apache.sysds.parser.BooleanIdentifier
-
- toString() - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- toString() - Method in class org.apache.sysds.parser.ConditionalPredicate
-
- toString() - Method in class org.apache.sysds.parser.DataExpression
-
- toString() - Method in class org.apache.sysds.parser.DataIdentifier
-
- toString() - Method in class org.apache.sysds.parser.DMLProgram
-
- toString() - Method in class org.apache.sysds.parser.DoubleIdentifier
-
- toString() - Method in class org.apache.sysds.parser.ExpressionList
-
- toString() - Method in class org.apache.sysds.parser.ForStatement
-
- toString() - Method in class org.apache.sysds.parser.FunctionCallIdentifier
-
- toString() - Method in class org.apache.sysds.parser.FunctionStatement
-
- toString() - Method in class org.apache.sysds.parser.IfStatement
-
- toString() - Method in class org.apache.sysds.parser.ImportStatement
-
- toString() - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- toString() - Method in class org.apache.sysds.parser.IntIdentifier
-
- toString() - Method in class org.apache.sysds.parser.IterablePredicate
-
- toString() - Method in class org.apache.sysds.parser.MultiAssignmentStatement
-
- toString() - Method in class org.apache.sysds.parser.OutputStatement
-
- toString() - Method in class org.apache.sysds.parser.ParameterExpression
-
- toString() - Method in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- toString() - Method in class org.apache.sysds.parser.ParForStatement
-
- toString() - Method in class org.apache.sysds.parser.ParForStatementBlock.ResultVar
-
- toString() - Method in class org.apache.sysds.parser.PathStatement
-
- toString() - Method in class org.apache.sysds.parser.PrintStatement
-
- toString() - Method in class org.apache.sysds.parser.RelationalExpression
-
- toString() - Method in class org.apache.sysds.parser.StatementBlock
-
- toString() - Method in class org.apache.sysds.parser.StringIdentifier
-
- toString() - Method in class org.apache.sysds.parser.VariableSet
-
- toString() - Method in class org.apache.sysds.parser.WhileStatement
-
- toString() - Method in class org.apache.sysds.runtime.compress.cocode.PlanningCoCodingGroup
-
- toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
-
- toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC1
-
- toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC2
-
- toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOffset
-
- toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
-
- toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
-
- toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupValue
-
- toString() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- toString() - Method in class org.apache.sysds.runtime.compress.CompressionSettings
-
- toString() - Method in class org.apache.sysds.runtime.compress.CompressionStatistics
-
- toString() - Method in class org.apache.sysds.runtime.compress.estim.EstimationFactors
-
- toString() - Method in class org.apache.sysds.runtime.compress.utils.ABitmap
-
- toString() - Method in class org.apache.sysds.runtime.compress.utils.Bitmap
-
- toString() - Method in class org.apache.sysds.runtime.compress.utils.BitmapLossy
-
- toString() - Method in class org.apache.sysds.runtime.compress.utils.DblArray
-
- toString() - Method in class org.apache.sysds.runtime.compress.utils.IntArrayList
-
- toString() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
-
- toString() - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- toString() - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext.SparkClusterConfig
-
- toString() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
-
- toString() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
-
- toString() - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
-
- toString() - Method in class org.apache.sysds.runtime.controlprogram.parfor.LocalTaskQueue
-
- toString() - Method in class org.apache.sysds.runtime.controlprogram.parfor.Task
-
- toString() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
-
- toString() - Method in class org.apache.sysds.runtime.data.DenseBlock
-
- toString() - Method in class org.apache.sysds.runtime.data.IndexedTensorBlock
-
- toString() - Method in class org.apache.sysds.runtime.data.SparseBlock
-
- toString() - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
- toString() - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- toString() - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- toString() - Method in class org.apache.sysds.runtime.data.SparseRow
-
- toString() - Method in class org.apache.sysds.runtime.data.TensorIndexes
-
- toString() - Method in class org.apache.sysds.runtime.functionobjects.Builtin
-
- toString() - Method in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
-
- toString() - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
-
- toString() - Method in class org.apache.sysds.runtime.instructions.cp.KahanObject
-
- toString() - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
-
- toString() - Method in class org.apache.sysds.runtime.instructions.cp.ScalarObject
-
- toString() - Method in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
- toString() - Method in class org.apache.sysds.runtime.instructions.gpu.context.ExecutionConfig
-
- toString() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
-
- toString() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryManager
-
Print debugging information
- toString() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
- toString() - Method in class org.apache.sysds.runtime.instructions.Instruction
-
- toString() - Method in class org.apache.sysds.runtime.instructions.spark.data.IndexedMatrixValue
-
- toString() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
-
- toString() - Method in enum org.apache.sysds.runtime.io.FileFormatPropertiesMM.MMField
-
- toString() - Method in enum org.apache.sysds.runtime.io.FileFormatPropertiesMM.MMFormat
-
- toString() - Method in enum org.apache.sysds.runtime.io.FileFormatPropertiesMM.MMSymmetry
-
- toString(InputStream) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
-
- toString() - Method in class org.apache.sysds.runtime.lineage.LineageItem
-
- toString() - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
-
- toString() - Method in class org.apache.sysds.runtime.matrix.data.DnnParameters
-
- toString() - Method in class org.apache.sysds.runtime.matrix.data.IJV
-
- toString() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- toString() - Method in class org.apache.sysds.runtime.matrix.data.MatrixIndexes
-
- toString() - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue.CellIndex
-
- toString() - Method in class org.apache.sysds.runtime.matrix.data.RandomMatrixGenerator
-
- toString() - Method in class org.apache.sysds.runtime.matrix.data.TripleIndexes
-
- toString() - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
-
- toString() - Method in class org.apache.sysds.runtime.matrix.data.WeightedPair
-
- toString() - Method in class org.apache.sysds.runtime.matrix.operators.BinaryOperator
-
- toString() - Method in class org.apache.sysds.runtime.matrix.operators.TernaryOperator
-
- toString() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
-
- toString() - Method in class org.apache.sysds.runtime.meta.MetaData
-
- toString() - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
-
- toString() - Method in class org.apache.sysds.runtime.privacy.finegrained.DataRange
-
- toString() - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyList
-
- toString() - Method in class org.apache.sysds.runtime.transform.encode.EncoderComposite
-
- toString() - Method in enum org.apache.sysds.runtime.transform.TfUtils.TfMethod
-
- toString(MatrixBlock) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- toString(MatrixBlock, boolean, String, String, int, int, int) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
Returns a string representation of a matrix
- toString(TensorBlock) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- toString(TensorBlock, boolean, String, String, String, String, int, int, int) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
Returns a string representation of a tensor
- toString(FrameBlock) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- toString(FrameBlock, boolean, String, String, int, int, int) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- toString(ListObject, int, int, boolean, String, String, int, int, int) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- toString(double[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
-
- toString() - Method in class org.apache.sysds.runtime.util.IndexRange
-
- toTensorBlock(JavaPairRDD<TensorIndexes, TensorBlock>, DataCharacteristics) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- toTensorJavaPairRDD(JavaSparkContext, TensorBlock, int) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- toTensorJavaPairRDD(JavaSparkContext, TensorBlock, int, int, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
-
- trace(Instruction, ExecutionContext) - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- trace(Instruction, ExecutionContext) - Method in class org.apache.sysds.runtime.lineage.LineageMap
-
- traceBasicProgramBlock(BasicProgramBlock, ExecutionContext, Collection<Map.Entry<Long, LineageMap>>) - Method in class org.apache.sysds.runtime.lineage.LineageDedupBlock
-
- traceCurrentDedupPath(ProgramBlock, ExecutionContext) - Method in class org.apache.sysds.runtime.lineage.Lineage
-
- traceIfProgramBlock(IfProgramBlock, ExecutionContext, Collection<Map.Entry<Long, LineageMap>>) - Method in class org.apache.sysds.runtime.lineage.LineageDedupBlock
-
- traceLineage(Instruction) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
-
- traceProgramBlock(ProgramBlock, ExecutionContext, Collection<Map.Entry<Long, LineageMap>>) - Method in class org.apache.sysds.runtime.lineage.LineageDedupBlock
-
- traceProgramBlocks(ArrayList<ProgramBlock>, ExecutionContext) - Method in class org.apache.sysds.runtime.lineage.LineageDedupBlock
-
- Transform - Class in org.apache.sysds.lops
-
- Transform(Lop, Types.ReOrgOp, Types.DataType, Types.ValueType, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.Transform
-
- Transform(Lop[], Types.ReOrgOp, Types.DataType, Types.ValueType, boolean, LopProperties.ExecType) - Constructor for class org.apache.sysds.lops.Transform
-
- Transform(Lop, Types.ReOrgOp, Types.DataType, Types.ValueType, LopProperties.ExecType, int) - Constructor for class org.apache.sysds.lops.Transform
-
- Transform(Lop[], Types.ReOrgOp, Types.DataType, Types.ValueType, LopProperties.ExecType, int) - Constructor for class org.apache.sysds.lops.Transform
-
- Transform(Lop, Types.ReOrgOp, Types.DataType, Types.ValueType, LopProperties.ExecType, boolean) - Constructor for class org.apache.sysds.lops.Transform
-
- Transform(Lop[], Types.ReOrgOp, Types.DataType, Types.ValueType, LopProperties.ExecType, boolean) - Constructor for class org.apache.sysds.lops.Transform
-
- Transform(Lop[], Types.ReOrgOp, Types.DataType, Types.ValueType, LopProperties.ExecType, boolean, int) - Constructor for class org.apache.sysds.lops.Transform
-
- TransformEncodeBuild2Function(EncoderMVImpute) - Constructor for class org.apache.sysds.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeBuild2Function
-
- TransformEncodeBuildFunction(Encoder) - Constructor for class org.apache.sysds.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeBuildFunction
-
- TransformEncodeGroup2Function(EncoderMVImpute) - Constructor for class org.apache.sysds.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeGroup2Function
-
- TransformEncodeGroupFunction(MultiReturnParameterizedBuiltinSPInstruction.MaxLongAccumulator) - Constructor for class org.apache.sysds.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeGroupFunction
-
- transpose() - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix
-
- transpose() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
-
- transpose() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
-
- transpose(GPUContext, Pointer, int, int, int, int) - Static method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
-
Transposes a dense matrix on the GPU by calling the cublasDgeam operation
- transpose(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
-
Transposes the input matrix using cublasDgeam
- transpose(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
- transpose(MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
-
- transposeInput - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
-
Transpose input matrix, to optimize performance, this reallocate the matrix to a more cache conscious allocation
for iteration in columns.
- transposeSelfMatrixMultOperations(MatrixBlock, MMTSJ.MMTSJType) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- transposeSelfMatrixMultOperations(MatrixBlock, MMTSJ.MMTSJType, int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
-
- transposeSelfMatrixMultOperations(MatrixBlock, MMTSJ.MMTSJType) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- transposeSelfMatrixMultOperations(MatrixBlock, MMTSJ.MMTSJType, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
-
- TripleIndexes - Class in org.apache.sysds.runtime.matrix.data
-
- TripleIndexes() - Constructor for class org.apache.sysds.runtime.matrix.data.TripleIndexes
-
- TripleIndexes(long, long, long) - Constructor for class org.apache.sysds.runtime.matrix.data.TripleIndexes
-
- TripleIndexes(TripleIndexes) - Constructor for class org.apache.sysds.runtime.matrix.data.TripleIndexes
-
- TripleIndexes.Comparator - Class in org.apache.sysds.runtime.matrix.data
-
- trueStringLiteral() - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- tsmm(MatrixBlock, MatrixBlock, boolean, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixNative
-
- tsmm(double[], double[], int, int, boolean, int) - Static method in class org.apache.sysds.utils.NativeHelper
-
- Tsmm2SPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- TsmmFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
-
- TsmmFEDInstruction(CPOperand, CPOperand, MMTSJ.MMTSJType, int, String, String) - Constructor for class org.apache.sysds.runtime.instructions.fed.TsmmFEDInstruction
-
- TsmmSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
-
- TXMTD_BIN_FILE_SUFFIX - Static variable in class org.apache.sysds.runtime.transform.TfUtils
-
- TXMTD_COLNAMES - Static variable in class org.apache.sysds.runtime.transform.TfUtils
-
- TXMTD_MV_FILE_SUFFIX - Static variable in class org.apache.sysds.runtime.transform.TfUtils
-
- TXMTD_MVPREFIX - Static variable in class org.apache.sysds.runtime.transform.TfUtils
-
- TXMTD_NDPREFIX - Static variable in class org.apache.sysds.runtime.transform.TfUtils
-
- TXMTD_RCD_DISTINCT_SUFFIX - Static variable in class org.apache.sysds.runtime.transform.TfUtils
-
- TXMTD_RCD_MAP_SUFFIX - Static variable in class org.apache.sysds.runtime.transform.TfUtils
-
- TXMTD_SEP - Static variable in class org.apache.sysds.runtime.transform.TfUtils
-
- type - Variable in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
-
- typedArgAssign - Variable in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
-
- typedArgAssign() - Method in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
-
- typedArgAssign(int) - Method in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
-
- typedArgAssign() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- TypedArgAssignContext(ParserRuleContext, int) - Constructor for class org.apache.sysds.parser.dml.DmlParser.TypedArgAssignContext
-
- typedArgNoAssign - Variable in class org.apache.sysds.parser.dml.DmlParser.ExternalFunctionDefExpressionContext
-
- typedArgNoAssign() - Method in class org.apache.sysds.parser.dml.DmlParser.ExternalFunctionDefExpressionContext
-
- typedArgNoAssign(int) - Method in class org.apache.sysds.parser.dml.DmlParser.ExternalFunctionDefExpressionContext
-
- typedArgNoAssign - Variable in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
-
- typedArgNoAssign() - Method in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
-
- typedArgNoAssign(int) - Method in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
-
- typedArgNoAssign() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- TypedArgNoAssignContext(ParserRuleContext, int) - Constructor for class org.apache.sysds.parser.dml.DmlParser.TypedArgNoAssignContext
-
- Types - Class in org.apache.sysds.common
-
- Types() - Constructor for class org.apache.sysds.common.Types
-
- Types.AggOp - Enum in org.apache.sysds.common
-
- Types.BlockType - Enum in org.apache.sysds.common
-
Serialization block types (empty, dense, sparse, ultra-sparse)
- Types.CorrectionLocationType - Enum in org.apache.sysds.common
-
- Types.DataType - Enum in org.apache.sysds.common
-
Data types (tensor, matrix, scalar, frame, object, unknown).
- Types.Direction - Enum in org.apache.sysds.common
-
Type of aggregation direction
- Types.ExecMode - Enum in org.apache.sysds.common
-
Execution mode for entire script.
- Types.ExecType - Enum in org.apache.sysds.common
-
Execution type of individual operations.
- Types.FileFormat - Enum in org.apache.sysds.common
-
- Types.FunctionBlock - Interface in org.apache.sysds.common
-
Common type for both function statement blocks and function program blocks
- Types.OpOp1 - Enum in org.apache.sysds.common
-
- Types.OpOp2 - Enum in org.apache.sysds.common
-
- Types.OpOp3 - Enum in org.apache.sysds.common
-
- Types.OpOp4 - Enum in org.apache.sysds.common
-
- Types.OpOpData - Enum in org.apache.sysds.common
-
- Types.OpOpDG - Enum in org.apache.sysds.common
-
- Types.OpOpDnn - Enum in org.apache.sysds.common
-
- Types.OpOpN - Enum in org.apache.sysds.common
-
- Types.ParamBuiltinOp - Enum in org.apache.sysds.common
-
- Types.ReOrgOp - Enum in org.apache.sysds.common
-
- Types.ReturnType - Enum in org.apache.sysds.common
-
Type of builtin or user-defined function with regard to its
number of return variables.
- Types.ValueType - Enum in org.apache.sysds.common
-
Value types (int, double, string, boolean, unknown).
- typos(FrameBlock, List<Integer>, double) - Static method in class org.apache.sysds.utils.DataAugmentation
-
This function modifies the given, preprocessed frame block to add typos to the string values,
marking them with the label typos.
- val - Variable in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
-
double array of non zero values
- validate(DMLProgram, VariableSet, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.ForStatementBlock
-
- validate(DMLProgram, VariableSet, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.FunctionStatementBlock
-
TODO: DRB: This needs to be changed to reflect:
1) Default values for variables -- need to add R styled check here to make sure that once vars with
default values start, they keep going to the right
2) The other parameters for External Functions
- validate(DMLProgram, VariableSet, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.IfStatementBlock
-
- validate(DMLProgram, VariableSet, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.ParForStatementBlock
-
- validate(DMLProgram, VariableSet, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.StatementBlock
-
- validate(DMLProgram, VariableSet, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.WhileStatementBlock
-
- validateExpression(HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.BinaryExpression
-
Validate parse tree : Process Binary Expression in an assignment
statement
- validateExpression(HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.BooleanExpression
-
Validate parse tree : Process Boolean Expression
- validateExpression(MultiAssignmentStatement, HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- validateExpression(HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
Validate parse tree : Process BuiltinFunction Expression in an assignment
statement
- validateExpression(HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.DataExpression
-
Validate parse tree : Process Data Expression in an assignment
statement
- validateExpression(HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.Expression
-
- validateExpression(MultiAssignmentStatement, HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.Expression
-
- validateExpression(HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.ExpressionList
-
- validateExpression(DMLProgram, HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.FunctionCallIdentifier
-
Validate parse tree : Process ExtBuiltinFunction Expression is an
assignment statement
NOTE: this does not override the normal validateExpression because it needs to pass dmlp!
- validateExpression(HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.Identifier
-
- validateExpression(HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.IterablePredicate
-
- validateExpression(HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
Validate parse tree : Process BuiltinFunction Expression in an assignment
statement
- validateExpression(MultiAssignmentStatement, HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- validateExpression(HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.RelationalExpression
-
Validate parse tree : Process Relational Expression
- validateFunction(DMLProgram, FunctionStatementBlock) - Method in class org.apache.sysds.parser.DMLTranslator
-
- validateHopDag(ArrayList<Hop>, HopRewriteRule) - Static method in class org.apache.sysds.hops.rewrite.HopDagValidator
-
- validateHopDag(Hop, HopRewriteRule) - Static method in class org.apache.sysds.hops.rewrite.HopDagValidator
-
- validateParseTree(DMLProgram) - Method in class org.apache.sysds.parser.DMLTranslator
-
- validateParseTree(DMLProgram, boolean) - Method in class org.apache.sysds.parser.DMLTranslator
-
- validationError(int, int, String) - Method in class org.apache.sysds.parser.dml.CustomErrorListener
-
Validation error occurred.
- validationError(ParseInfo, String) - Method in class org.apache.sysds.parser.dml.CustomErrorListener
-
- validationWarning(int, int, String) - Method in class org.apache.sysds.parser.dml.CustomErrorListener
-
Validation warning occurred.
- VALIDATOR_IGNORE_ISSUES - Static variable in class org.apache.sysds.api.DMLScript
-
If true, allow DMLProgram to be generated while not halting due to validation errors/warnings
- validCompressions - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
-
Valid Compressions List, containing the ColGroup CompressionTypes that are allowed to be used for the compression
Default is to always allow for Uncompromisable ColGroup.
- value - Variable in class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap.DArrayIListEntry
-
- value - Variable in class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap.DIListEntry
-
- value - Variable in class org.apache.sysds.runtime.util.LongLongDoubleHashMap.ADoubleEntry
-
- valueClass - Variable in class org.apache.sysds.runtime.io.InputOutputInfo
-
- ValueComparisonFunction - Class in org.apache.sysds.runtime.functionobjects
-
Abstraction for comparison (relational) operators in order to
force a proper implementation by all relevant subclasses.
- ValueComparisonFunction() - Constructor for class org.apache.sysds.runtime.functionobjects.ValueComparisonFunction
-
- ValueFunction - Class in org.apache.sysds.runtime.functionobjects
-
- ValueFunction() - Constructor for class org.apache.sysds.runtime.functionobjects.ValueFunction
-
- valueOf(String) - Static method in enum org.apache.sysds.api.mlcontext.FrameFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.api.mlcontext.MatrixFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.api.mlcontext.MLContext.ExecutionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.api.mlcontext.MLContext.ExplainLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Builtins
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.AggOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.BlockType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.CorrectionLocationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.DataType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.ExecMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.ExecType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.FileFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.OpOp1
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.OpOp2
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.OpOp3
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.OpOp4
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.OpOpData
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.OpOpDG
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.OpOpDnn
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.OpOpN
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.ParamBuiltinOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.ReOrgOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.ReturnType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.common.Types.ValueType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.conf.CompilerConfig.ConfigType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.AggBinaryOp.MMultMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.AggBinaryOp.SparkAggType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.BinaryOp.AppendMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.BinaryOp.MMBinaryMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.codegen.cplan.CNodeNary.NaryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.codegen.cplan.CNodeTernary.TernaryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.codegen.opt.InterestingPoint.DecisionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.codegen.SpoofCompiler.CompilerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.codegen.SpoofCompiler.IntegrationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.codegen.SpoofCompiler.PlanCachePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.codegen.SpoofCompiler.PlanSelector
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.codegen.SpoofCompiler.RegisterAlloc
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.codegen.SpoofFusedOp.SpoofOutputDimsType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.codegen.template.TemplateBase.CloseType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.codegen.template.TemplateBase.TemplateType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.cost.CostEstimationWrapper.CostType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.estim.SparsityEstimator.OpCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.FunctionOp.FunctionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.LeftIndexingOp.LeftIndexingMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.OptimizerUtils.OptimizationLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.hops.recompile.Recompiler.ResetType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.AppendM.CacheType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.BinaryM.VectorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.Compression.CompressConfig
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.Ctable.OperationTypes
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.GroupedAggregateM.CacheType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.LeftIndex.LixCacheType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.Lop.SimpleInstType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.Lop.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.Lop.VisitStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.LopProperties.ExecType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.MapMult.CacheType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.MapMultChain.ChainType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.MMCJ.MMCJType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.MMTSJ.MMTSJType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.PickByCount.OperationTypes
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.PMMJ.CacheType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.SortKeys.OperationTypes
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.WeightedCrossEntropy.WCeMMType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.WeightedDivMM.WDivMMType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.WeightedSigmoid.WSigmoidType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.WeightedSquaredLoss.WeightsType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.lops.WeightedUnaryMM.WUMMType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.parser.BuiltinConstant
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.parser.dml.CustomErrorListener.ParseIssueType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.parser.Expression.BinaryOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.parser.Expression.BooleanOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.parser.Expression.DataOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.parser.Expression.FunctCallOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.parser.Expression.RelationalOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.parser.PrintStatement.PRINTTYPE
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.parser.Statement.PSCheckpointing
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.parser.Statement.PSFrequency
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.parser.Statement.PSModeType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.parser.Statement.PSScheme
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.parser.Statement.PSUpdateType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.codegen.SpoofCellwise.AggOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.codegen.SpoofCellwise.CellType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.codegen.SpoofOuterProduct.OutProdType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.compress.cocode.PlanningCoCoder.PartitionerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.compress.colgroup.ColGroup.CompressionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.compress.utils.ABitmap.BitmapType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.caching.CacheableData.CacheStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.caching.CacheStatistics.Stat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer.RPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.caching.MatrixObject.UpdateType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.federated.FederatedRequest.RequestType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.federated.FederatedResponse.ResponseType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.federated.FederationMap.FType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcResponse.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator.DataFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator.ExcludeType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator.TestMeasure
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.Optimizer.CostModelType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.Optimizer.PlanInputType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.ExecType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.NodeType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.ParamType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.Task.TaskType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
-
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PDataPartitioner
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PDataPartitionFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PExecMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.ParForProgramBlock.POptMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PResultMerge
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PTaskPartitioner
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.data.DenseBlock.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.data.SparseBlock.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ParameterizedBuiltinCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ProbabilityDistributionCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.instructions.cp.AggregateUnaryCPInstruction.AUType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.instructions.cp.AppendCPInstruction.AppendType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.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.sysds.runtime.instructions.Instruction.IType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.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.sysds.runtime.io.FileFormatPropertiesMM.MMField
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.io.FileFormatPropertiesMM.MMFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.io.FileFormatPropertiesMM.MMSymmetry
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.lineage.LineageCacheConfig.LineageCachePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.lineage.LineageCacheConfig.ReuseCacheType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.lineage.LineageItem.LineageItemType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.matrix.data.LibMatrixBincell.BinaryAccessType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.matrix.data.LibMatrixDNN.PoolingType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.matrix.operators.CMOperator.AggregateOperationTypes
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.matrix.operators.CountDistinctOperator.CountDistinctTypes
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.privacy.PrivacyConstraint.PrivacyLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.privacy.propagation.OperatorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.transform.encode.EncoderMVImpute.MVMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.transform.TfUtils.TfMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.runtime.util.LongLongDoubleHashMap.EntryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.utils.Explain.ExplainType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.utils.Hash.HashType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.sysds.utils.NativeHelper.NativeBlasState
-
Returns the enum constant of this type with the specified name.
- valueOfByOpcode(String) - Static method in enum org.apache.sysds.common.Types.OpOp1
-
- valueOfByOpcode(String) - Static method in enum org.apache.sysds.common.Types.OpOp2
-
- valueOfByOpcode(String) - Static method in enum org.apache.sysds.common.Types.OpOp3
-
- valueOfByOpcode(String) - Static method in enum org.apache.sysds.common.Types.ReOrgOp
-
- values() - Static method in enum org.apache.sysds.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.sysds.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.sysds.api.mlcontext.MLContext.ExecutionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.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.sysds.common.Builtins
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.AggOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.BlockType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.CorrectionLocationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.DataType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.ExecMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.ExecType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.FileFormat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.OpOp1
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.OpOp2
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.OpOp3
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.OpOp4
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.OpOpData
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.OpOpDG
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.OpOpDnn
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.OpOpN
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.ParamBuiltinOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.ReOrgOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.ReturnType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.common.Types.ValueType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.conf.CompilerConfig.ConfigType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.AggBinaryOp.MMultMethod
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.AggBinaryOp.SparkAggType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.BinaryOp.AppendMethod
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.BinaryOp.MMBinaryMethod
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.codegen.cplan.CNodeNary.NaryType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.codegen.cplan.CNodeTernary.TernaryType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.codegen.opt.InterestingPoint.DecisionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.codegen.SpoofCompiler.CompilerType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.codegen.SpoofCompiler.IntegrationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.codegen.SpoofCompiler.PlanCachePolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.codegen.SpoofCompiler.PlanSelector
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.codegen.SpoofCompiler.RegisterAlloc
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.codegen.SpoofFusedOp.SpoofOutputDimsType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.codegen.template.TemplateBase.CloseType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.codegen.template.TemplateBase.TemplateType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.cost.CostEstimationWrapper.CostType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.estim.SparsityEstimator.OpCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.FunctionOp.FunctionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.LeftIndexingOp.LeftIndexingMethod
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.OptimizerUtils.OptimizationLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.hops.recompile.Recompiler.ResetType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.AppendM.CacheType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.BinaryM.VectorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.Compression.CompressConfig
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.Ctable.OperationTypes
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.GroupedAggregateM.CacheType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.LeftIndex.LixCacheType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.Lop.SimpleInstType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.Lop.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.Lop.VisitStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.LopProperties.ExecType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.MapMult.CacheType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.MapMultChain.ChainType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.MMCJ.MMCJType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.MMTSJ.MMTSJType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.PickByCount.OperationTypes
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.PMMJ.CacheType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.SortKeys.OperationTypes
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.WeightedCrossEntropy.WCeMMType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.WeightedDivMM.WDivMMType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.WeightedSigmoid.WSigmoidType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.WeightedSquaredLoss.WeightsType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.lops.WeightedUnaryMM.WUMMType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.parser.BuiltinConstant
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.parser.dml.CustomErrorListener.ParseIssueType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.parser.Expression.BinaryOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.parser.Expression.BooleanOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.parser.Expression.DataOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.parser.Expression.FunctCallOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.parser.Expression.RelationalOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.parser.PrintStatement.PRINTTYPE
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.parser.Statement.PSCheckpointing
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.parser.Statement.PSFrequency
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.parser.Statement.PSModeType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.parser.Statement.PSScheme
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.parser.Statement.PSUpdateType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.codegen.SpoofCellwise.AggOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.codegen.SpoofCellwise.CellType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values(int) - Method in class org.apache.sysds.runtime.codegen.SpoofOperator.SideInput
-
- values(int) - Method in class org.apache.sysds.runtime.codegen.SpoofOperator.SideInputSparseRow
-
- values() - Static method in enum org.apache.sysds.runtime.codegen.SpoofOuterProduct.OutProdType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.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.sysds.runtime.compress.colgroup.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.sysds.runtime.compress.utils.ABitmap.BitmapType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.caching.CacheableData.CacheStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.caching.CacheStatistics.Stat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer.RPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.caching.MatrixObject.UpdateType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.federated.FederatedRequest.RequestType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.federated.FederatedResponse.ResponseType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.federated.FederationMap.FType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcResponse.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator.DataFormat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator.ExcludeType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator.TestMeasure
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.Optimizer.CostModelType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.Optimizer.PlanInputType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.ExecType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.NodeType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.ParamType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.parfor.Task.TaskType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PDataPartitioner
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PDataPartitionFormat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PExecMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.ParForProgramBlock.POptMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PResultMerge
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PTaskPartitioner
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.data.DenseBlock.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values(int) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Get the allocated block for the given row.
- values(int) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- values(int) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- values(int) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- values(int) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- values(int) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- values(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
-
- values(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
-
- values(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
-
- values(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
-
- values(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
-
- values(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
-
- values(int) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- values() - Static method in enum org.apache.sysds.runtime.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.sysds.runtime.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.sysds.runtime.data.SparseBlockCOO
-
- values() - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
-
Get raw access to underlying array of values
For use in GPU code
- values() - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
Get raw access to underlying array of values
For use in GPU code
- values(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
-
- values(int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
-
- values() - Method in class org.apache.sysds.runtime.data.SparseRow
-
Get the value array of non-zero entries, co-aligned
with the array of indexes.
- values() - Method in class org.apache.sysds.runtime.data.SparseRowScalar
-
- values() - Method in class org.apache.sysds.runtime.data.SparseRowVector
-
- values() - Static method in enum org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ParameterizedBuiltinCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ProbabilityDistributionCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.instructions.cp.AggregateUnaryCPInstruction.AUType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.instructions.cp.AppendCPInstruction.AppendType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.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.sysds.runtime.instructions.Instruction.IType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.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.sysds.runtime.io.FileFormatPropertiesMM.MMField
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.io.FileFormatPropertiesMM.MMFormat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.io.FileFormatPropertiesMM.MMSymmetry
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.lineage.LineageCacheConfig.LineageCachePolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.lineage.LineageCacheConfig.ReuseCacheType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.lineage.LineageItem.LineageItemType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.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.sysds.runtime.matrix.data.LibMatrixDNN.PoolingType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.matrix.operators.CMOperator.AggregateOperationTypes
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.matrix.operators.CountDistinctOperator.CountDistinctTypes
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.privacy.PrivacyConstraint.PrivacyLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.privacy.propagation.OperatorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.transform.encode.EncoderMVImpute.MVMethod
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.transform.TfUtils.TfMethod
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.runtime.util.LongLongDoubleHashMap.EntryType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.utils.Explain.ExplainType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.utils.Hash.HashType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.sysds.utils.NativeHelper.NativeBlasState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- valuesAt(int) - Method in class org.apache.sysds.runtime.data.DenseBlock
-
Get an allocated block.
- valuesAt(int) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
-
- valuesAt(int) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
-
- valuesAt(int) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
-
- valuesAt(int) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
-
- valuesAt(int) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
-
- valuesAt(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
-
- valuesAt(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
-
- valuesAt(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
-
- valuesAt(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
-
- valuesAt(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
-
- valuesAt(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
-
- valuesAt(int) - Method in class org.apache.sysds.runtime.data.DenseBlockString
-
- valueType() - Method in class org.apache.sysds.parser.dml.DmlParser.Ml_typeContext
-
- valueType() - Method in class org.apache.sysds.parser.dml.DmlParser
-
- VALUETYPE_PREFIX - Static variable in class org.apache.sysds.lops.Lop
-
- VALUETYPE_PREFIX - Static variable in class org.apache.sysds.runtime.instructions.Instruction
-
- ValueTypeContext(ParserRuleContext, int) - Constructor for class org.apache.sysds.parser.dml.DmlParser.ValueTypeContext
-
- VALUETYPEPARAM - Static variable in class org.apache.sysds.parser.DataExpression
-
- VARIABLE_NAME_PLACEHOLDER - Static variable in class org.apache.sysds.lops.Lop
-
- VariableCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
-
- VariableCPInstruction.VariableOperationCode - Enum in org.apache.sysds.runtime.instructions.cp
-
- VariableSet - Class in org.apache.sysds.parser
-
- VariableSet() - Constructor for class org.apache.sysds.parser.VariableSet
-
- VariableSet(VariableSet) - Constructor for class org.apache.sysds.parser.VariableSet
-
- variablesRead() - Method in class org.apache.sysds.parser.AssignmentStatement
-
- variablesRead() - Method in class org.apache.sysds.parser.BinaryExpression
-
- variablesRead() - Method in class org.apache.sysds.parser.BooleanExpression
-
- variablesRead() - Method in class org.apache.sysds.parser.BooleanIdentifier
-
- variablesRead() - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- variablesRead() - Method in class org.apache.sysds.parser.ConditionalPredicate
-
- variablesRead() - Method in class org.apache.sysds.parser.DataExpression
-
- variablesRead() - Method in class org.apache.sysds.parser.DataIdentifier
-
- variablesRead() - Method in class org.apache.sysds.parser.DoubleIdentifier
-
- variablesRead() - Method in class org.apache.sysds.parser.Expression
-
- variablesRead() - Method in class org.apache.sysds.parser.ExpressionList
-
- variablesRead() - Method in class org.apache.sysds.parser.ForStatement
-
- variablesRead() - Method in class org.apache.sysds.parser.FunctionCallIdentifier
-
- variablesRead() - Method in class org.apache.sysds.parser.FunctionStatement
-
- variablesRead() - Method in class org.apache.sysds.parser.IfStatement
-
- variablesRead() - Method in class org.apache.sysds.parser.ImportStatement
-
- variablesRead() - Method in class org.apache.sysds.parser.IndexedIdentifier
-
- variablesRead() - Method in class org.apache.sysds.parser.IntIdentifier
-
- variablesRead() - Method in class org.apache.sysds.parser.IterablePredicate
-
- variablesRead() - Method in class org.apache.sysds.parser.LiveVariableAnalysis
-
- variablesRead() - Method in class org.apache.sysds.parser.MultiAssignmentStatement
-
- variablesRead() - Method in class org.apache.sysds.parser.OutputStatement
-
- variablesRead() - Method in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- variablesRead() - Method in class org.apache.sysds.parser.PathStatement
-
- variablesRead() - Method in class org.apache.sysds.parser.PrintStatement
-
- variablesRead() - Method in class org.apache.sysds.parser.RelationalExpression
-
- variablesRead() - Method in class org.apache.sysds.parser.Statement
-
- variablesRead() - Method in class org.apache.sysds.parser.StringIdentifier
-
- variablesRead() - Method in class org.apache.sysds.parser.WhileStatement
-
- variablesUpdated() - Method in class org.apache.sysds.parser.AssignmentStatement
-
- variablesUpdated() - Method in class org.apache.sysds.parser.BinaryExpression
-
- variablesUpdated() - Method in class org.apache.sysds.parser.BooleanExpression
-
- variablesUpdated() - Method in class org.apache.sysds.parser.BooleanIdentifier
-
- variablesUpdated() - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
-
- variablesUpdated() - Method in class org.apache.sysds.parser.ConditionalPredicate
-
- variablesUpdated() - Method in class org.apache.sysds.parser.DataExpression
-
- variablesUpdated() - Method in class org.apache.sysds.parser.DataIdentifier
-
- variablesUpdated() - Method in class org.apache.sysds.parser.DoubleIdentifier
-
- variablesUpdated() - Method in class org.apache.sysds.parser.Expression
-
- variablesUpdated() - Method in class org.apache.sysds.parser.ExpressionList
-
- variablesUpdated() - Method in class org.apache.sysds.parser.ForStatement
-
- variablesUpdated() - Method in class org.apache.sysds.parser.FunctionCallIdentifier
-
- variablesUpdated() - Method in class org.apache.sysds.parser.FunctionStatement
-
- variablesUpdated() - Method in class org.apache.sysds.parser.IfStatement
-
- variablesUpdated() - Method in class org.apache.sysds.parser.ImportStatement
-
- variablesUpdated() - Method in class org.apache.sysds.parser.IntIdentifier
-
- variablesUpdated() - Method in class org.apache.sysds.parser.IterablePredicate
-
- variablesUpdated() - Method in class org.apache.sysds.parser.LiveVariableAnalysis
-
- variablesUpdated() - Method in class org.apache.sysds.parser.MultiAssignmentStatement
-
- variablesUpdated() - Method in class org.apache.sysds.parser.OutputStatement
-
- variablesUpdated() - Method in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
-
- variablesUpdated() - Method in class org.apache.sysds.parser.PathStatement
-
- variablesUpdated() - Method in class org.apache.sysds.parser.PrintStatement
-
- variablesUpdated() - Method in class org.apache.sysds.parser.RelationalExpression
-
- variablesUpdated() - Method in class org.apache.sysds.parser.Statement
-
- variablesUpdated() - Method in class org.apache.sysds.parser.StringIdentifier
-
- variablesUpdated() - Method in class org.apache.sysds.parser.WhileStatement
-
- VARS_BEGIN - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- VARS_END - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
-
- VarStats - Class in org.apache.sysds.hops.cost
-
- VarStats(long, long, int, long, boolean) - Constructor for class org.apache.sysds.hops.cost.VarStats
-
- vectAbsAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectAbsAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectAbsWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectAbsWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectAcosAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectAcosAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectAcosWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectAcosWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.compress.utils.LinearAlgebraUtils
-
- vectAdd(double, double[], char[], int, int, int) - Static method in class org.apache.sysds.runtime.compress.utils.LinearAlgebraUtils
-
Add aval to a series of indexes in c.
- vectAdd(double, double[], int, int) - Static method in class org.apache.sysds.runtime.compress.utils.LinearAlgebraUtils
-
- vectAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- vectAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- vectAdd(double[], double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- vectAddInPlace(double, double[], int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- vectAsinAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectAsinAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectAsinWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectAsinWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectAtanAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectAtanAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectAtanWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectAtanWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectAvgpoolWrite(double[], int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectAvgpoolWrite(double[], int[], int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectBiasaddWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectBiasaddWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectBiasmultWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectBiasmultWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectBitwandWrite(double[], double, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectBitwandWrite(double, double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectBitwandWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectBitwandWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectBitwandWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectBitwandWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectBitwandWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCbindAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCbindAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCbindWrite(double, double) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCbindWrite(double[], double, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCbindWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCeilAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCeilAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCeilWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCeilWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectConv2dmmWrite(double[], double[], int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCosAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCosAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCoshAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCoshAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCoshWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCoshWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCosWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCosWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCountnnz(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCountnnz(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCummaxAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCummaxAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCummaxWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCummaxWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCumminAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCumminAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCumminWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCumminWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCumsumAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCumsumAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCumsumWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectCumsumWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectDivAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectDivAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectDivAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectDivAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectDivWrite(double[], double, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectDivWrite(double, double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectDivWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectDivWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectDivWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectDivWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectDivWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectEqualAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectEqualAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectEqualAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectEqualAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectEqualWrite(double[], double, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectEqualWrite(double, double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectEqualWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectEqualWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectEqualWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectEqualWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectEqualWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectExpAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectExpAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectExpWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectExpWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectFloorAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectFloorAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectFloorWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectFloorWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalWrite(double[], double, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalWrite(double, double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterequalWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterWrite(double[], double, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterWrite(double, double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectGreaterWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectIm2colWrite(double[], int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectIm2colWrite(double[], int[], int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalWrite(double[], double, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalWrite(double, double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessequalWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessWrite(double[], double, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessWrite(double, double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLessWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectListAdd(double[], double[], char[], int, int) - Static method in class org.apache.sysds.runtime.compress.utils.LinearAlgebraUtils
-
- vectListAdd(double[], double[], byte[], int, int) - Static method in class org.apache.sysds.runtime.compress.utils.LinearAlgebraUtils
-
- vectLogAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLogAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLogWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectLogWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMatrixMult(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMatrixMult(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMax(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMax(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMaxAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMaxAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMaxAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMaxAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMaxpoolWrite(double[], int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMaxpoolWrite(double[], int[], int, int, int, int, int, int, int, int, int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMaxWrite(double[], double, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMaxWrite(double, double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMaxWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMaxWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMaxWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMaxWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMaxWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMean(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMean(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMin(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMin(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinusAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinusAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinusAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinusAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinusWrite(double[], double, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinusWrite(double, double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinusWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinusWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinusWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinusWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinusWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinWrite(double[], double, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinWrite(double, double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMinWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMult2Add(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMult2Add(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMult2Write(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMult2Write(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMultAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMultAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMultAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMultAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMultAdd(double[], double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMultiplyAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.compress.utils.LinearAlgebraUtils
-
- vectMultiplyAdd(double, double[], double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.compress.utils.LinearAlgebraUtils
-
- vectMultiplyAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- vectMultiplyAdd(double, double[], double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- vectMultiplyInPlace(double, double[], int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- vectMultiplyWrite(double, double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- vectMultiplyWrite(double[], double[], double[], int, int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- vectMultiplyWrite(double[], double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
-
- vectMultWrite(double[], double, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMultWrite(double, double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMultWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMultWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMultWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMultWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectMultWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalWrite(double[], double, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalWrite(double, double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectNotequalWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectOuterMultAdd(double[], double[], double[], int, int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectOuterMultAdd(double[], double[], double[], int[], int, int, int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectOuterMultAdd(double[], double[], double[], int, int[], int, int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPlusAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPlusAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPlusAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPlusAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPlusWrite(double[], double, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPlusWrite(double, double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPlusWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPlusWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPlusWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPlusWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPlusWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPow2Add(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPow2Add(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPow2Write(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPow2Write(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPowAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPowAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPowAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPowAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPowWrite(double[], double, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPowWrite(double, double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPowWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPowWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectPowWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectRoundAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectRoundAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectRoundWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectRoundWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSigmoidAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSigmoidAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSigmoidWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSigmoidWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSignAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSignAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSignWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSignWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSinAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSinAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSinhAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSinhAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSinhWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSinhWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSinWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSinWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSpropAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSpropAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSpropWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSpropWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSqrtAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSqrtAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSqrtWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSqrtWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSum(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
Computes c = sum(A), where A is a dense vectors.
- vectSum(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSum(double[], char[], int, int, int) - Static method in class org.apache.sysds.runtime.compress.utils.LinearAlgebraUtils
-
- vectSum(double[], int, int) - Static method in class org.apache.sysds.runtime.compress.utils.LinearAlgebraUtils
-
- vectSumsq(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectSumsq(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectTanAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectTanAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectTanhAdd(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectTanhAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectTanhWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectTanhWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectTanWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectTanWrite(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectWrite(double[], double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectWrite(boolean[], boolean[], int[]) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectWrite(boolean[], boolean[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectXorAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
Computes c = xor(A,B)
- vectXorAdd(double, double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectXorAdd(double[], double, double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectXorAdd(double, double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectXorWrite(double[], double, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectXorWrite(double, double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectXorWrite(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectXorWrite(double[], double, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectXorWrite(double, double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectXorWrite(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- vectXorWrite(double[], double[], int, int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
-
- verifySparkVersionSupported(SparkSession) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Check that the Spark version is supported.
- version() - Method in class org.apache.sysds.api.mlcontext.MLContext
-
Obtain the SystemDS version number.
- version() - Method in class org.apache.sysds.api.mlcontext.ProjectInfo
-
Obtain the project version from the manifest.
- VERSION_NOT_AVAILABLE - Static variable in class org.apache.sysds.api.mlcontext.MLContextUtil
-
Version not available message.
- visitErrorNode(ErrorNode) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
- visitErrorNode(ErrorNode) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- visitErrorNode(ErrorNode) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- VisitMarkCost(long, long) - Constructor for class org.apache.sysds.hops.codegen.opt.PlanSelection.VisitMarkCost
-
- visitTerminal(TerminalNode) - Method in class org.apache.sysds.parser.dml.DmlBaseListener
- visitTerminal(TerminalNode) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
-
- visitTerminal(TerminalNode) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
-
- VOCABULARY - Static variable in class org.apache.sysds.parser.dml.DmlLexer
-
- VOCABULARY - Static variable in class org.apache.sysds.parser.dml.DmlParser
-