A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
All Classes All Packages

A

ABitmap - Class in org.apache.sysds.runtime.compress.bitmap
 
ABooleanArray - Class in org.apache.sysds.runtime.frame.data.columns
 
ABooleanArray(int) - Constructor for class org.apache.sysds.runtime.frame.data.columns.ABooleanArray
 
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
ABS - org.apache.sysds.common.Builtins
 
ABS - org.apache.sysds.common.Types.OpOp1
 
ABS - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
ABS - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
ABSTAIN - org.apache.sysds.common.Builtins
 
ABSTRACT_PLAN - org.apache.sysds.runtime.controlprogram.parfor.opt.Optimizer.PlanInputType
 
accAggregationTime(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
accBatchIndexingTime(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
accBroadCastTime(long) - Static method in class org.apache.sysds.utils.stats.SparkStatistics
 
accCollectTime(long) - Static method in class org.apache.sysds.utils.stats.SparkStatistics
 
accept(Class) - Method in class org.apache.sysds.runtime.io.BinaryBlockSerialization
 
acceptNegativeNumbersAsDigits(String) - Static method in class org.apache.sysds.runtime.util.DMVUtils
 
accExecutionTime(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
accFedAggregation(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
accFedCommunicationTime(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
accFedDataPartitioningTime(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
accFedGradientWeightingTime(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
accFedNetworkTime(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
accFedWorkerComputing(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
accGradientComputeTime(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
accHEAccumulation(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
accHEDecryptionTime(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
accHEEncryptionTime(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
accHEPartialDecryptionTime(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
accLocalModelUpdateTime(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
accModelBroadcastTime(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
accParallelizeTime(long) - Static method in class org.apache.sysds.utils.stats.SparkStatistics
 
accRpcRequestTime(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
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
accrueModels(ListObject, ListObject, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
Accumulate the given models into the accrued accrueModels
accrueModels(ListObject, ListObject, boolean, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
Accumulate the given models into the accrued models
accSetupTime(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
accumulateCiphertexts(long, byte[][]) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.NativeHEHelper
accumulates the given ciphertexts into a sum ciphertext and returns it
accumulateCiphertexts(CiphertextMatrix[]) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.homomorphicEncryption.SEALServer
accumulates the given ciphertext blocks into a sum ciphertext and returns it
AccumulatorAssignmentStatementContext(DmlParser.StatementContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.AccumulatorAssignmentStatementContext
 
accValidationTime(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
AColGroup - Class in org.apache.sysds.runtime.compress.colgroup
Abstract Class that is the lowest class type for the Compression framework.
AColGroup.CompressionType - Enum in org.apache.sysds.runtime.compress.colgroup
Public super types of compression ColGroups supported
AColGroupCompressed - Class in org.apache.sysds.runtime.compress.colgroup
Base class for column groups encoded Encoded in a compressed manner.
AColGroupOffset - Class in org.apache.sysds.runtime.compress.colgroup
Base class for column groups encoded with various types of bitmap encoding.
AColGroupValue - Class in org.apache.sysds.runtime.compress.colgroup
 
AColIndex - Class in org.apache.sysds.runtime.compress.colgroup.indexes
 
AColIndex() - Constructor for class org.apache.sysds.runtime.compress.colgroup.indexes.AColIndex
 
AColumnCoCoder - Class in org.apache.sysds.runtime.compress.cocode
 
AComEst - Class in org.apache.sysds.runtime.compress.estim
Main abstract class for estimating size of compressions on columns.
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
ACOS - org.apache.sysds.common.Builtins
 
ACOS - org.apache.sysds.common.Types.OpOp1
 
ACOS - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
ACOS - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
ACostEstimate - Class in org.apache.sysds.runtime.compress.cost
A cost estimator interface.
acquireDeviceModifyDense() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
 
acquireDeviceModifyDense(boolean) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
 
acquireDeviceModifySparse() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
 
acquireDeviceModifySparse(boolean) - 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.
acquireRead() - Method in class org.apache.sysds.runtime.controlprogram.context.MatrixObjectFuture
 
acquireReadAndRelease() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
activate() - Static method in class org.apache.sysds.hops.fedplanner.FederatedCompilationTimer
 
activatePrefetch() - Method in class org.apache.sysds.hops.Hop
Activate prefetch of HOP.
activatePrefetch() - Method in class org.apache.sysds.lops.Lop
 
add(double) - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox.SmallestPriorityQueue
 
add(int) - Method in class org.apache.sysds.runtime.util.IndexRange
 
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(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(long, Pointer) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPULazyCudaFreeMemoryManager
Add a pointer to the rmvar-ed list
add(String) - Method in class org.apache.sysds.runtime.lineage.LineageTokenizer
 
add(String, String) - Method in class org.apache.sysds.runtime.lineage.LineageTokenizer
 
add(String, Data, LineageItem) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
add(Hop, CPlanMemoTable.MemoTableEntry) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
 
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(Array<?>[], Array<?>) - Static method in interface org.apache.sysds.runtime.frame.data.lib.FrameUtil
 
add(Data, LineageItem) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
ADD_PRIME1 - Static variable in class org.apache.sysds.runtime.util.UtilFunctions
 
addAll(Collection<T>, T[]) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
 
addAll(Hop, CPlanMemoTable.MemoTableEntrySet) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
 
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(WTreeNode) - Method in class org.apache.sysds.runtime.compress.workload.AWTreeNode
 
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
 
addCompressionTime(double, int) - Static method in class org.apache.sysds.utils.DMLCompressionStatistics
 
addCorrectionLayer(double[], double[], int, double[]) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibTSMM
 
addCostPointer(long) - Method in class org.apache.sysds.hops.cost.HopRel
Adds hopID to set of hops pointing to this HopRel.
addCPMemObject(int, double) - Static method in class org.apache.sysds.utils.Statistics
 
addDataObject(DataObjectModel) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
addDecompressCacheCount() - Static method in class org.apache.sysds.utils.DMLCompressionStatistics
 
addDecompressSparkCount() - Static method in class org.apache.sysds.utils.DMLCompressionStatistics
 
addDecompressTime(double, int) - Static method in class org.apache.sysds.utils.DMLCompressionStatistics
 
addDecompressToBlockTime(double, int) - Static method in class org.apache.sysds.utils.DMLCompressionStatistics
 
addDependent(DependencyTask<?>) - Method in class org.apache.sysds.runtime.util.DependencyTask
 
addDimsPreservingFunction(String) - Method in class org.apache.sysds.hops.ipa.FunctionCallSizeInfo
Adds a function to the set of dimension-preserving functions.
addEncoder(ColumnEncoder) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
addEntryList(List<LineageCacheEntry>) - Static method in class org.apache.sysds.runtime.lineage.LineageGPUCacheEviction
 
addEvent(EventModel) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
addExprParam(String, Expression, boolean) - Method in class org.apache.sysds.parser.OutputStatement
 
addFederatedExprParam(String, Expression) - Method in class org.apache.sysds.parser.DataExpression
 
addFrameExprParam(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
 
addFunctionProgramBlock(String, FunctionProgramBlock, boolean) - Method in class org.apache.sysds.runtime.controlprogram.Program
 
addFunctionStatementBlock(String, String, FunctionStatementBlock) - Method in class org.apache.sysds.parser.DMLProgram
 
addFunctionStatementBlock(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
 
addInputTotalCost(double) - Method in class org.apache.sysds.hops.cost.FederatedCost
Add cost to the stored input cost.
addInputTotalCost(FederatedCost) - Method in class org.apache.sysds.hops.cost.FederatedCost
Add total of federatedCost to stored inputTotalCost.
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
 
addLast(String, ByteBuffer) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheEvictionQueue
 
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 occurrence of the given privacy level to the loaded constraints log total.
addMatrixExprParam(String, Expression) - Method in class org.apache.sysds.parser.DataExpression
 
addMatrixToResult(MatrixBlock, MatrixBlock, IColIndex, int, int) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupUtils
 
addNode(Lop) - Method in class org.apache.sysds.lops.compile.Dag
Method to add a node to the DAG.
addOp(Op) - Method in class org.apache.sysds.runtime.compress.workload.AWTreeNode
 
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
 
addPool(ExecutorService) - Method in class org.apache.sysds.runtime.util.DependencyTask
 
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
 
addReplaceLegacyEncoder(T) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
address - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.WorkerModel
 
addressOfGlobalFreeSpaceIndex - Variable in class org.apache.sysds.runtime.io.hdf5.H5Superblock
 
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
 
addTimeToDate(String, int, String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
addTmpParforFunction(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
addToCommon(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
Take the values in this constant column group and add to the given constV.
addToDag(Dag<Lop>) - Method in class org.apache.sysds.lops.Lop
Method to recursively add LOPS to a DAG
addToEntry(double[], int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Copies and adds the dictionary entry from this dictionary to the d dictionary
addToEntry(double[], int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
addToEntry(double[], int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
addToEntry(double[], int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
addToEntry(double[], int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
addToEntry(double[], int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
copies and adds the dictonary entry from this dictionary yo the d dictionary rep times.
addToEntry(double[], int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
addToEntry(double[], int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
addToEntry(double[], int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
addToEntry(double[], int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
addToEntryVectorized(double[], int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
 
addToEntryVectorized(double[], int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
addToEntryVectorized(double[], int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
addToEntryVectorized(double[], int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
addToEntryVectorized(double[], int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
addToUpperTriangle(int, int, int, double[], double) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.DictLibMatrixMult
Add to the upper triangle, but twice if on the diagonal
addValidCompression(AColGroup.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
 
addVarParam(String, Expression, HashMap<String, Expression>) - Method in class org.apache.sysds.runtime.meta.MetaDataAll
 
addWorkerRequest(RequestModel) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
addWrappedTaskFuture(Future<Future<?>>) - Method in class org.apache.sysds.runtime.util.DependencyWrapperTask
 
addWriteLock() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
 
ADictBasedColGroup - Class in org.apache.sysds.runtime.compress.colgroup
 
ADictionary - Class in org.apache.sysds.runtime.compress.colgroup.dictionary
This dictionary class aims to encapsulate the storage and operations over unique tuple values of a column group.
ADictionary() - Constructor for class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
 
ADictionary.DictType - Enum in org.apache.sysds.runtime.compress.colgroup.dictionary
 
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
 
AFederatedPlanner - Class in org.apache.sysds.hops.fedplanner
 
AFederatedPlanner() - Constructor for class org.apache.sysds.hops.fedplanner.AFederatedPlanner
 
AGG - org.apache.sysds.lops.MMCJ.MMCJType
 
AGG_OUTER_PRODUCT - org.apache.sysds.runtime.codegen.SpoofOuterProduct.OutProdType
 
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
 
aggBooleanScalar(Future<FederatedResponse>[]) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
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
 
aggFedPutLineage(String) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
aggFedSerializationReuse(long) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
aggMatrix(AggregateUnaryOperator, Future<FederatedResponse>[], Future<FederatedResponse>[], FederationMap) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
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, Optional<FTypes.FType>) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
aggMinMaxIndex(Future<FederatedResponse>[], boolean, FederationMap) - 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
 
aggProd(Future<FederatedResponse>[], FederationMap, AggregateUnaryOperator) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
aggregate(double, Builtin) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.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.Dictionary
 
aggregate(double, Builtin) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
aggregate(double, Builtin) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
aggregate(double, Builtin) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
aggregate(long, long, double) - Method in class org.apache.sysds.runtime.matrix.data.CTableMap
 
aggregate(FederatedStatistics.FedStatsCollection) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics.FedStatsCollection
 
Aggregate - org.apache.sysds.lops.Lop.Type
 
Aggregate - org.apache.sysds.runtime.privacy.propagation.OperatorType
 
aggregateBinary(DataCharacteristics, DataCharacteristics, AggregateBinaryOperator, DataCharacteristics) - Static method in class org.apache.sysds.runtime.meta.DataCharacteristics
 
AggregateBinary - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
AggregateBinary - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
AggregateBinary - org.apache.sysds.runtime.instructions.gpu.GPUInstruction.GPUINSTRUCTION_TYPE
 
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
 
AggregateBinaryFEDInstruction(Operator, CPOperand, CPOperand, CPOperand, String, String, FEDInstruction.FederatedOutput) - 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(MatrixBlock, MatrixBlock, MatrixBlock, AggregateBinaryOperator) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
aggregateBinaryOperations(MatrixBlock, MatrixBlock, MatrixBlock, AggregateBinaryOperator) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
aggregateBinaryOperations(MatrixBlock, MatrixBlock, MatrixBlock, AggregateBinaryOperator, boolean, boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
aggregateBinaryOperations(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
 
AggregateBinarySPInstruction - Class in org.apache.sysds.runtime.instructions.spark
Class to group the different MM SPInstructions together.
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+.
aggregateCmCov(MatrixBlock, MatrixBlock, MatrixBlock, ValueFunction) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
Single threaded Covariance and Central Moment operations CM = Central Moment COV = Covariance
aggregateCmCov(MatrixBlock, MatrixBlock, MatrixBlock, ValueFunction, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
Multi threaded Covariance and Central Moment operations CM = Central Moment COV = Covariance
aggregateCols(double[], Builtin, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Aggregates the columns into the target double array provided.
aggregateCols(double[], Builtin, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
aggregateCols(double[], Builtin, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
aggregateCols(double[], Builtin, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
aggregateCols(double[], Builtin, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
aggregateCols(double[], Builtin, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
aggregateColsWithReference(double[], Builtin, IColIndex, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Aggregates the columns into the target double array provided.
aggregateColsWithReference(double[], Builtin, IColIndex, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
aggregateColsWithReference(double[], Builtin, IColIndex, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
aggregateColsWithReference(double[], Builtin, IColIndex, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
aggregateColsWithReference(double[], Builtin, IColIndex, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
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
 
aggregatePartialPublicKeys(long, byte[][]) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.NativeHEHelper
accumulates the given partial public keys into a public key, stores it in server and returns it
aggregatePartialPublicKeys(PublicKey[]) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.HEParamServer
 
aggregatePartialPublicKeys(PublicKey[]) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.homomorphicEncryption.SEALServer
accumulates the given partial public keys into a public key, stores it in ctx and returns it
aggregatePartialResults(SpoofCellwise.AggOp[], MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.codegen.SpoofMultiAggregate
 
aggregateResponses(List<Pair<FederatedRange, Future<FederatedResponse>>>) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
Aggregate partially aggregated data from federated workers by adding values with the same index in different federated locations.
aggregateRows(Builtin, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Aggregate all entries in the rows.
aggregateRows(Builtin, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
aggregateRows(Builtin, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
aggregateRows(Builtin, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
aggregateRows(Builtin, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
aggregateRows(Builtin, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
aggregateRowsWithDefault(Builtin, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Aggregate all entries in the rows of the dictionary with a extra cell in the end that contains the aggregate of the given defaultTuple.
aggregateRowsWithDefault(Builtin, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
aggregateRowsWithDefault(Builtin, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
aggregateRowsWithDefault(Builtin, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
aggregateRowsWithDefault(Builtin, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
aggregateRowsWithReference(Builtin, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Aggregate all entries in the rows with an offset value reference added.
aggregateRowsWithReference(Builtin, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
aggregateRowsWithReference(Builtin, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
aggregateRowsWithReference(Builtin, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
aggregateRowsWithReference(Builtin, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
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
 
AggregateTernary - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
AggregateTernary - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
AggregateTernary - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
AggregateTernaryCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
AggregateTernaryFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
aggregateTernaryOperations(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, AggregateTernaryOperator, boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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(CompressedMatrixBlock, MatrixBlock, AggregateUnaryOperator, int, MatrixIndexes, boolean) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibCompAgg
 
aggregateUnary(DataCharacteristics, AggregateUnaryOperator, DataCharacteristics) - Static method in class org.apache.sysds.runtime.meta.DataCharacteristics
 
AggregateUnary - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
AggregateUnary - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
AggregateUnary - org.apache.sysds.runtime.instructions.gpu.GPUInstruction.GPUINSTRUCTION_TYPE
 
AggregateUnary - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
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, 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) - 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) - 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
 
aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, MatrixIndexes, boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, MatrixIndexes, boolean) - 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.MatrixBlock
 
aggregateUnaryOperations(AggregateUnaryOperator, MatrixValue, int, MatrixIndexes, boolean) - 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.MatrixValue
 
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
 
AggregateUnarySketch - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
AggregateUnarySketchSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
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.
aggregateWithReference(double, Builtin, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Aggregate all the contained values, with a reference offset.
aggregateWithReference(double, Builtin, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
aggregateWithReference(double, Builtin, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
aggregateWithReference(double, Builtin, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
aggregateWithReference(double, Builtin, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
aggScalar(AggregateUnaryOperator, Future<FederatedResponse>[]) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
aggScalar(AggregateUnaryOperator, Future<FederatedResponse>[], Future<FederatedResponse>[], FederationMap) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
aggScalar(AggregateUnaryOperator, Future<FederatedResponse>[], FederationMap) - 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
 
aggVar(Future<FederatedResponse>[], Future<FederatedResponse>[], FederationMap, boolean, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
AInsertionSorter - Class in org.apache.sysds.runtime.compress.colgroup.insertionsort
This abstract class is for sorting the IntArrayList entries efficiently for SDC Column Groups construction.
AInsertionSorter(int, int, IntArrayList[]) - Constructor for class org.apache.sysds.runtime.compress.colgroup.insertionsort.AInsertionSorter
 
AInsertionSorter(int, int, IntArrayList[], int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.insertionsort.AInsertionSorter
 
AIterator - Class in org.apache.sysds.runtime.compress.colgroup.offset
Iterator interface, that returns a iterator of the indexes while also maintaining a data index.
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) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
allocate(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.SparseBlock
Allocate the underlying data structure holding non-zero values of row r if necessary, w/ given size.
allocate(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
allocate(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
allocate(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
 
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, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
allocate(int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
allocate(int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
 
allocate(String, long) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
Default behavior for gpu memory allocation (init to zero)
allocate(String, long, boolean) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
Invokes memory manager's malloc method
allocate(Pointer, long) - Method in class org.apache.sysds.runtime.instructions.gpu.context.CudaMemoryAllocator
Allocate memory on the device.
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.
allocate(Types.ValueType, int) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
allocate(Types.ValueType, int, String) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
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.compress.CompressedMatrixBlock
 
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.compress.CompressedMatrixBlock
 
allocateBlockAsync() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
allocateBoolean(int) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
allocateColGroup(AColGroup) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
Allocate the given column group and remove all references to old column groups.
allocateColGroupList(List<AColGroup>) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
Replace the column groups in this CompressedMatrixBlock with the given column groups
allocateDenseBlock() - 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.compress.CompressedMatrixBlock
 
allocateDenseBlock(boolean) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
 
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
 
allocateEmpty(GPUContext, long, long, boolean) - 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.
allocateInternalMeta(int) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplier
 
allocateInternalMeta(int) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierCount
 
allocateInternalMeta(int) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierHash
 
allocateInternalRepresentation(int) - Method in class org.apache.sysds.runtime.transform.tokenize.Tokenizer
 
allocateMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
allocateMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
allocateMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
allocateMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderFeatureHash
 
allocateMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderPassThrough
 
allocateMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
allocateMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderUDF
 
allocateMetaData(FrameBlock) - Method in interface org.apache.sysds.runtime.transform.encode.Encoder
Pre-allocate a FrameBlock for metadata collection.
allocateMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
allocateOptional(Types.ValueType, int) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
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.compress.CompressedMatrixBlock
 
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_COMPRESSION_REWRITE - Static variable in class org.apache.sysds.hops.OptimizerUtils
Boolean specifying if compression rewrites is allowed.
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_CSE_PERSISTENT_READS - org.apache.sysds.conf.CompilerConfig.ConfigType
 
ALLOW_CTABLE_SEQUENCE_REWRITES - Static variable in class org.apache.sysds.hops.TernaryOp
 
ALLOW_DYN_RECOMPILATION - org.apache.sysds.conf.CompilerConfig.ConfigType
 
ALLOW_EVAL_FCALL_REPLACEMENT - Static variable in class org.apache.sysds.hops.OptimizerUtils
Replace eval second-order function calls with normal function call if the function name is a known string (after constant propagation).
ALLOW_FOR_LOOP_REMOVAL - Static variable in class org.apache.sysds.hops.OptimizerUtils
Enables the removal of (par)for-loops when from, to, and increment are constants (original literals or results of constant folding) and lead to an empty sequence, i.e., (par)for-loops without a single iteration.
ALLOW_INDIVIDUAL_SB_SPECIFIC_OPS - org.apache.sysds.conf.CompilerConfig.ConfigType
 
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_INTERMEDIATE_CANDIDATES - Static variable in class org.apache.sysds.runtime.compress.workload.WorkloadAnalyzer
 
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_PARALLEL_DYN_RECOMPILATION - org.apache.sysds.conf.CompilerConfig.ConfigType
 
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_SCRIPT_LEVEL_COMPRESS_COMMAND - Static variable in class org.apache.sysds.hops.OptimizerUtils
This variable allows for insertion of Compress and decompress in the dml script from the user.
ALLOW_SCRIPT_LEVEL_LOCAL_COMMAND - Static variable in class org.apache.sysds.hops.OptimizerUtils
This variable allows for use of explicit local command, that forces a spark block to be executed and returned as a local block.
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_TRANSITIVE_SPARK_EXEC_TYPE - Static variable in class org.apache.sysds.hops.OptimizerUtils
Enable transitive spark execution type selection.
ALLOW_UNARY_UPDATE_IN_PLACE - Static variable in class org.apache.sysds.hops.OptimizerUtils
Enables the update-in-place for all unary operators with a single consumer.
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
 
allZero(double[]) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupUtils
 
ALPHA - Static variable in class org.apache.sysds.runtime.util.DMVUtils
 
ALPHABET - Static variable in class org.apache.sysds.parser.dml.DmlLexer
 
ALPHABET - Static variable in class org.apache.sysds.parser.dml.DmlParser
 
ALS - org.apache.sysds.common.Builtins
 
ALS_CG - org.apache.sysds.common.Builtins
 
ALS_DS - org.apache.sysds.common.Builtins
 
ALS_PREDICT - org.apache.sysds.common.Builtins
 
ALS_TOPK_PREDICT - org.apache.sysds.common.Builtins
 
alwaysRequiresReblock(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
AMapToData - Class in org.apache.sysds.runtime.compress.colgroup.mapping
This Class's job is to link into the dictionary entries for column groups.
AMapToDataGroup - Interface in org.apache.sysds.runtime.compress.colgroup
 
AMorphingMMColGroup - Class in org.apache.sysds.runtime.compress.colgroup
Abstract class for column group types that do not perform matrix Multiplication, and decompression for performance reasons but instead transforms into another type of column group type to perform that operation.
analyze(VariableSet) - Method in class org.apache.sysds.parser.ForStatementBlock
 
analyze(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
 
analyze(VariableSet, VariableSet) - Method in class org.apache.sysds.parser.FunctionStatementBlock
 
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
 
analyzeValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Analyze the column to figure out if the value type can be refined to a better type.
analyzeValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
analyzeValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
analyzeValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
analyzeValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
analyzeValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
analyzeValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
analyzeValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
analyzeValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
analyzeValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
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
 
AND - org.apache.sysds.common.Types.OpOp2
 
AND - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
AOffset - Class in org.apache.sysds.runtime.compress.colgroup.offset
Offset list encoder interface.
AOffset() - Constructor for class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
 
AOffset.OffsetSliceInfo - Class in org.apache.sysds.runtime.compress.colgroup.offset
 
AOffsetIterator - Class in org.apache.sysds.runtime.compress.colgroup.offset
Iterator interface that only iterate through offsets without considering data index.
AOffsetsGroup - Interface in org.apache.sysds.runtime.compress.colgroup
 
API - Static variable in class org.apache.sysds.hops.codegen.SpoofCompiler
 
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(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(Boolean) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
append(Boolean) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
append(Character) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
append(Double) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
append(Float) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
append(Integer) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
append(Long) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
append(String) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Append a string value to the current Array, this should in general be avoided, and appending larger blocks at a time should be preferred.
append(String) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
append(String) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
append(String) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
append(String) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
append(String) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
append(String) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
append(String) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
append(String) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
append(String) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
append(AColGroup) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Append the other column group to this column group.
append(AColGroup) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
append(AColGroup) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
append(AColGroup) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
append(AColGroup) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
append(AColGroup) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
append(AColGroup) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
 
append(AColGroup) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
 
append(AColGroup) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
append(AColGroup) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
append(AColGroup) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
append(AColGroup) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
append(AColGroup) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
append(AColGroup) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
append(AMapToData) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
 
append(AMapToData) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
append(AMapToData) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
append(AMapToData) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
append(AMapToData) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
append(AMapToData) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
append(AMapToData) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
append(AOffset, int) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
Append the offsets from that other offset to the offsets in this.
append(Array<?>, Array<?>) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
append arrays to each other, and cast to highest common type if different types.
append(Array<Boolean>) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
append(Array<Boolean>) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
append(Array<Character>) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
append(Array<Double>) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
append(Array<Float>) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
append(Array<Integer>) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
append(Array<Long>) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
append(Array<String>) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
append(Array<T>) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
append other array, if the other array is fitting in current allocated size use that allocated size, otherwise allocate new array to combine the other with this.
append(Array<T>) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
append(FrameBlock, boolean) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
Appends the given argument FrameBlock 'that' to this FrameBlock by creating a deep copy to prevent side effects.
append(FrameBlock, FrameBlock, boolean) - Static method in class org.apache.sysds.runtime.frame.data.lib.FrameLibAppend
Appends the given argument FrameBlock 'that' to this FrameBlock by creating a deep copy to prevent side effects.
append(MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Append that matrix to this matrix, while allocating a new matrix.
append(MatrixBlock[], MatrixBlock, boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
append(MatrixBlock[], MatrixBlock, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Append that list of matrixes to this matrix.
append(MatrixBlock, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Append that matrix to this matrix, while allocating a new matrix.
append(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Append that matrix to this matrix.
append(MatrixBlock, MatrixBlock, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Append that matrix to this matrix.
append(MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibAppend
 
append(MatrixValue, ArrayList<IndexedMatrixValue>, int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
append(MatrixValue, ArrayList<IndexedMatrixValue>, int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
 
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(T) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Append a value of the same type of the Array.
append(T) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
Append - Class in org.apache.sysds.lops
 
Append - org.apache.sysds.lops.Lop.Type
 
Append - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
Append - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
Append - org.apache.sysds.runtime.instructions.gpu.GPUInstruction.GPUINSTRUCTION_TYPE
 
Append(Lop, Lop, Lop, Types.DataType, Types.ValueType, boolean, Types.ExecType) - Constructor for class org.apache.sysds.lops.Append
 
APPEND_MEM_MULTIPLIER - Static variable in class org.apache.sysds.hops.BinaryOp
 
appendCbind(FrameBlock, FrameBlock) - Static method in class org.apache.sysds.runtime.frame.data.lib.FrameLibAppend
 
appendCell(long, long, double) - Method in class org.apache.sysds.runtime.instructions.spark.data.ReblockBuffer
 
appendCell(long, long, Object) - Method in class org.apache.sysds.runtime.instructions.spark.data.FrameReblockBuffer
 
appendColumn(boolean[]) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
Append a column of value type BOOLEAN as the last column of the data frame.
appendColumn(double[]) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
Append a column of value type DOUBLE as the last column of the data frame.
appendColumn(float[]) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
Append a column of value type float as the last column of the data frame.
appendColumn(int[]) - Method in class org.apache.sysds.runtime.frame.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.frame.data.FrameBlock
Append a column of value type LONG as the last column of the data frame.
appendColumn(String[]) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
Append a column of value type STRING as the last column of the data frame.
appendColumn(Array) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
Add a column of already allocated Array type.
appendColumns(double[][]) - Method in class org.apache.sysds.runtime.frame.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, Types.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, Types.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
 
appendN(AColGroup[]) - Static method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Append all column groups in the list provided together in one go allocating the output once.
appendN(AMapToDataGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
 
appendN(AMapToDataGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
appendN(AMapToDataGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
appendN(AMapToDataGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
appendN(AMapToDataGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
appendN(AMapToDataGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
appendN(AMapToDataGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
appendN(AOffsetsGroup[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
Append a list of offsets together in order.
appendN(AOffsetsGroup[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetByte
 
appendNInternal(AColGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
appendNInternal(AColGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
appendNInternal(AColGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
appendNInternal(AColGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
appendNInternal(AColGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
appendNInternal(AColGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
 
appendNInternal(AColGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
 
appendNInternal(AColGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
appendNInternal(AColGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
appendNInternal(AColGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
appendNInternal(AColGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
appendNInternal(AColGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
appendNInternal(AColGroup[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
appendOpcode(StringBuilder) - Method in class org.apache.sysds.lops.DnnTransform
 
appendOperands(int, int, String, StringBuilder) - Method in class org.apache.sysds.lops.DnnTransform
 
appendOther(OptionalArray<T>, Array<T>) - Static method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
appendParam(Object) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
 
appendParams(Object...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
 
AppendPropagator - Class in org.apache.sysds.runtime.privacy.propagation
 
AppendPropagator(MatrixBlock, PrivacyConstraint, MatrixBlock, PrivacyConstraint) - Constructor for class org.apache.sysds.runtime.privacy.propagation.AppendPropagator
 
AppendR - Class in org.apache.sysds.lops
 
AppendR(Lop, Lop, Types.DataType, Types.ValueType, boolean, Types.ExecType) - Constructor for class org.apache.sysds.lops.AppendR
 
appendRbind(FrameBlock, FrameBlock) - Static method in class org.apache.sysds.runtime.frame.data.lib.FrameLibAppend
 
appendRow(int, SparseRow) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
appendRow(int, SparseRow, boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
appendRow(int, SparseRow, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
appendRow(Object[]) - Method in class org.apache.sysds.runtime.frame.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.frame.data.FrameBlock
Append a row to the end of the data frame, where all row fields are string encoded.
appendRowToSparse(SparseBlock, MatrixBlock, int, int, int, boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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
 
AppendSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
Class to group the different append SPInstructions together.
appendTokensLong(int, List<Object>, List<Token>, FrameBlock) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierPosition
 
appendTokensWide(int, List<Object>, List<Token>, FrameBlock) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierPosition
 
appendToSparse(MatrixBlock, int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
appendValue(double, int) - Method in class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap
Append value into the hashmap, but ignore all zero keys.
appendValue(int) - Method in class org.apache.sysds.runtime.compress.utils.IntArrayList
 
appendValue(int, int, double) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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
appendValue(DblArray, int) - Method in class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap
 
appendValuePlain(int, int, double) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
appendValuePlain(int, int, double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
apply(String) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock.FrameMapFunction
 
apply(String[]) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock.FrameMapFunction
 
apply(String, String) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock.FrameMapFunction
 
apply(Set<Long>, Set<Long>) - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinct.BitMapValueCombiner
 
apply(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
apply(CacheBlock<?>, int) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
apply(CacheBlock<?>, MatrixBlock, int) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
Apply Functions are only used in Single Threaded or Multi-Threaded Dense context.
apply(CacheBlock<?>, MatrixBlock, int) - Method in interface org.apache.sysds.runtime.transform.encode.Encoder
Apply the generated metadata to the FrameBlock and saved the result in out.
apply(CacheBlock<?>, MatrixBlock, int) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
apply(CacheBlock<?>, MatrixBlock, int, int) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
apply(CacheBlock<?>, MatrixBlock, int, int, int) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
apply(CacheBlock<?>, MatrixBlock, int, int, int) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
apply(FrameBlock, int) - Method in class org.apache.sysds.runtime.transform.tokenize.Tokenizer
 
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.LegacyEncoder
Encode input data blockwise according to existing transform meta data (transform apply).
APPLY_ENCODER_SEPARATE_STAGES - Static variable in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
APPLY_PIPELINE - org.apache.sysds.common.Builtins
 
APPLY_ROW_BLOCKS_PER_COLUMN - Static variable in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
APPLY_SCHEMA - org.apache.sysds.common.Builtins
 
APPLY_SCHEMA - org.apache.sysds.common.Types.OpOp2
 
APPLY_SCHEMA - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
applyColumnOffset() - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
applyDense(CacheBlock<?>, MatrixBlock, int, int, int) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderUDF
 
applyInternalRepresentation(DocumentRepresentation[], FrameBlock) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplier
 
applyInternalRepresentation(DocumentRepresentation[], FrameBlock, int, int) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierCount
 
applyInternalRepresentation(DocumentRepresentation[], FrameBlock, int, int) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierHash
 
applyInternalRepresentation(DocumentRepresentation[], FrameBlock, int, int) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierPosition
 
applyScalarOp(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Allocate a new dictionary and applies the scalar operation on each cell of to then return the new dictionary.
applyScalarOp(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.DeltaDictionary
 
applyScalarOp(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
applyScalarOp(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
applyScalarOp(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
applyScalarOp(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
applyScalarOpAndAppend(ScalarOperator, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Allocate a new dictionary with one extra row and applies the scalar operation on each cell of to then return the new dictionary.
applyScalarOpAndAppend(ScalarOperator, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
applyScalarOpAndAppend(ScalarOperator, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
applyScalarOpAndAppend(ScalarOperator, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
applyScalarOpAndAppend(ScalarOperator, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
applyScalarOpWithReference(ScalarOperator, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Allocate a new dictionary and apply the scalar operation on each cell to then return a new dictionary.
applyScalarOpWithReference(ScalarOperator, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
applyScalarOpWithReference(ScalarOperator, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
applyScalarOpWithReference(ScalarOperator, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
applyScalarOpWithReference(ScalarOperator, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
applySchema(FrameBlock, Types.ValueType[]) - Static method in class org.apache.sysds.runtime.frame.data.lib.FrameLibApplySchema
Method to create a new FrameBlock where the given schema is applied.
applySchema(FrameBlock, Types.ValueType[], int) - Static method in class org.apache.sysds.runtime.frame.data.lib.FrameLibApplySchema
Method to create a new FrameBlock where the given schema is applied, k is the parallelization degree.
applySchema(FrameBlock, FrameBlock, int) - Static method in class org.apache.sysds.runtime.frame.data.lib.FrameLibApplySchema
Method to create a new FrameBlock where the given schema is applied, k is the parallelization degree.
applyToAll(Class<T>, Consumer<? super T>) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
applyToAll(Consumer<? super ColumnEncoderComposite>) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
applyUnaryOp(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Allocate a new dictionary and apply the unary operator on each cell.
applyUnaryOp(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
applyUnaryOp(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
applyUnaryOp(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
applyUnaryOp(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
applyUnaryOpAndAppend(UnaryOperator, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Allocate a new dictionary with one extra row and apply the unary operator on each cell.
applyUnaryOpAndAppend(UnaryOperator, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
applyUnaryOpAndAppend(UnaryOperator, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
applyUnaryOpAndAppend(UnaryOperator, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
applyUnaryOpAndAppend(UnaryOperator, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
applyUnaryOpWithReference(UnaryOperator, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Allocate a new dictionary and apply the scalar operation on each cell to then return a new dictionary.
applyUnaryOpWithReference(UnaryOperator, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
applyUnaryOpWithReference(UnaryOperator, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
applyUnaryOpWithReference(UnaryOperator, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
applyUnaryOpWithReference(UnaryOperator, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
APreAgg - Class in org.apache.sysds.runtime.compress.colgroup
Abstract class for all the column groups that use preAggregation for Left matrix multiplications.
ARBITRARY_LEN - Static variable in class org.apache.sysds.runtime.util.DMVUtils
 
argVals - Variable in class org.apache.sysds.api.DMLOptions
 
ARIMA - org.apache.sysds.common.Builtins
 
ArithmeticBinary - org.apache.sysds.runtime.instructions.gpu.GPUInstruction.GPUINSTRUCTION_TYPE
 
ArithmeticBinaryGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
 
Array<T> - Class in org.apache.sysds.runtime.frame.data.columns
Generic, resizable native arrays for the internal representation of the columns in the FrameBlock.
ARRAY - org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex.ColIndexType
 
ARRAY - org.apache.sysds.runtime.io.FileFormatPropertiesMM.MMFormat
 
Array.ArrayIterator - Class in org.apache.sysds.runtime.frame.data.columns
 
ArrayFactory - Interface in org.apache.sysds.runtime.frame.data.columns
 
ArrayFactory.FrameArrayType - Enum in org.apache.sysds.runtime.frame.data.columns
 
ArrayIndex - Class in org.apache.sysds.runtime.compress.colgroup.indexes
 
ArrayIndex(int[]) - Constructor for class org.apache.sysds.runtime.compress.colgroup.indexes.ArrayIndex
 
ArrayIterator() - Constructor for class org.apache.sysds.runtime.frame.data.columns.Array.ArrayIterator
 
asArrayList(T...) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
 
ASDC - Class in org.apache.sysds.runtime.compress.colgroup
Column group that sparsely encodes the dictionary values.
ASDCZero - Class in org.apache.sysds.runtime.compress.colgroup
 
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
ASIN - org.apache.sysds.common.Builtins
 
ASIN - org.apache.sysds.common.Types.OpOp1
 
ASIN - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
ASIN - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
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.
ASP - org.apache.sysds.parser.Statement.PSUpdateType
 
assembleTrainingData(JavaPairRDD<MatrixIndexes, MatrixBlock>, JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.SparkParamservUtils
Assemble the matrix of features and labels according to the rowID
ASSERT - org.apache.sysds.common.Types.OpOp1
 
ASSERT - org.apache.sysds.parser.PrintStatement.PRINTTYPE
 
asSet(List<T>...) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
 
asSet(T...) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
 
asSet(T[]...) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
 
assignFuture(CompletableFuture<Future<?>>) - Method in class org.apache.sysds.runtime.util.DependencyTask
 
AssignmentStatement - Class in org.apache.sysds.parser
 
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
 
AssignmentStatement(DataIdentifier, Expression) - Constructor for class org.apache.sysds.parser.AssignmentStatement
 
AssignmentStatement(DataIdentifier, Expression, ParseInfo) - Constructor for class org.apache.sysds.parser.AssignmentStatement
 
AssignmentStatementContext(DmlParser.StatementContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.AssignmentStatementContext
 
AssignVariable - org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
 
ASYNC_BROADCAST_SPARK - Static variable in class org.apache.sysds.hops.OptimizerUtils
 
ASYNC_CHECKPOINT_SPARK - Static variable in class org.apache.sysds.hops.OptimizerUtils
 
ASYNC_CP_OPCODE - Static variable in class org.apache.sysds.lops.Checkpoint
 
ASYNC_PREFETCH_SPARK - Static variable in class org.apache.sysds.hops.OptimizerUtils
Enable prefetch and broadcast.
ASYNC_SPARK_BROADCAST - Static variable in class org.apache.sysds.conf.DMLConfig
 
ASYNC_SPARK_CHECKPOINT - Static variable in class org.apache.sysds.conf.DMLConfig
 
ASYNC_SPARK_PREFETCH - Static variable in class org.apache.sysds.conf.DMLConfig
Asynchronous triggering of Spark OPs and operator placement
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
ATAN - org.apache.sysds.common.Builtins
 
ATAN - org.apache.sysds.common.Types.OpOp1
 
ATAN - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
ATAN - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
AtomicExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.AtomicExpressionContext
 
ATTEMPTED_LOADING_NATIVE_BLAS_UNSUCCESSFULLY - org.apache.sysds.utils.NativeHelper.NativeBlasState
 
AUC - org.apache.sysds.common.Builtins
 
AUTHORPARAM - Static variable in class org.apache.sysds.parser.DataExpression
 
AUTO - org.apache.sysds.hops.codegen.SpoofCompiler.CompilerType
 
AUTO - org.apache.sysds.hops.codegen.SpoofCompiler.GeneratorAPI
 
AUTO - org.apache.sysds.lops.Compression.CompressConfig
 
AUTO - org.apache.sysds.lops.DeCompression.CompressConfig
 
AUTO - org.apache.sysds.runtime.compress.cocode.CoCoderFactory.PartitionerType
 
AUTO - org.apache.sysds.runtime.compress.cost.CostEstimatorFactory.CostType
 
AutoDiff - Class in org.apache.sysds.runtime.util
 
AutoDiff() - Constructor for class org.apache.sysds.runtime.util.AutoDiff
 
AUTODIFF - org.apache.sysds.common.Builtins
 
AUTODIFF - org.apache.sysds.common.Types.ParamBuiltinOp
 
AUTODIFF - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
AUTODIFF - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ParameterizedBuiltinCode
 
AUTOENCODER2LAYER - org.apache.sysds.common.Builtins
 
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
average(long, byte[], byte[][]) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.NativeHEHelper
averages the partial decryptions and returns the result
average(CiphertextMatrix, PlaintextMatrix[]) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.homomorphicEncryption.SEALServer
averages the partial decryptions
AVG - org.apache.sysds.runtime.matrix.data.LibMatrixDNN.PoolingType
 
AVG_POOL - org.apache.sysds.common.Builtins
 
AVG_POOL - org.apache.sysds.common.Types.OpOpDnn
 
AVG_POOL_BACKWARD - org.apache.sysds.common.Builtins
 
AVG_POOL_BACKWARD - org.apache.sysds.common.Types.OpOpDnn
 
awaitTermination(long, TimeUnit) - Method in class org.apache.sysds.runtime.util.CommonThreadPool
 
AWTreeNode - Class in org.apache.sysds.runtime.compress.workload
A workload tree is a compact representation of the operations on a matrix and derived intermediates, including the basic control structure and inlined functions as well as links to categories.
AWTreeNode(AWTreeNode.WTNodeType) - Constructor for class org.apache.sysds.runtime.compress.workload.AWTreeNode
 
AWTreeNode.WTNodeType - Enum in org.apache.sysds.runtime.compress.workload
 
axpy(ExecutionContext, GPUContext, String, MatrixObject, MatrixObject, String, double) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
Performs daxpy operation

B

BALANCE_TO_AVG - org.apache.sysds.parser.Statement.FederatedPSScheme
 
BalanceMetrics(long, long, long) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionFederatedScheme.BalanceMetrics
 
BalanceToAvgFederatedScheme - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
Balance to Avg Federated scheme When the parameter server runs in federated mode it cannot pull in the data which is already on the workers.
BalanceToAvgFederatedScheme() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.BalanceToAvgFederatedScheme
 
BANDIT - org.apache.sysds.common.Builtins
 
baseAddressByte - Variable in class org.apache.sysds.runtime.io.hdf5.H5Superblock
 
BASELINE - org.apache.sysds.parser.Statement.PSRuntimeBalancing
 
baseMemoryCost() - Static method in class org.apache.sysds.runtime.frame.data.columns.Array
Get the base memory cost of the Arrays allocation.
BaseModel - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.models
 
BaseModel() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.BaseModel
 
baseSizeInMemory() - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
BASIC - org.apache.sysds.lops.WeightedCrossEntropy.WCeMMType
 
BASIC - org.apache.sysds.lops.WeightedSigmoid.WSigmoidType
 
BASIC_BLOCK - org.apache.sysds.runtime.compress.workload.AWTreeNode.WTNodeType
 
BASIC_DATA_TYPES - Static variable in class org.apache.sysds.api.mlcontext.MLContextUtil
Basic data types supported by the MLContext API.
BASIC_EPS - org.apache.sysds.lops.WeightedCrossEntropy.WCeMMType
 
BasicProgramBlock - Class in org.apache.sysds.runtime.controlprogram
 
BasicProgramBlock(Program) - Constructor for class org.apache.sysds.runtime.controlprogram.BasicProgramBlock
 
BasicTensorBlock - Class in org.apache.sysds.runtime.data
 
BasicTensorBlock() - Constructor for class org.apache.sysds.runtime.data.BasicTensorBlock
 
BasicTensorBlock(double) - Constructor for class org.apache.sysds.runtime.data.BasicTensorBlock
 
BasicTensorBlock(int[], Types.ValueType, double) - Constructor for class org.apache.sysds.runtime.data.BasicTensorBlock
 
BasicTensorBlock(Types.ValueType, int[]) - Constructor for class org.apache.sysds.runtime.data.BasicTensorBlock
 
BasicTensorBlock(Types.ValueType, int[], boolean) - Constructor for class org.apache.sysds.runtime.data.BasicTensorBlock
 
BasicTensorBlock(Types.ValueType, int[], boolean, long) - Constructor for class org.apache.sysds.runtime.data.BasicTensorBlock
 
BasicTensorBlock(BasicTensorBlock) - Constructor for class org.apache.sysds.runtime.data.BasicTensorBlock
 
BATCH - org.apache.sysds.parser.Statement.PSFrequency
 
BATCH_NORM2D - org.apache.sysds.common.Builtins
 
BATCH_NORM2D_BACKWARD - org.apache.sysds.common.Builtins
 
BATCH_NORM2D_TEST - org.apache.sysds.common.Types.OpOpDnn
 
batchNorm2D(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, String, double, double, MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNN
 
batchNorm2DBackward(MatrixBlock, MatrixBlock, MatrixBlock, double, MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNN
 
batchNormalizationBackward(GPUContext, String, MatrixObject, MatrixObject, MatrixObject, MatrixObject, MatrixObject, MatrixObject, double, MatrixObject, MatrixObject) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNN
This method computes the backpropagation errors for image, scale and bias of batch normalization layer
batchNormalizationForwardInference(GPUContext, String, MatrixObject, MatrixObject, MatrixObject, MatrixObject, MatrixObject, MatrixObject, double) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNN
Performs the forward BatchNormalization layer computation for inference
batchNormalizationForwardTraining(GPUContext, String, MatrixObject, MatrixObject, MatrixObject, MatrixObject, MatrixObject, MatrixObject, MatrixObject, MatrixObject, double, double, MatrixObject, MatrixObject) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNN
Performs the forward BatchNormalization layer computation for training
baToInt(byte[], int) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
 
baToLong(byte[], int) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
 
baToShort(byte[], int) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
 
bFunc - Variable in class org.apache.sysds.runtime.functionobjects.Builtin
 
bFunc - Variable in class org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin
 
bias - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
 
biasAdd(GPUContext, String, MatrixObject, MatrixObject, MatrixObject) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
Performs the operation corresponding to the DML script: ones = matrix(1, rows=1, cols=Hout*Wout) output = input + matrix(bias %*% ones, rows=1, cols=F*Hout*Wout) This operation is often followed by conv2d and hence we have introduced bias_add(input, bias) built-in function
biasAdd(MatrixBlock, MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNN
Performs the operation corresponding to the DML script: ones = matrix(1, rows=1, cols=Hout*Wout) output = input + matrix(bias %*% ones, rows=1, cols=F*Hout*Wout) This operation is often followed by conv2d and hence we have introduced bias_add(input, bias) built-in function
BIASADD - org.apache.sysds.common.Builtins
 
BIASADD - org.apache.sysds.common.Types.OpOpDnn
 
BIASADD - org.apache.sysds.hops.codegen.cplan.CNodeTernary.TernaryType
 
BIASMULT - org.apache.sysds.common.Builtins
 
BIASMULT - org.apache.sysds.common.Types.OpOpDnn
 
BIASMULT - org.apache.sysds.hops.codegen.cplan.CNodeTernary.TernaryType
 
biasMultiply(GPUContext, String, MatrixObject, MatrixObject, MatrixObject) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
Performs the operation corresponding to the DML script: ones = matrix(1, rows=1, cols=Hout*Wout) output = input * matrix(bias %*% ones, rows=1, cols=F*Hout*Wout) This operation is often followed by conv2d and hence we have introduced bias_add(input, bias) built-in function
biasMultiply(MatrixBlock, MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNN
Performs the operation corresponding to the DML script: ones = matrix(1, rows=1, cols=Hout*Wout) output = input * matrix(bias %*% ones, rows=1, cols=F*Hout*Wout) This operation is often followed by conv2d and hence we have introduced bias_multiply(input, bias) built-in function
Bin - org.apache.sysds.runtime.transform.encode.ColumnEncoder.EncoderType
 
BIN - org.apache.sysds.runtime.transform.TfUtils.TfMethod
 
BIN_PACKING - org.apache.sysds.runtime.compress.cocode.CoCoderFactory.PartitionerType
 
Binary - Class in org.apache.sysds.hops.codegen.cplan.cuda
 
Binary - Class in org.apache.sysds.hops.codegen.cplan.java
 
Binary - Class in org.apache.sysds.lops
Lop to perform binary operation.
Binary - org.apache.sysds.lops.Lop.Type
 
Binary - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
Binary - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
Binary - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
Binary() - Constructor for class org.apache.sysds.hops.codegen.cplan.cuda.Binary
 
Binary() - Constructor for class org.apache.sysds.hops.codegen.cplan.java.Binary
 
Binary(Lop, Lop, Types.OpOp2, Types.DataType, Types.ValueType, Types.ExecType) - Constructor for class org.apache.sysds.lops.Binary
Constructor to perform a binary operation.
Binary(Lop, Lop, Types.OpOp2, Types.DataType, Types.ValueType, Types.ExecType, int) - Constructor for class org.apache.sysds.lops.Binary
 
BINARY - org.apache.sysds.common.Types.FileFormat
 
BinaryBlockFrameInputOutputInfo - Static variable in class org.apache.sysds.runtime.io.InputOutputInfo
 
BinaryBlockInputFormat - Class in org.apache.sysds.runtime.util
Custom binary block input format to return the custom record reader.
BinaryBlockInputFormat() - Constructor for class org.apache.sysds.runtime.util.BinaryBlockInputFormat
 
BinaryBlockInputOutputInfo - Static variable in class org.apache.sysds.runtime.io.InputOutputInfo
 
BinaryBlockRecordReader - Class in org.apache.sysds.runtime.util
Custom record reader for binary block.
BinaryBlockRecordReader(Configuration, FileSplit) - Constructor for class org.apache.sysds.runtime.util.BinaryBlockRecordReader
 
BinaryBlockSerialization - Class in org.apache.sysds.runtime.io
This custom serialization class can be used via job.set(MRConfigurationNames.IO_SERIALIZATIONS, "org.apache.sysds.runtime.io.BinaryBlockSerialization");
BinaryBlockSerialization() - Constructor for class org.apache.sysds.runtime.io.BinaryBlockSerialization
 
BinaryBlockSerialization.MatrixBlockDeserializer - Class in org.apache.sysds.runtime.io
 
BinaryBlockSerialization.MatrixBlockSerializer - Class in org.apache.sysds.runtime.io
 
binaryBlocksToFrameObject(JavaPairRDD<Long, FrameBlock>) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
Convert a JavaPairRDD<Long, FrameBlock> to a FrameObject.
binaryBlocksToFrameObject(JavaPairRDD<Long, FrameBlock>, FrameMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
Convert a JavaPairRDD<Long, FrameBlock> to a FrameObject.
binaryBlocksToMatrixBlock(JavaPairRDD<MatrixIndexes, MatrixBlock>, MatrixMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
Convert a JavaPairRDD<MatrixIndexes, MatrixBlock> to a MatrixBlock
binaryBlocksToMatrixObject(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
Convert a JavaPairRDD<MatrixIndexes, MatrixBlock> to a MatrixObject.
binaryBlocksToMatrixObject(JavaPairRDD<MatrixIndexes, MatrixBlock>, MatrixMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
Convert a JavaPairRDD<MatrixIndexes, MatrixBlock> to a MatrixObject.
BinaryBlockTensorInputOutputInfo - Static variable in class org.apache.sysds.runtime.io.InputOutputInfo
 
binaryBlockToBinaryBlock(JavaPairRDD<MatrixIndexes, MatrixBlock>, DataCharacteristics, DataCharacteristics) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
 
binaryBlockToCsv(JavaPairRDD<Long, FrameBlock>, DataCharacteristics, FileFormatPropertiesCSV, boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
 
binaryBlockToCsv(JavaPairRDD<MatrixIndexes, MatrixBlock>, DataCharacteristics, FileFormatPropertiesCSV, boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
 
binaryBlockToDataFrame(SparkSession, JavaPairRDD<Long, FrameBlock>, DataCharacteristics, Types.ValueType[]) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
 
binaryBlockToDataFrame(SparkSession, JavaPairRDD<MatrixIndexes, MatrixBlock>, DataCharacteristics, boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
 
binaryBlockToDataFrame(SQLContext, JavaPairRDD<Long, FrameBlock>, DataCharacteristics, Types.ValueType[]) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
Deprecated.
binaryBlockToDataFrame(SQLContext, JavaPairRDD<MatrixIndexes, MatrixBlock>, DataCharacteristics, boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
Deprecated.
binaryBlockToLabeledPoints(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
Converter from binary block rdd to rdd of labeled points.
binaryBlockToLibsvm(JavaPairRDD<MatrixIndexes, MatrixBlock>, DataCharacteristics, FileFormatPropertiesLIBSVM, boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
 
binaryBlockToMatrixBlock(JavaPairRDD<Long, FrameBlock>, DataCharacteristics, DataCharacteristics) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
 
binaryBlockToTextCell(JavaPairRDD<Long, FrameBlock>, DataCharacteristics) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
 
binaryBlockToTextCell(JavaPairRDD<MatrixIndexes, MatrixBlock>, DataCharacteristics) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
 
BinaryBlockToTextCellConverter - Class in org.apache.sysds.runtime.matrix.data
 
BinaryBlockToTextCellConverter() - Constructor for class org.apache.sysds.runtime.matrix.data.BinaryBlockToTextCellConverter
 
binaryCellToBinaryBlock(JavaSparkContext, JavaPairRDD<MatrixIndexes, MatrixCell>, DataCharacteristics, boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
 
BinaryCellToBinaryBlockFunction(DataCharacteristics) - Constructor for class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils.BinaryCellToBinaryBlockFunction
 
BinaryCP - org.apache.sysds.lops.Lop.Type
 
BinaryCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
binaryDefRowLeft(BinaryOperator, double[], IColIndex) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupUtils
Calculate the result of performing the binary operation on an empty row to the left v op empty
binaryDefRowRight(BinaryOperator, double[], IColIndex) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupUtils
Calculate the result of performing the binary operation on an empty row to the right empty op v
BinaryExpression - Class in org.apache.sysds.parser
 
BinaryExpression(Expression.BinaryOp) - Constructor for class org.apache.sysds.parser.BinaryExpression
 
BinaryExpression(Expression.BinaryOp, ParseInfo) - Constructor for class org.apache.sysds.parser.BinaryExpression
 
BinaryFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
BinaryFEDInstruction(FEDInstruction.FEDType, Operator, CPOperand, CPOperand, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysds.runtime.instructions.fed.BinaryFEDInstruction
 
binaryFn - Variable in class org.apache.sysds.runtime.matrix.operators.AggregateBinaryOperator
 
binaryFn - Variable in class org.apache.sysds.runtime.matrix.operators.AggregateTernaryOperator
 
BinaryFrameFrameCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
BinaryFrameFrameSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
BinaryFrameMatrixCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
BinaryFrameMatrixSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
BinaryM - Class in org.apache.sysds.lops
Lop to perform binary operation.
BinaryM(Lop, Lop, Types.OpOp2, Types.DataType, Types.ValueType, Types.ExecType, boolean) - Constructor for class org.apache.sysds.lops.BinaryM
Constructor to perform a binary operation.
BinaryM.VectorType - Enum in org.apache.sysds.lops
 
BinaryMatrixBVectorSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
BinaryMatrixMatrixCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
BinaryMatrixMatrixFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
BinaryMatrixMatrixSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
BinaryMatrixScalarCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
BinaryMatrixScalarFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
BinaryMatrixScalarSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
BinaryOp - Class in org.apache.sysds.hops
 
BinaryOp(String, Types.DataType, Types.ValueType, Types.OpOp2, Hop, Hop) - Constructor for class org.apache.sysds.hops.BinaryOp
 
BinaryOp.AppendMethod - Enum in org.apache.sysds.hops
 
BinaryOp.MMBinaryMethod - Enum in org.apache.sysds.hops
 
binaryOperations(BinaryOperator, TensorBlock, TensorBlock) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
binaryOperations(BinaryOperator, FrameBlock, FrameBlock) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
This method performs the value comparison on two frames if the values in both frames are equal, not equal, less than, greater than, less than/greater than and equal to the output frame will store boolean value for each each comparison
binaryOperations(BinaryOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
binaryOperations(BinaryOperator, MatrixValue, MatrixValue) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
binaryOperations(BinaryOperator, MatrixValue, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
 
binaryOperations(BinaryOperator, MatrixValue, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
binaryOperations(BinaryOperator, MatrixValue, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
binaryOperations(BinaryOperator, MatrixValue, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
 
binaryOperationsInPlace(BinaryOperator, MatrixValue) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
binaryOperationsInPlace(BinaryOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
 
binaryOperationsInPlace(BinaryOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
binaryOperationsInPlace(BinaryOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
binaryOperationsInPlace(BinaryOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
 
binaryOperationsLeft(BinaryOperator, CompressedMatrixBlock, MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibBinaryCellOp
 
binaryOperationsLeft(BinaryOperator, MatrixValue, MatrixValue) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
binaryOperationsRight(BinaryOperator, CompressedMatrixBlock, MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibBinaryCellOp
 
BinaryOperator - Class in org.apache.sysds.runtime.matrix.operators
 
BinaryOperator(ValueFunction) - Constructor for class org.apache.sysds.runtime.matrix.operators.BinaryOperator
 
BinaryOperator(ValueFunction, int) - Constructor for class org.apache.sysds.runtime.matrix.operators.BinaryOperator
 
binaryRowOpLeft(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Perform a binary row operation.
binaryRowOpLeft(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
binaryRowOpLeft(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
binaryRowOpLeft(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
binaryRowOpLeft(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
binaryRowOpLeft(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
binaryRowOpLeft(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
 
binaryRowOpLeft(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
 
binaryRowOpLeft(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
binaryRowOpLeft(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
binaryRowOpLeft(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
binaryRowOpLeft(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
binaryRowOpLeft(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
binaryRowOpLeft(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
binaryRowOpRight(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Perform a binary row operation.
binaryRowOpRight(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
binaryRowOpRight(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
binaryRowOpRight(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
binaryRowOpRight(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
binaryRowOpRight(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
binaryRowOpRight(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
 
binaryRowOpRight(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
 
binaryRowOpRight(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
binaryRowOpRight(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
binaryRowOpRight(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
binaryRowOpRight(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
binaryRowOpRight(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
binaryRowOpRight(BinaryOperator, double[], boolean) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
BinaryScalar - Class in org.apache.sysds.lops
Lop to perform binary scalar operations.
BinaryScalar(Lop, Lop, Types.OpOp2, Types.DataType, Types.ValueType) - Constructor for class org.apache.sysds.lops.BinaryScalar
Constructor to perform a scalar operation
BinaryScalarScalarCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
BinarySPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
BinaryTensorTensorBroadcastSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
BinaryTensorTensorCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
BinaryTensorTensorSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
BinaryUAggChain - Class in org.apache.sysds.lops
 
BinaryUAggChain(Lop, Types.OpOp2, Types.AggOp, Types.Direction, Types.DataType, Types.ValueType, Types.ExecType) - Constructor for class org.apache.sysds.lops.BinaryUAggChain
Constructor to setup a map mult chain without weights
bincellOp(TensorBlock, TensorBlock, TensorBlock, BinaryOperator) - Static method in class org.apache.sysds.runtime.data.LibTensorBincell
tensor-tensor binary operations
bincellOp(MatrixBlock, MatrixBlock, MatrixBlock, BinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixBincell
matrix-matrix binary operations, MM, MV
bincellOp(MatrixBlock, MatrixBlock, MatrixBlock, BinaryOperator, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixBincell
 
bincellOp(MatrixBlock, MatrixBlock, ScalarOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixBincell
matrix-scalar, scalar-matrix binary operations.
bincellOp(MatrixBlock, MatrixBlock, ScalarOperator, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixBincell
 
bincellOpInPlace(MatrixBlock, MatrixBlock, BinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixBincell
NOTE: operations in place always require m1 and m2 to be of equal dimensions defaults to right side operations, updating the m1 matrix with like: m1ret op m2
bincellOpInPlaceLeft(MatrixBlock, MatrixBlock, BinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixBincell
Left side operations, updating the m1 matrix like: m2 op m1ret
bincellOpInPlaceRight(MatrixBlock, MatrixBlock, BinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixBincell
Right side operations, updating the m1 matrix like: m1ret op m2
bind(long, long, FederationMap) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
bind(Future<FederatedResponse>[], boolean) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
bindResponses(List<Pair<FederatedRange, Future<FederatedResponse>>>, long[]) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
Bind data from federated workers based on non-overlapping federated ranges.
binOpLeft(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Apply binary row operation on the left side
binOpLeft(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
binOpLeft(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
binOpLeft(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
binOpLeft(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
binOpLeftAndAppend(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Apply binary row operation on the left side with one extra row evaluating with zeros.
binOpLeftAndAppend(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
binOpLeftAndAppend(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
binOpLeftAndAppend(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
binOpLeftAndAppend(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
binOpLeftWithReference(BinaryOperator, double[], IColIndex, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Apply the binary operator such that each value is offset by the reference before application.
binOpLeftWithReference(BinaryOperator, double[], IColIndex, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
binOpLeftWithReference(BinaryOperator, double[], IColIndex, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
binOpLeftWithReference(BinaryOperator, double[], IColIndex, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
binOpLeftWithReference(BinaryOperator, double[], IColIndex, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
binOpRight(BinaryOperator, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Apply binary row operation on the right side as with no columns to extract from v.
binOpRight(BinaryOperator, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
binOpRight(BinaryOperator, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
binOpRight(BinaryOperator, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
binOpRight(BinaryOperator, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
binOpRight(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Apply binary row operation on the right side.
binOpRight(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
binOpRight(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
binOpRight(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
binOpRight(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
binOpRightAndAppend(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Apply binary row operation on the right side with one extra row evaluating with zeros.
binOpRightAndAppend(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
binOpRightAndAppend(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
binOpRightAndAppend(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
binOpRightAndAppend(BinaryOperator, double[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
binOpRightWithReference(BinaryOperator, double[], IColIndex, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Apply the binary operator such that each value is offset by the reference before application.
binOpRightWithReference(BinaryOperator, double[], IColIndex, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
binOpRightWithReference(BinaryOperator, double[], IColIndex, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
binOpRightWithReference(BinaryOperator, double[], IColIndex, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
binOpRightWithReference(BinaryOperator, double[], IColIndex, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
BinUaggChain - org.apache.sysds.lops.Lop.Type
 
BinUaggChain - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
BinUaggChainSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
Instruction that performs res = X / rowsum(x)
BinUaggChainSPInstruction.RDDBinUaggChainFunction - Class in org.apache.sysds.runtime.instructions.spark
 
BIT - org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory.MAP_TYPE
 
Bitmap - Class in org.apache.sysds.runtime.compress.bitmap
Uncompressed representation of one or more columns in bitmap format.
BITMAP_BLOCK_SZ - Static variable in class org.apache.sysds.runtime.compress.CompressionSettings
Size of the blocks used in a blocked bitmap representation.
BitmapEncoder - Class in org.apache.sysds.runtime.compress.bitmap
Static functions for extracting bitmaps from a MatrixBlock.
BitmapEncoder() - Constructor for class org.apache.sysds.runtime.compress.bitmap.BitmapEncoder
 
BitMapValueCombiner - Class in org.apache.sysds.runtime.matrix.data.sketch.countdistinct
 
BitMapValueCombiner() - Constructor for class org.apache.sysds.runtime.matrix.data.sketch.countdistinct.BitMapValueCombiner
 
BITSET - org.apache.sysds.runtime.frame.data.columns.ArrayFactory.FrameArrayType
 
BitSetArray - Class in org.apache.sysds.runtime.frame.data.columns
 
BitSetArray(boolean[]) - Constructor for class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
BitSetArray(long[], int) - Constructor for class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
BitSetArray(BitSet, int) - Constructor for class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
bitSetCost(long) - Static method in class org.apache.sysds.utils.MemoryEstimates
Get the worst case memory usage of an java.util.BitSet java object.
BitsetMatrix(int, int) - Constructor for class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix
 
BitsetMatrix1(int, int) - Constructor for class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix1
 
BitsetMatrix1(MatrixBlock) - Constructor for class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix1
 
BitsetMatrix2(int, int) - Constructor for class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix2
 
BitsetMatrix2(MatrixBlock) - Constructor for class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix2
 
bitSetSwitchPoint - Static variable in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
bitsToInt(BitSet, int, int) - Static method in class org.apache.sysds.runtime.io.hdf5.Utils
 
BitwAnd - Class in org.apache.sysds.runtime.functionobjects
 
BITWAND - org.apache.sysds.common.Builtins
 
BITWAND - org.apache.sysds.common.Types.OpOp2
 
BITWAND - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
BitwOr - Class in org.apache.sysds.runtime.functionobjects
 
BITWOR - org.apache.sysds.common.Builtins
 
BITWOR - org.apache.sysds.common.Types.OpOp2
 
BitwShiftL - Class in org.apache.sysds.runtime.functionobjects
 
BITWSHIFTL - org.apache.sysds.common.Builtins
 
BITWSHIFTL - org.apache.sysds.common.Types.OpOp2
 
BitwShiftR - Class in org.apache.sysds.runtime.functionobjects
 
BITWSHIFTR - org.apache.sysds.common.Builtins
 
BITWSHIFTR - org.apache.sysds.common.Types.OpOp2
 
BitwXor - Class in org.apache.sysds.runtime.functionobjects
 
BITWXOR - org.apache.sysds.common.Builtins
 
BITWXOR - org.apache.sysds.common.Types.OpOp2
 
BIVAR - org.apache.sysds.common.Builtins
 
blen - Variable in class org.apache.sysds.runtime.io.ReadProperties
 
block - Variable in class org.apache.sysds.runtime.controlprogram.parfor.util.PairWritableBlock
 
Block - Interface in org.apache.sysds.runtime.data
 
BLOCK_SIZE - org.apache.sysds.conf.CompilerConfig.ConfigType
 
BLOCK_WISE_M_N - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PDataPartitionFormat
 
blockDimX - Variable in class org.apache.sysds.runtime.instructions.gpu.context.ExecutionConfig
 
blockDimY - Variable in class org.apache.sysds.runtime.instructions.gpu.context.ExecutionConfig
 
blockDimZ - Variable in class org.apache.sysds.runtime.instructions.gpu.context.ExecutionConfig
 
BlockPartitioner - Class in org.apache.sysds.runtime.instructions.spark.data
Default partitioner used for all binary block rdd operations in order to enable sufficient local aggregation independent of the aggregation direction (row/col-wise).
BlockPartitioner(DataCharacteristics, int) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.BlockPartitioner
 
blocks - Variable in class org.apache.sysds.parser.dml.DmlParser.ProgramrootContext
 
blockSize() - Method in class org.apache.sysds.runtime.data.DenseBlock
Get the number of rows per block, except last one.
blockSize() - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
 
blockSize() - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
 
blockSize(int) - Method in class org.apache.sysds.runtime.data.DenseBlock
Get the number of rows of the given block.
blockSize(int) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
 
blockSize(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
 
BLOCKSIZE_J - Static variable in class org.apache.sysds.runtime.io.FrameWriterTextCSV
 
BLOCKSIZE_J - Static variable in class org.apache.sysds.runtime.io.WriterTextCSV
 
blocksizeIJ - Static variable in interface org.apache.sysds.runtime.frame.data.lib.MatrixBlockFromFrame
 
body - Variable in class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
 
body - Variable in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
 
body - Variable in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
 
body - Variable in class org.apache.sysds.parser.dml.DmlParser.WhileStatementContext
 
BOOLEAN - org.apache.sysds.common.Types.ValueType
 
BOOLEAN - org.apache.sysds.runtime.frame.data.columns.ArrayFactory.FrameArrayType
 
BOOLEAN_SIZE - Static variable in class org.apache.sysds.hops.OptimizerUtils
 
BOOLEAN_VALUE_TYPE - Static variable in class org.apache.sysds.parser.Statement
 
BooleanAndExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.BooleanAndExpressionContext
 
BooleanArray - Class in org.apache.sysds.runtime.frame.data.columns
 
BooleanArray(boolean[]) - Constructor for class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
BooleanArray32 - Class in org.apache.sysds.runtime.lineage
 
BooleanArray32(int) - Constructor for class org.apache.sysds.runtime.lineage.BooleanArray32
 
booleanArrayCost(long) - Static method in class org.apache.sysds.utils.MemoryEstimates
Get the worst case memory usage of an array of booleans.
BooleanExpression - Class in org.apache.sysds.parser
 
BooleanExpression(Expression.BooleanOp) - Constructor for class org.apache.sysds.parser.BooleanExpression
 
BooleanExpression(Expression.BooleanOp, ParseInfo) - Constructor for class org.apache.sysds.parser.BooleanExpression
 
BooleanIdentifier - Class in org.apache.sysds.parser
 
BooleanIdentifier(boolean) - Constructor for class org.apache.sysds.parser.BooleanIdentifier
 
BooleanIdentifier(boolean, ParseInfo) - Constructor for class org.apache.sysds.parser.BooleanIdentifier
 
BooleanIdentifier(ParserRuleContext, boolean, String) - Constructor for class org.apache.sysds.parser.BooleanIdentifier
 
BooleanNotExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.BooleanNotExpressionContext
 
BooleanObject - Class in org.apache.sysds.runtime.instructions.cp
 
BooleanObject(boolean) - Constructor for class org.apache.sysds.runtime.instructions.cp.BooleanObject
 
BooleanOrExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.BooleanOrExpressionContext
 
booleanPattern - Static variable in interface org.apache.sysds.runtime.frame.data.lib.FrameUtil
 
BREADTH_FIRST - org.apache.sysds.lops.compile.linearization.ILinearize.DagLinearization
 
BREAKPOINT - org.apache.sysds.runtime.instructions.Instruction.IType
 
broadcast(CacheableData<?>) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
broadcast(MatrixLineagePair) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
broadcast(ScalarObject) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
Broadcast - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
BROADCAST - org.apache.sysds.common.Types.OpOp1
 
BROADCAST - org.apache.sysds.hops.fedplanner.FTypes.FType
 
BroadcastCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
BroadcastObject<T extends CacheBlock<?>> - Class in org.apache.sysds.runtime.instructions.spark.data
 
BroadcastObject() - Constructor for class org.apache.sysds.runtime.instructions.spark.data.BroadcastObject
 
broadcastSliced(CacheableData<?>, boolean) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
broadcastSliced(CacheableData<?>, boolean, int[][]) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
broadcastSliced(CacheableData<?>, LineageItem, boolean, int[][]) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
broadcastSliced(MatrixLineagePair, boolean) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
broadcastSliced(MatrixLineagePair, boolean, int[][]) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
broadcastVariable(CacheableData<CacheBlock<?>>) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
 
BSP - org.apache.sysds.parser.Statement.PSUpdateType
 
BUFFER_POOL_SIZE - Static variable in class org.apache.sysds.hops.OptimizerUtils
Buffer pool size in bytes
BUFFER_SIZE - Static variable in class org.apache.sysds.runtime.frame.data.FrameBlock
Buffer size variable: 1M elements, size of default matrix block
BUFFER_SIZE - Static variable in class org.apache.sysds.runtime.util.LocalFileUtils
 
bufferBuilder - Variable in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
BUFFERPOOL_LIMIT - Static variable in class org.apache.sysds.conf.DMLConfig
 
build() - Method in class org.apache.sysds.runtime.io.hdf5.H5BufferBuilder
 
build(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
build(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
build(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
build(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderFeatureHash
 
build(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderPassThrough
 
build(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
build(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderUDF
 
build(CacheBlock<?>) - Method in interface org.apache.sysds.runtime.transform.encode.Encoder
Build the transform meta data for the given block input.
build(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
build(CacheBlock<?>, double[]) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
build(CacheBlock<?>, double[]) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
build(CacheBlock<?>, int) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
build(CacheBlock<?>, int, Map<Integer, double[]>) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
build(CacheBlock<?>, Map<Integer, double[]>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
build(CacheBlock<?>, Map<Integer, double[]>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
build(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
 
build(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
 
build(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.LegacyEncoder
Build the transform meta data for the given block input.
build(FrameBlock, int) - Method in class org.apache.sysds.runtime.transform.tokenize.Tokenizer
 
build(DocumentRepresentation[], int, int) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplier
 
build(DocumentRepresentation[], int, int) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierCount
 
build(DocumentRepresentation[], int, int) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierHash
 
BUILD_ROW_BLOCKS_PER_COLUMN - Static variable in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
BUILD_TIME_NOT_AVAILABLE - Static variable in class org.apache.sysds.api.mlcontext.MLContextUtil
Build time not available message.
buildCombinations(List<List<FTypes.FType>>, List<List<FTypes.FType>>, int, List<FTypes.FType>) - Method in class org.apache.sysds.hops.fedplanner.FederatedPlannerCostbased
 
buildNext(MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorLayeredGraph.LayeredGraph
 
buildPartial(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
Partial build of internal data structures (e.g., in distributed spark operations).
buildPartial(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
buildPartial(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
buildPartial(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
buildPartial(FrameBlock) - Method in interface org.apache.sysds.runtime.transform.encode.Encoder
Partial build of internal data structures (e.g., in distributed spark operations).
buildPartial(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.LegacyEncoder
Partial build of internal data structures (e.g., in distributed spark operations).
buildPartial(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
buildTime() - Method in class org.apache.sysds.api.mlcontext.MLContext
Obtain the SystemDS jar file build time.
buildTime() - Method in class org.apache.sysds.api.mlcontext.ProjectInfo
Object the artifact build time from the manifest.
Builtin - Class in org.apache.sysds.runtime.functionobjects
Class with pre-defined set of objects.
Builtin - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
Builtin - org.apache.sysds.runtime.instructions.gpu.GPUInstruction.GPUINSTRUCTION_TYPE
 
Builtin - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
BUILTIN_NAMESPACE - Static variable in class org.apache.sysds.parser.DMLProgram
 
Builtin.BuiltinCode - Enum in org.apache.sysds.runtime.functionobjects
 
BuiltinBinary - org.apache.sysds.runtime.instructions.gpu.GPUInstruction.GPUINSTRUCTION_TYPE
 
BuiltinBinaryGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
 
BuiltinConstant - Enum in org.apache.sysds.parser
These are the builtin constants
BuiltinFunctionExpression - Class in org.apache.sysds.parser
 
BuiltinFunctionExpression(ParserRuleContext, Builtins, ArrayList<ParameterExpression>, String) - Constructor for class org.apache.sysds.parser.BuiltinFunctionExpression
 
BuiltinFunctionExpression(ParserRuleContext, Builtins, Expression[], String) - Constructor for class org.apache.sysds.parser.BuiltinFunctionExpression
 
BuiltinFunctionExpression(Builtins, Expression[], ParseInfo) - Constructor for class org.apache.sysds.parser.BuiltinFunctionExpression
 
BuiltinFunctionExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.BuiltinFunctionExpressionContext
 
BuiltinNary - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
BuiltinNary - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
BuiltinNaryCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
Instruction to handle a variable number of input operands.
BuiltinNaryCPInstruction(Operator, String, String, CPOperand, CPOperand...) - Constructor for class org.apache.sysds.runtime.instructions.cp.BuiltinNaryCPInstruction
 
BuiltinNarySPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
BuiltinNarySPInstruction.PadBlocksFunction - Class in org.apache.sysds.runtime.instructions.spark
 
Builtins - Enum in org.apache.sysds.common
Enum to represent all builtin functions in the default name space.
BuiltinUnary - org.apache.sysds.runtime.instructions.gpu.GPUInstruction.GPUINSTRUCTION_TYPE
 
BuiltinUnaryGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
 
bwAnd(double, double) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
 
BYTE - org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory.MAP_TYPE
 
BYTE - org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory.OFF_TYPE_SPECIALIZATIONS
 
BYTE - org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory.OFF_TYPE
 
byteAmount - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.TrafficModel
 
byteArrayCost(long) - Static method in class org.apache.sysds.utils.MemoryEstimates
Get the worst case memory usage of an array of bytes.
ByteBuffer - Class in org.apache.sysds.runtime.controlprogram.caching
Wrapper for WriteBuffer byte array per matrix/frame in order to support matrix/frame serialization outside global lock.
ByteBuffer(long) - Constructor for class org.apache.sysds.runtime.controlprogram.caching.ByteBuffer
 
ByteBufferDataInput - Class in org.apache.sysds.runtime.util
 
ByteBufferDataInput(ByteBuffer) - Constructor for class org.apache.sysds.runtime.util.ByteBufferDataInput
 
ByteClassLoader - Class in org.apache.sysds.runtime.codegen
 
ByteClassLoader(URL[], ClassLoader, byte[]) - Constructor for class org.apache.sysds.runtime.codegen.ByteClassLoader
 

C

C - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
 
c2 - Variable in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
 
CACHE_BLOCK - Static variable in class org.apache.sysds.runtime.compress.colgroup.insertionsort.MaterializeSort
The block size to materialize at a time
CACHE_HITS_FS - org.apache.sysds.runtime.controlprogram.caching.CacheStatistics.Stat
 
CACHE_HITS_FSBUFF - org.apache.sysds.runtime.controlprogram.caching.CacheStatistics.Stat
 
CACHE_HITS_HDFS - org.apache.sysds.runtime.controlprogram.caching.CacheStatistics.Stat
 
CACHE_HITS_LIN - org.apache.sysds.runtime.controlprogram.caching.CacheStatistics.Stat
 
CACHE_HITS_MEM - org.apache.sysds.runtime.controlprogram.caching.CacheStatistics.Stat
 
CACHE_TIME_ACQM - org.apache.sysds.runtime.controlprogram.caching.CacheStatistics.Stat
 
CACHE_TIME_ACQR - org.apache.sysds.runtime.controlprogram.caching.CacheStatistics.Stat
 
CACHE_TIME_EXP - org.apache.sysds.runtime.controlprogram.caching.CacheStatistics.Stat
 
CACHE_TIME_RLS - org.apache.sysds.runtime.controlprogram.caching.CacheStatistics.Stat
 
CACHE_WRITES_FS - org.apache.sysds.runtime.controlprogram.caching.CacheStatistics.Stat
 
CACHE_WRITES_FSBUFF - org.apache.sysds.runtime.controlprogram.caching.CacheStatistics.Stat
 
CACHE_WRITES_HDFS - org.apache.sysds.runtime.controlprogram.caching.CacheStatistics.Stat
 
CACHE_WRITES_LIN - org.apache.sysds.runtime.controlprogram.caching.CacheStatistics.Stat
 
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<T> - 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
 
CACHED - org.apache.sysds.runtime.controlprogram.caching.CacheableData.CacheStatus
 
CACHED_NOWRITE - org.apache.sysds.runtime.controlprogram.caching.CacheableData.CacheStatus
 
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(byte[]) - Constructor for class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
 
CacheDataOutput(int) - 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
 
CacheEvictionQueue - Class in org.apache.sysds.runtime.controlprogram.caching
 
CacheEvictionQueue() - Constructor for class org.apache.sysds.runtime.controlprogram.caching.CacheEvictionQueue
 
cacheIterator(AIterator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
Cache a iterator in use, note that there is no check for if the iterator is correctly positioned at the given row
CacheMaintenanceService - Class in org.apache.sysds.runtime.controlprogram.caching
 
CacheMaintenanceService() - Constructor for class org.apache.sysds.runtime.controlprogram.caching.CacheMaintenanceService
 
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_ASYNC_SERIALIZE - 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_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
 
calculatePatternsRatio(Map<String, Integer>, int) - Static method in class org.apache.sysds.runtime.util.DMVUtils
 
call() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.FederatedPSControlThread
Entry point of the functionality
call() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.LocalPSWorker
 
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
 
call() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderFeatureHash.FeatureHashSparseApplyTask
 
call() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderPassThrough.PassThroughSparseApplyTask
 
call() - Method in class org.apache.sysds.runtime.util.DependencyTask
 
call() - Method in class org.apache.sysds.runtime.util.DependencyWrapperTask
 
call(Iterable<WeightedCell>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.PerformGroupByAggInReducer
 
call(String) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ConvertStringToLongTextPair
 
call(Iterator<MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.RecomputeNnzFunction
 
call(Iterator<Tuple2<Long, Iterable<Writable>>>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteDPParForSparkWorker
 
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(Iterator<Tuple2<TensorIndexes, BasicTensorBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.CopyTensorBlockPairFunction
 
call(Iterator<Tuple2<TensorIndexes, TensorBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.TensorTensorBinaryOpPartitionFunction
 
call(Iterator<Tuple2<MatrixIndexes, MatrixBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.CopyMatrixBlockPairFunction
 
call(Iterator<Tuple2<MatrixIndexes, MatrixBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.MatrixVectorBinaryOpPartitionFunction
 
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.functions.GetMIMBFromRow
 
call(Row) - Method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils.DataFrameExtractIDFunction
 
call(CompressedWriteBlock) - Method in class org.apache.sysds.runtime.compress.io.CompressUnwrap
 
call(Task) - Method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForSparkWorker
 
call(BasicTensorBlock) - Method in class org.apache.sysds.runtime.instructions.spark.functions.CopyTensorBlockFunction
 
call(FrameBlock) - Method in class org.apache.sysds.runtime.instructions.spark.functions.CopyFrameBlockFunction
 
call(FrameBlock) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDFrameReplaceFunction
 
call(MatrixBlock) - Method in class org.apache.sysds.runtime.compress.io.CompressWrap
 
call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.BinUaggChainSPInstruction.RDDBinUaggChainFunction
 
call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.CompressionSPInstruction.CompressionFunction
 
call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.CompressionSPInstruction.CompressionWorkloadFunction
 
call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.CompressionSPInstruction.SizeFunction
 
call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.CtableSPInstruction.MapJoinSignature1
 
call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.DeCompressionSPInstruction.DeCompressionFunction
 
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(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.functions.CopyMatrixBlockFunction
 
call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.functions.CreateSparseBlockFunction
 
call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.functions.FilterNonEmptyBlocksFunction2
 
call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.functions.MapInputSignature
 
call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.functions.MatrixScalarUnaryFunction
 
call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDContainsFunction
 
call(MatrixBlock) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDReplaceFunction
 
call(WeightedCell) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.CreateMatrixCell
 
call(WeightedCell, WeightedCell) - Method in class org.apache.sysds.runtime.instructions.spark.functions.PerformGroupByAggInCombiner
 
call(Tuple2<Integer, Iterable<Object>>) - Method in class org.apache.sysds.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeGroupFunction
 
call(Tuple2<Integer, Iterable<ColumnMetadata>>) - Method in class org.apache.sysds.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeGroup2Function
 
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<Integer, Tuple2<MatrixBlock, MatrixBlock>>) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.SparkPSWorker
 
call(Tuple2<Long, Iterable<Writable>>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.DataPartitionerRemoteSparkReducer
 
call(Tuple2<Long, FrameBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ConvertFrameBlockToIJVLines
 
call(Tuple2<Long, FrameBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.IsFrameBlockInRange
 
call(Tuple2<Long, FrameBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTokenizeFunction
 
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<Long, FrameBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils.LongFrameToLongWritableFrameFunction
 
call(Tuple2<Long, Tuple2<MatrixBlock, MatrixBlock>>) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionerSparkMapper
Do data partitioning
call(Tuple2<LongWritable, Text>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.CopyTextInputFunction
 
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.functions.CopyFrameBlockPairFunction
 
call(Tuple2<LongWritable, FrameBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils.LongWritableFrameToLongFrameFunction
 
call(Tuple2<LongWritable, FrameBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils.LongWritableToSerFunction
 
call(Tuple2<Row, Long>) - Method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtilsExt.AddRowID
 
call(Tuple2<TensorBlock, TensorBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.TensorTensorBinaryOpFunction
 
call(Tuple2<TensorIndexes, TensorBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.AggregateUnarySPInstruction.RDDUTensorAggFunction2
 
call(Tuple2<TensorIndexes, TensorBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ReblockTensorFunction
 
call(Tuple2<TensorIndexes, TensorBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ReplicateTensorFunction
 
call(Tuple2<MatrixBlock, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.CtableSPInstruction.MapJoinSignature2
 
call(Tuple2<MatrixBlock, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.MatrixMatrixBinaryOpFunction
 
call(Tuple2<MatrixBlock[], MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.MapJoinSignature
 
call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.DataPartitionerRemoteSparkMapper
 
call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.AggregateUnarySPInstruction.RDDUAggFunction2
 
call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.AppendGAlignedSPInstruction.ShiftColumnIndex
 
call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.AppendGSPInstruction.ShiftMatrix
 
call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.BuiltinNarySPInstruction.PadBlocksFunction
 
call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ConvertMatrixBlockToIJVLines
 
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, 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(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<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.OuterVectorBinaryOpFunction
 
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<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ReplicateVectorFunction
 
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, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDRemoveEmptyFunctionInMem
 
call(Tuple2<MatrixIndexes, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDRExpandFunction
 
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<MatrixIndexes, MatrixCell>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.CopyBinaryCellFunction
 
call(Tuple2<MatrixIndexes, Tuple2<Iterable<MatrixBlock>, Iterable<MatrixBlock>>>) - Method in class org.apache.sysds.runtime.instructions.spark.AppendGSPInstruction.MergeWithShiftedBlocks
 
call(Tuple2<MatrixIndexes, Tuple2<Iterable<MatrixBlock>, MatrixBlock>>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeRemoteSparkWCompare
 
call(Tuple2<MatrixIndexes, Tuple2<MatrixBlock, MatrixBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ExtractGroup.ExtractGroupJoin
 
call(Tuple2<MatrixIndexes, Tuple2<MatrixBlock, MatrixBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDRemoveEmptyFunction
 
call(Tuple2<MatrixIndexes, Tuple2<Tuple2<MatrixBlock, MatrixBlock>, MatrixBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.functions.ExtractGroupNWeights
 
call(Tuple2<Tuple2<MatrixBlock, MatrixBlock>, MatrixBlock>) - Method in class org.apache.sysds.runtime.instructions.spark.CtableSPInstruction.MapJoinSignature3
 
callInstruction(String[], CPOperand, long, CPOperand[], long[], Types.ExecType) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
callInstruction(String[], CPOperand, CPOperand[], long[]) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
callInstruction(String, CPOperand, long, CPOperand[], long[], Types.ExecType, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
callInstruction(String, CPOperand, CPOperand[], long[]) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
callInstruction(String, CPOperand, CPOperand[], long[], boolean) - 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
 
Cast - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
Cast - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
CAST_AS_BOOLEAN - org.apache.sysds.common.Builtins
 
CAST_AS_BOOLEAN - org.apache.sysds.common.Types.OpOp1
 
CAST_AS_DOUBLE - org.apache.sysds.common.Builtins
 
CAST_AS_DOUBLE - org.apache.sysds.common.Types.OpOp1
 
CAST_AS_FRAME - org.apache.sysds.common.Builtins
 
CAST_AS_FRAME - org.apache.sysds.common.Types.OpOp1
 
CAST_AS_INT - org.apache.sysds.common.Builtins
 
CAST_AS_INT - org.apache.sysds.common.Types.OpOp1
 
CAST_AS_LIST - org.apache.sysds.common.Builtins
 
CAST_AS_LIST - org.apache.sysds.common.Types.OpOp1
 
CAST_AS_MATRIX - org.apache.sysds.common.Builtins
 
CAST_AS_MATRIX - org.apache.sysds.common.Types.OpOp1
 
CAST_AS_SCALAR - org.apache.sysds.common.Builtins
 
CAST_AS_SCALAR - org.apache.sysds.common.Types.OpOp1
 
CastAsBooleanVariable - org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
 
CastAsDoubleVariable - org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
 
CastAsFrameVariable - org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
 
CastAsIntegerVariable - org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
 
CastAsListVariable - org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
 
CastAsMatrixVariable - org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
 
CastAsScalarVariable - org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
 
CastFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
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
 
CBIND - org.apache.sysds.common.Builtins
 
CBIND - org.apache.sysds.common.Types.OpOp2
 
CBIND - org.apache.sysds.common.Types.OpOpN
 
CBIND - org.apache.sysds.hops.estim.SparsityEstimator.OpCode
 
CBIND - org.apache.sysds.runtime.instructions.cp.AppendCPInstruction.AppendType
 
cbindMatrix(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
 
CBindPropagator - Class in org.apache.sysds.runtime.privacy.propagation
 
CBindPropagator(MatrixBlock, PrivacyConstraint, MatrixBlock, PrivacyConstraint) - Constructor for class org.apache.sysds.runtime.privacy.propagation.CBindPropagator
 
CDATA_BEGIN - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
 
CDATA_END - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
 
CDF - org.apache.sysds.common.Builtins
 
CDF - org.apache.sysds.common.Types.ParamBuiltinOp
 
CDF - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ParameterizedBuiltinCode
 
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
CEIL - org.apache.sysds.common.Builtins
 
CEIL - org.apache.sysds.common.Types.OpOp1
 
CEIL - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
CEIL - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
cell - Variable in class org.apache.sysds.runtime.controlprogram.parfor.util.PairWritableCell
 
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 - org.apache.sysds.hops.codegen.template.TemplateBase.TemplateType
 
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
 
CELLWISE_OUTER_PRODUCT - org.apache.sysds.runtime.codegen.SpoofOuterProduct.OutProdType
 
centralMoment(CompressedMatrixBlock, CMOperator) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibCMOps
 
centralMoment(ValueFunction, int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Central moment function to calculate the central moment of this column group.
centralMoment(CM_COV_Object, ValueFunction, int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Central moment function to calculate the central moment of this column group.
centralMoment(CM_COV_Object, ValueFunction, int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
centralMoment(CM_COV_Object, ValueFunction, int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
centralMoment(CM_COV_Object, ValueFunction, int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
centralMoment(CM_COV_Object, ValueFunction, int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
centralMoment(CMOperator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Central Moment instruction executed on a column group.
centralMoment(CMOperator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupValue
 
centralMoment(CMOperator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
centralMoment(CMOperator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
centralMoment(CMOperator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
centralMoment(CMOperator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
centralMoment(CMOperator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
centralMoment(CMOperator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
centralMoment(CMOperator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
centralMoment(CMOperator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
CentralMoment - Class in org.apache.sysds.lops
Lop to perform cross product operation
CentralMoment - org.apache.sysds.lops.Lop.Type
 
CentralMoment - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
CentralMoment - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
CentralMoment - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
CentralMoment(Lop, Lop, Types.DataType, Types.ValueType, int, Types.ExecType) - Constructor for class org.apache.sysds.lops.CentralMoment
 
CentralMoment(Lop, Lop, Lop, Types.DataType, Types.ValueType, int, Types.ExecType) - Constructor for class org.apache.sysds.lops.CentralMoment
 
CentralMomentCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
CentralMomentFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
CentralMomentSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
centralMomentWithDefault(ValueFunction, int[], double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Central moment function to calculate the central moment of this column group with a default offset on all missing tuples.
centralMomentWithDefault(CM_COV_Object, ValueFunction, int[], double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Central moment function to calculate the central moment of this column group with a default offset on all missing tuples.
centralMomentWithDefault(CM_COV_Object, ValueFunction, int[], double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
centralMomentWithDefault(CM_COV_Object, ValueFunction, int[], double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
centralMomentWithDefault(CM_COV_Object, ValueFunction, int[], double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
centralMomentWithDefault(CM_COV_Object, ValueFunction, int[], double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
centralMomentWithReference(ValueFunction, int[], double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Central moment function to calculate the central moment of this column group with a reference offset on each tuple.
centralMomentWithReference(CM_COV_Object, ValueFunction, int[], double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Central moment function to calculate the central moment of this column group with a reference offset on each tuple.
centralMomentWithReference(CM_COV_Object, ValueFunction, int[], double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
centralMomentWithReference(CM_COV_Object, ValueFunction, int[], double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
centralMomentWithReference(CM_COV_Object, ValueFunction, int[], double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
centralMomentWithReference(CM_COV_Object, ValueFunction, int[], double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
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.compress.CompressedMatrixBlock
 
chainMatrixMultOperations(MatrixBlock, MatrixBlock, MatrixBlock, MapMultChain.ChainType, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
changeType(Types.ValueType) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Change the allocated array to a different type.
changeTypeCharacter() - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
changeTypeCharacter() - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
changeTypeCharacter() - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
changeTypeCharacter() - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
changeTypeCharacter() - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
changeTypeCharacter() - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
changeTypeCharacter() - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
changeTypeCharacter() - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
changeTypeString() - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
changeTypeWithNulls(Types.ValueType) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
 
changeTypeWithNulls(Types.ValueType) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
CHANNEL_SUMS - org.apache.sysds.common.Types.OpOpDnn
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.NetworkTrafficCounter
 
channelNames - Static variable in class org.apache.sysds.parser.dml.DmlLexer
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedWorkerHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.FederatedMonitoringServerHandler
 
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 - org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory.MAP_TYPE
 
CHAR - org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory.OFF_TYPE_SPECIALIZATIONS
 
CHAR - org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory.OFF_TYPE
 
CHAR_BYTE - org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory.MAP_TYPE
 
CHAR_SIZE - Static variable in class org.apache.sysds.hops.OptimizerUtils
 
CHARACTER - org.apache.sysds.common.Types.ValueType
 
CHARACTER - org.apache.sysds.runtime.frame.data.columns.ArrayFactory.FrameArrayType
 
CharArray - Class in org.apache.sysds.runtime.frame.data.columns
 
CharArray(char[]) - Constructor for class org.apache.sysds.runtime.frame.data.columns.CharArray
 
charArrayCost(long) - Static method in class org.apache.sysds.utils.MemoryEstimates
Get the worst case memory usage of an array of chars.
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
Check and replace CP instructions with federated instructions if the instruction match criteria.
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
 
checkCMOperations(MatrixBlock, CMOperator) - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
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
 
checkDimensionsForAppend(MatrixBlock[], boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
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
 
checkFedMapType(MatrixObject) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
checkHasDelimitedFormat(String, boolean) - Static method in class org.apache.sysds.runtime.meta.MetaDataAll
 
checkHasMatrixMarketFormat(String, String, boolean) - Static method in class org.apache.sysds.runtime.meta.MetaDataAll
 
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.compress.CompressedMatrixBlock
 
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...) - 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 - org.apache.sysds.lops.Lop.Type
 
Checkpoint - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
Checkpoint - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
Checkpoint(Lop, Types.DataType, Types.ValueType, String) - Constructor for class org.apache.sysds.lops.Checkpoint
 
Checkpoint(Lop, Types.DataType, Types.ValueType, String, boolean) - 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
 
checkpointRDD(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.ComputationSPInstruction
 
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
 
checkRexpand(MatrixBlock, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
Quick check if the input is valid for rexpand, this check does not guarantee that the input is valid for rexpand
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.
checkSparsity(String, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
 
checkTransposeSelf() - Method in class org.apache.sysds.hops.AggBinaryOp
TSMM: Determine if XtX pattern applies for this aggbinary and if yes which type.
checkValidEncoders(JSONObject) - Static method in class org.apache.sysds.runtime.transform.meta.TfMetaUtils
 
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
 
CHISQ - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ProbabilityDistributionCode
 
CHOLESKY - org.apache.sysds.common.Builtins
 
CHOLESKY - org.apache.sysds.common.Types.OpOp1
 
CiphertextMatrix - Class in org.apache.sysds.runtime.instructions.cp
This class abstracts over an encrypted matrix of ciphertexts.
CiphertextMatrix(int[], DataCharacteristics, byte[]) - Constructor for class org.apache.sysds.runtime.instructions.cp.CiphertextMatrix
 
CLALibAppend - Class in org.apache.sysds.runtime.compress.lib
 
CLALibAppend() - Constructor for class org.apache.sysds.runtime.compress.lib.CLALibAppend
 
CLALibBinaryCellOp - Class in org.apache.sysds.runtime.compress.lib
 
CLALibBinaryCellOp() - Constructor for class org.apache.sysds.runtime.compress.lib.CLALibBinaryCellOp
 
CLALibCMOps - Class in org.apache.sysds.runtime.compress.lib
 
CLALibCMOps() - Constructor for class org.apache.sysds.runtime.compress.lib.CLALibCMOps
 
CLALibCombine - Class in org.apache.sysds.runtime.compress.lib
 
CLALibCombine() - Constructor for class org.apache.sysds.runtime.compress.lib.CLALibCombine
 
CLALibCompAgg - Class in org.apache.sysds.runtime.compress.lib
 
CLALibCompAgg() - Constructor for class org.apache.sysds.runtime.compress.lib.CLALibCompAgg
 
CLALibDecompress - Class in org.apache.sysds.runtime.compress.lib
Library to decompress a list of column groups into a matrix.
CLALibDecompress() - Constructor for class org.apache.sysds.runtime.compress.lib.CLALibDecompress
 
CLALibLeftMultBy - Class in org.apache.sysds.runtime.compress.lib
 
CLALibLeftMultBy() - Constructor for class org.apache.sysds.runtime.compress.lib.CLALibLeftMultBy
 
CLALibMatrixMult - Class in org.apache.sysds.runtime.compress.lib
 
CLALibMatrixMult() - Constructor for class org.apache.sysds.runtime.compress.lib.CLALibMatrixMult
 
CLALibMMChain - Interface in org.apache.sysds.runtime.compress.lib
 
CLALibRexpand - Class in org.apache.sysds.runtime.compress.lib
 
CLALibRexpand() - Constructor for class org.apache.sysds.runtime.compress.lib.CLALibRexpand
 
CLALibRightMultBy - Class in org.apache.sysds.runtime.compress.lib
 
CLALibRightMultBy() - Constructor for class org.apache.sysds.runtime.compress.lib.CLALibRightMultBy
 
CLALibScalar - Class in org.apache.sysds.runtime.compress.lib
 
CLALibScalar() - Constructor for class org.apache.sysds.runtime.compress.lib.CLALibScalar
 
CLALibSlice - Class in org.apache.sysds.runtime.compress.lib
 
CLALibSlice() - Constructor for class org.apache.sysds.runtime.compress.lib.CLALibSlice
 
CLALibSquash - Class in org.apache.sysds.runtime.compress.lib
 
CLALibSquash() - Constructor for class org.apache.sysds.runtime.compress.lib.CLALibSquash
 
CLALibTSMM - Class in org.apache.sysds.runtime.compress.lib
 
CLALibTSMM() - Constructor for class org.apache.sysds.runtime.compress.lib.CLALibTSMM
 
CLALibUnary - Class in org.apache.sysds.runtime.compress.lib
 
CLALibUnary() - Constructor for class org.apache.sysds.runtime.compress.lib.CLALibUnary
 
CLALibUtils - Class in org.apache.sysds.runtime.compress.lib
 
CLALibUtils() - Constructor for class org.apache.sysds.runtime.compress.lib.CLALibUtils
 
clean - Variable in class org.apache.sysds.api.DMLOptions
 
cleanup() - Static method in class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
 
cleanup() - Static method in class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
 
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, String) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
 
cleanupData(ExecutionContext, Data) - 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
 
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() - 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
 
clear() - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox.SmallestPriorityQueue
 
CLEAR - org.apache.sysds.runtime.controlprogram.federated.FederatedRequest.RequestType
 
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
Clears all checked constraints.
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(long) - Method in class org.apache.sysds.runtime.controlprogram.context.MatrixObjectFuture
 
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
 
clearGPUObject() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
 
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.
clearMap() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
 
clearMaps() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfo
 
clearMemEstimate() - Method in class org.apache.sysds.hops.Hop
 
clearMemory() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
Clears all memory used by this GPUContext.
clearMemory() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryManager
Clear the allocated GPU objects
clearNNZ() - Method in class org.apache.sysds.runtime.compress.estim.AComEst
Clear the pointer to the materialized list of nnz in columns
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
clearSoftReferenceToDecompressed() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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 that are not inside lineage cache
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
 
clearWorkGroup() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
 
clen - Variable in class org.apache.sysds.runtime.codegen.SpoofOperator.SideInput
 
clen - Variable in class org.apache.sysds.runtime.io.ReadProperties
 
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.dictionary.ADictionary
Returns a deep clone of the dictionary.
clone() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
clone() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
clone() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
clone() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
clone() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
clone() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AIterator
Copy the iterator with the current values.
clone() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
clone() - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
 
clone() - Method in class org.apache.sysds.runtime.controlprogram.Program
 
clone() - Method in class org.apache.sysds.runtime.frame.data.columns.ABooleanArray
 
clone() - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Overwrite of the java internal clone function for arrays, return a clone of underlying data that is mutable, (not immutable data.) Immutable data is dependent on the individual allocated arrays
clone() - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
clone() - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
clone() - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
clone() - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
clone() - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
clone() - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
clone() - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
clone() - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
clone() - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
clone() - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
 
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
 
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(boolean) - Method in class org.apache.sysds.runtime.controlprogram.Program
 
clone(int) - Method in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
 
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() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheMaintenanceService
 
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
 
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
 
CLOSED_INVALID - org.apache.sysds.hops.codegen.template.TemplateBase.CloseType
 
CLOSED_VALID - org.apache.sysds.hops.codegen.template.TemplateBase.CloseType
 
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
 
CM2 - org.apache.sysds.runtime.matrix.operators.CMOperator.AggregateOperationTypes
 
CM3 - org.apache.sysds.runtime.matrix.operators.CMOperator.AggregateOperationTypes
 
CM4 - org.apache.sysds.runtime.matrix.operators.CMOperator.AggregateOperationTypes
 
cmOperations(CMOperator) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
cmOperations(CMOperator) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
cmOperations(CMOperator, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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(ValueFunction, CMOperator.AggregateOperationTypes, int) - 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(CNodeData, String) - Constructor for class org.apache.sysds.hops.codegen.cplan.CNodeData
 
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
 
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
 
CoCodeBinPacking - Class in org.apache.sysds.runtime.compress.cocode
Column group partitioning with bin packing heuristic.
CoCodeGreedy - Class in org.apache.sysds.runtime.compress.cocode
 
CoCodeHybrid - Class in org.apache.sysds.runtime.compress.cocode
This cocode strategy starts combines the use of CoCodePriorityQue and CoCodeGreedy.
coCodePercentage - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
A Cocode parameter that differ in behavior based on compression method, in general it is a value that reflects aggressively likely coCoding is used.
CoCodePriorityQue - Class in org.apache.sysds.runtime.compress.cocode
Column group partitioning by number of distinct items estimated.
CoCoderFactory - Interface in org.apache.sysds.runtime.compress.cocode
 
CoCoderFactory.PartitionerType - Enum in org.apache.sysds.runtime.compress.cocode
The Valid coCoding techniques
CoCodeStatic - Class in org.apache.sysds.runtime.compress.cocode
Column group co coding with static distribution heuristic.
codegen() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
 
codegen(boolean, SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNode
 
codegen(boolean, SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeBinary
 
codegen(boolean, SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
 
codegen(boolean, SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeData
 
codegen(boolean, SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
 
codegen(boolean, SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeNary
 
codegen(boolean, SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeOuterProduct
 
codegen(boolean, SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
 
codegen(boolean, SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTernary
 
codegen(boolean, SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeUnary
 
CODEGEN - Static variable in class org.apache.sysds.conf.DMLConfig
 
CODEGEN_API - Static variable in class org.apache.sysds.conf.DMLConfig
 
CODEGEN_COMPILER - Static variable in class org.apache.sysds.conf.DMLConfig
 
CODEGEN_ENABLED - org.apache.sysds.conf.CompilerConfig.ConfigType
 
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
 
CodegenStatistics - Class in org.apache.sysds.utils.stats
 
CodegenStatistics() - Constructor for class org.apache.sysds.utils.stats.CodegenStatistics
 
CodegenUtils - Class in org.apache.sysds.runtime.codegen
 
CodegenUtils() - Constructor for class org.apache.sysds.runtime.codegen.CodegenUtils
 
CodeTemplate - Class in org.apache.sysds.hops.codegen.cplan
 
CodeTemplate() - Constructor for class org.apache.sysds.hops.codegen.cplan.CodeTemplate
 
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
 
Col - org.apache.sysds.common.Types.Direction
 
COL - org.apache.sysds.hops.fedplanner.FTypes.AlignType
 
COL - org.apache.sysds.hops.fedplanner.FTypes.FPartitioning
 
COL - org.apache.sysds.hops.fedplanner.FTypes.FType
 
COL_AGG - org.apache.sysds.runtime.codegen.SpoofCellwise.CellType
 
COL_AGG - org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
 
COL_AGG_B1 - org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
 
COL_AGG_B1_T - org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
 
COL_AGG_B1R - org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
 
COL_AGG_CONST - org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
 
COL_AGG_T - org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
 
COL_COUNT_DISTINCT - org.apache.sysds.common.Builtins
 
COL_COUNT_DISTINCT - org.apache.sysds.common.Types.AggOp
 
COL_T - org.apache.sysds.hops.fedplanner.FTypes.AlignType
 
COL_VECTOR - org.apache.sysds.lops.BinaryM.VectorType
 
COL_VECTOR_MATRIX - org.apache.sysds.runtime.matrix.data.LibMatrixBincell.BinaryAccessType
 
col2imOverSingleImage(int, MatrixBlock, DnnParameters) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNIm2Col
 
colContainsValue(int, double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
colEnd - Variable in class org.apache.sysds.runtime.util.IndexRange
 
ColGroupConst - Class in org.apache.sysds.runtime.compress.colgroup
 
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).
ColGroupDDCFOR - Class in org.apache.sysds.runtime.compress.colgroup
Class to encapsulate information about a column group that is encoded with dense dictionary encoding (DDC).
ColGroupDeltaDDC - Class in org.apache.sysds.runtime.compress.colgroup
Class to encapsulate information about a column group that is first delta encoded then encoded with dense dictionary encoding (DeltaDDC).
ColGroupDeltaDDC() - Constructor for class org.apache.sysds.runtime.compress.colgroup.ColGroupDeltaDDC
 
ColGroupEmpty - Class in org.apache.sysds.runtime.compress.colgroup
 
ColGroupEmpty(IColIndex) - Constructor for class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
Constructs an Constant Colum Group, that contains only one tuple, with the given value.
ColGroupFactory - Class in org.apache.sysds.runtime.compress.colgroup
Factory class for constructing ColGroups.
ColGroupIO - Interface in org.apache.sysds.runtime.compress.colgroup
IO for ColGroups, it enables read and write ColGroups
ColGroupLinearFunctional - Class in org.apache.sysds.runtime.compress.colgroup
 
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.
ColGroupSDC - Class in org.apache.sysds.runtime.compress.colgroup
Column group that sparsely encodes the dictionary values.
ColGroupSDCFOR - Class in org.apache.sysds.runtime.compress.colgroup
ColGroup for Patched Frame Of Reference.
ColGroupSDCSingle - Class in org.apache.sysds.runtime.compress.colgroup
Column group that sparsely encodes the dictionary values.
ColGroupSDCSingleZeros - Class in org.apache.sysds.runtime.compress.colgroup
Column group that sparsely encodes the dictionary values.
ColGroupSDCZeros - Class in org.apache.sysds.runtime.compress.colgroup
Column group that sparsely encodes the dictionary values.
ColGroupSizes - Interface in org.apache.sysds.runtime.compress.colgroup
 
ColGroupUncompressed - Class in org.apache.sysds.runtime.compress.colgroup
Column group type for columns that are stored as dense arrays of doubles.
ColGroupUtils - Interface in org.apache.sysds.runtime.compress.colgroup
 
colInd - Variable in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
integer array of nnz values' column indices
ColIndexes - Class in org.apache.sysds.runtime.compress.cocode
 
ColIndexes(IColIndex) - Constructor for class org.apache.sysds.runtime.compress.cocode.ColIndexes
 
ColIndexFactory - Interface in org.apache.sysds.runtime.compress.colgroup.indexes
 
CollectionUtils - Class in org.apache.sysds.runtime.util
 
CollectionUtils() - Constructor for class org.apache.sysds.runtime.util.CollectionUtils
 
collectSparkRoots(Lop, Map<Long, Integer>, List<Lop>) - Static method in class org.apache.sysds.lops.OperatorOrderingUtils
 
colLower - Variable in class org.apache.sysds.parser.dml.DmlParser.IndexedExpressionContext
 
colMax() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Wrapper method for reduceall-colMin of a matrix.
COLMAX - org.apache.sysds.common.Builtins
 
COLMEAN - org.apache.sysds.common.Builtins
 
colMin() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Wrapper method for reduceall-colMin of a matrix.
COLMIN - org.apache.sysds.common.Builtins
 
COLNAMES - org.apache.sysds.common.Builtins
 
COLNAMES - org.apache.sysds.common.Types.OpOp1
 
COLPROD - org.apache.sysds.common.Builtins
 
colProduct(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Calculate the column product of the dictionary weighted by counts.
colProduct(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
colProduct(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
colProduct(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
colProduct(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
colProduct(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
colProductWithReference(double[], int[], IColIndex, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Calculate the column product of the dictionary weighted by counts.
colProductWithReference(double[], int[], IColIndex, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
colProductWithReference(double[], int[], IColIndex, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
colProductWithReference(double[], int[], IColIndex, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
colProductWithReference(double[], int[], IColIndex, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
COLSD - org.apache.sysds.common.Builtins
 
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
 
colSum() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
colSum() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Wrapper method for single threaded reduceall-colSum of a matrix.
colSum(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Get the column sum of the values contained in the dictionary
colSum(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
colSum(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
colSum(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
colSum(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
colSum(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
colSum(Collection<AColGroup>, double[], int) - Static method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Compute the column sum of the given list of groups
COLSUM - org.apache.sysds.common.Builtins
 
colSumSq(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Get the column sum of the values contained in the dictionary
colSumSq(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
colSumSq(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
colSumSq(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
colSumSq(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
colSumSq(double[], int[], IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
colSumSqWithReference(double[], int[], IColIndex, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Get the column sum of the values contained in the dictionary with an offset reference value added to each cell.
colSumSqWithReference(double[], int[], IColIndex, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
colSumSqWithReference(double[], int[], IColIndex, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
colSumSqWithReference(double[], int[], IColIndex, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
colSumSqWithReference(double[], int[], IColIndex, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
column - Variable in class org.apache.sysds.runtime.matrix.data.MatrixValue.CellIndex
 
COLUMN_BLOCK_WISE - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PDataPartitionFormat
 
COLUMN_BLOCK_WISE_N - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PDataPartitionFormat
 
COLUMN_DIMS_COLS - org.apache.sysds.hops.codegen.SpoofFusedOp.SpoofOutputDimsType
 
COLUMN_DIMS_ROWS - org.apache.sysds.hops.codegen.SpoofFusedOp.SpoofOutputDimsType
 
COLUMN_RANK_DIMS - org.apache.sysds.hops.codegen.SpoofFusedOp.SpoofOutputDimsType
 
COLUMN_RANK_DIMS_T - org.apache.sysds.hops.codegen.SpoofFusedOp.SpoofOutputDimsType
 
COLUMN_WISE - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PDataPartitionFormat
 
COLUMN_WISE - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
 
COLUMNBLOCKCOUNTPARAM - Static variable in class org.apache.sysds.parser.DataExpression
 
ColumnEncoder - 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.
ColumnEncoder.EncoderType - Enum in org.apache.sysds.runtime.transform.encode
 
ColumnEncoderBin - Class in org.apache.sysds.runtime.transform.encode
 
ColumnEncoderBin() - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
ColumnEncoderBin(int, int, double[], double[]) - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
ColumnEncoderBin(int, int, ColumnEncoderBin.BinMethod) - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
ColumnEncoderBin.BinMethod - Enum in org.apache.sysds.runtime.transform.encode
 
ColumnEncoderComposite - Class in org.apache.sysds.runtime.transform.encode
Simple composite encoder that applies a list of encoders in specified order.
ColumnEncoderComposite() - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
ColumnEncoderComposite(List<ColumnEncoder>) - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
ColumnEncoderComposite(List<ColumnEncoder>, FrameBlock) - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
ColumnEncoderComposite(ColumnEncoder) - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
ColumnEncoderDummycode - Class in org.apache.sysds.runtime.transform.encode
 
ColumnEncoderDummycode() - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
ColumnEncoderDummycode(int) - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
ColumnEncoderDummycode(int, int) - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
ColumnEncoderFeatureHash - Class in org.apache.sysds.runtime.transform.encode
Class used for feature hashing transformation of frames.
ColumnEncoderFeatureHash() - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderFeatureHash
 
ColumnEncoderFeatureHash(int, long) - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderFeatureHash
 
ColumnEncoderFeatureHash.FeatureHashSparseApplyTask - Class in org.apache.sysds.runtime.transform.encode
 
ColumnEncoderPassThrough - Class in org.apache.sysds.runtime.transform.encode
 
ColumnEncoderPassThrough() - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderPassThrough
 
ColumnEncoderPassThrough.PassThroughSparseApplyTask - Class in org.apache.sysds.runtime.transform.encode
 
ColumnEncoderRecode - Class in org.apache.sysds.runtime.transform.encode
 
ColumnEncoderRecode() - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
ColumnEncoderRecode(int) - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
ColumnEncoderUDF - Class in org.apache.sysds.runtime.transform.encode
 
ColumnEncoderUDF() - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderUDF
 
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 - Class in org.apache.sysds.runtime.frame.data.columns
 
ColumnMetadata() - Constructor for class org.apache.sysds.runtime.frame.data.columns.ColumnMetadata
Default constructor
ColumnMetadata(long) - Constructor for class org.apache.sysds.runtime.frame.data.columns.ColumnMetadata
 
ColumnMetadata(long, String) - Constructor for class org.apache.sysds.runtime.frame.data.columns.ColumnMetadata
 
ColumnMetadata(ColumnMetadata) - Constructor for class org.apache.sysds.runtime.frame.data.columns.ColumnMetadata
 
columnPartitioner - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
The selected method for column partitioning used in CoCoding compressed columns
columnStringToCSVString(String, String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
colUpper - Variable in class org.apache.sysds.parser.dml.DmlParser.IndexedExpressionContext
 
COLVAR - org.apache.sysds.common.Builtins
 
combine(int[], int[]) - Static method in interface org.apache.sysds.runtime.compress.utils.Util
 
combine(List<AColGroup>) - Static method in interface org.apache.sysds.runtime.compress.colgroup.indexes.ColIndexFactory
 
combine(Map<MatrixIndexes, MatrixBlock>, int) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibCombine
 
combine(Map<MatrixIndexes, MatrixBlock>, int, int, int, int) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibCombine
 
combine(IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.ArrayIndex
 
combine(IColIndex) - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex
combine the indexes of this colIndex with another, it is expected that all calls to this contains unique indexes, and no copies of values.
combine(IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.RangeIndex
 
combine(IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.SingleIndex
 
combine(IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.TwoIndex
 
combine(IColIndex, CompressedSizeInfoColGroup, CompressedSizeInfoColGroup) - Method in class org.apache.sysds.runtime.compress.estim.AComEst
Combine two analyzed column groups together.
combine(CompressedSizeInfoColGroup, CompressedSizeInfoColGroup) - Method in class org.apache.sysds.runtime.compress.estim.AComEst
combine two analyzed column groups together.
combine(IEncode) - Method in class org.apache.sysds.runtime.compress.estim.encoding.ConstEncoding
 
combine(IEncode) - Method in class org.apache.sysds.runtime.compress.estim.encoding.DenseEncoding
 
combine(IEncode) - Method in class org.apache.sysds.runtime.compress.estim.encoding.EmptyEncoding
 
combine(IEncode) - Method in interface org.apache.sysds.runtime.compress.estim.encoding.IEncode
Combine two encodings, note it should be guaranteed by the caller that the number of unique multiplied does not overflow Integer.
combine(IEncode) - Method in class org.apache.sysds.runtime.compress.estim.encoding.SparseEncoding
 
CombineBinary - org.apache.sysds.lops.Lop.Type
 
combineConstColumns(CompressedMatrixBlock) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibUtils
Combine all column groups that are constant types, this include empty and const.
COMBINEDINPUT - Static variable in class org.apache.sysds.lops.GroupedAggregate
 
CombineTernary - org.apache.sysds.lops.Lop.Type
 
CombineUnary - org.apache.sysds.lops.Lop.Type
 
ComEstExact - Class in org.apache.sysds.runtime.compress.estim
Exact compressed size estimator (examines entire dataset).
ComEstExact(MatrixBlock, CompressionSettings) - Constructor for class org.apache.sysds.runtime.compress.estim.ComEstExact
 
ComEstFactory - Interface in org.apache.sysds.runtime.compress.estim
 
ComEstSample - Class in org.apache.sysds.runtime.compress.estim
Estimate compression size based on subsample of data.
ComEstSample(MatrixBlock, CompressionSettings, int, int) - Constructor for class org.apache.sysds.runtime.compress.estim.ComEstSample
CompressedSizeEstimatorSample, samples from the input data and estimates the size of the compressed matrix.
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
 
commutative - Variable in class org.apache.sysds.runtime.matrix.operators.BinaryOperator
 
compact() - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
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
 
compact(double) - Method in class org.apache.sysds.runtime.data.SparseRow
In-place compaction of values over eps away from zero; and shifts non-zero entries to the left if necessary.
compact(double) - Method in class org.apache.sysds.runtime.data.SparseRowScalar
 
compact(double) - Method in class org.apache.sysds.runtime.data.SparseRowVector
 
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
 
compactEmptyBlock() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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.frame.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(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.Equals
 
compare(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThan
 
compare(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThanEquals
 
compare(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.LessThan
 
compare(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.LessThanEquals
 
compare(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.NotEquals
 
compare(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.ValueComparisonFunction
 
compare(byte[], int, int, byte[], int, int) - 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(double[], double[]) - Static method in class org.apache.sysds.runtime.util.SortUtils
 
compare(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Equals
 
compare(double, double) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThan
 
compare(double, double) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThanEquals
 
compare(double, double) - Method in class org.apache.sysds.runtime.functionobjects.LessThan
 
compare(double, double) - Method in class org.apache.sysds.runtime.functionobjects.LessThanEquals
 
compare(double, double) - 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.Equals
 
compare(long, long) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThan
 
compare(long, long) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThanEquals
 
compare(long, long) - Method in class org.apache.sysds.runtime.functionobjects.LessThan
 
compare(long, long) - Method in class org.apache.sysds.runtime.functionobjects.LessThanEquals
 
compare(long, long) - Method in class org.apache.sysds.runtime.functionobjects.NotEquals
 
compare(long, long) - Method in class org.apache.sysds.runtime.functionobjects.ValueComparisonFunction
 
compare(String, String) - Method in class org.apache.sysds.runtime.functionobjects.Equals
 
compare(String, String) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThan
 
compare(String, String) - Method in class org.apache.sysds.runtime.functionobjects.GreaterThanEquals
 
compare(String, String) - Method in class org.apache.sysds.runtime.functionobjects.LessThan
 
compare(String, String) - Method in class org.apache.sysds.runtime.functionobjects.LessThanEquals
 
compare(String, String) - Method in class org.apache.sysds.runtime.functionobjects.NotEquals
 
compare(String, String) - Method in class org.apache.sysds.runtime.functionobjects.ValueComparisonFunction
 
compare(N, N) - Method in class org.apache.sysds.lops.compile.LopComparator
 
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(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) - 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(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(DoubleIntListHashMap.DIListEntry, DoubleIntListHashMap.DIListEntry) - Method in class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap.DIListEntry
 
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(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.matrix.data.MatrixIndexes
 
compare(TripleIndexes, TripleIndexes) - Method in class org.apache.sysds.runtime.matrix.data.TripleIndexes.Comparator
 
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(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(Object) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
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
 
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(CompressedWriteBlock) - Method in class org.apache.sysds.runtime.compress.io.CompressedWriteBlock
 
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(ValueTrimFormat) - Method in class org.apache.sysds.runtime.iogen.ValueTrimFormat
 
compareTo(MatrixCell) - 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(ColumnEncoder) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
compareTo(DependencyTask<?>) - Method in class org.apache.sysds.runtime.util.DependencyTask
 
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.
compile(SpoofCompiler.GeneratorAPI, String) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
 
compile(SpoofCompiler.GeneratorAPI, String) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
 
compile(SpoofCompiler.GeneratorAPI, String) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeOuterProduct
 
compile(SpoofCompiler.GeneratorAPI, String) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
 
compile(SpoofCompiler.GeneratorAPI, String) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
 
COMPILE_COST_BASED - org.apache.sysds.hops.fedplanner.FTypes.FederatedPlanner
 
COMPILE_FED_ALL - org.apache.sysds.hops.fedplanner.FTypes.FederatedPlanner
 
COMPILE_FED_HEURISTIC - org.apache.sysds.hops.fedplanner.FTypes.FederatedPlanner
 
compileClass(String, String) - Static method in class org.apache.sysds.runtime.codegen.CodegenUtils
 
COMPILERASSISTED_RW - Static variable in class org.apache.sysds.conf.DMLConfig
 
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 - org.apache.sysds.runtime.io.FileFormatPropertiesMM.MMField
 
COMPLEX_DATA_TYPES - Static variable in class org.apache.sysds.api.mlcontext.MLContextUtil
Complex data types supported by the MLContext API.
COMPONENTS - org.apache.sysds.common.Builtins
 
COMPONENTS_DELIM - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
 
Composite - org.apache.sysds.runtime.transform.encode.ColumnEncoder.EncoderType
 
compress(FrameBlock, int) - Static method in class org.apache.sysds.runtime.frame.data.lib.FrameLibCompress
 
compress(FrameBlock, int, WTreeRoot) - Static method in class org.apache.sysds.runtime.frame.data.lib.FrameLibCompress
 
compress(MatrixBlock) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
Default sequential compression with no parallelization
compress(MatrixBlock, int) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
 
compress(MatrixBlock, int, CompressionSettingsBuilder) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
 
compress(MatrixBlock, int, CompressionSettingsBuilder, ACostEstimate) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
 
compress(MatrixBlock, int, CompressionSettingsBuilder, CostEstimatorBuilder) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
The main method for compressing the input matrix.
compress(MatrixBlock, int, CompressionSettingsBuilder, WTreeRoot) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
The main method for compressing the input matrix.
compress(MatrixBlock, int, ACostEstimate) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
 
compress(MatrixBlock, int, CostEstimatorBuilder) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
 
compress(MatrixBlock, int, InstructionTypeCounter) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
 
compress(MatrixBlock, int, WTreeRoot) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
 
compress(MatrixBlock, CompressionSettingsBuilder) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
 
compress(MatrixBlock, ACostEstimate) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
 
compress(MatrixBlock, CostEstimatorBuilder) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
 
compress(MatrixBlock, InstructionTypeCounter) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
 
compress(MatrixBlock, WTreeRoot) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
 
COMPRESS - org.apache.sysds.common.Builtins
 
COMPRESS - org.apache.sysds.common.Types.OpOp1
 
compressAsync(ExecutionContext, String) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
 
compressAsync(ExecutionContext, String, InstructionTypeCounter) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
 
compressColGroups(MatrixBlock, CompressedSizeInfo, CompressionSettings) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupFactory
The actual compression method, that handles the logic of compressing multiple columns together.
compressColGroups(MatrixBlock, CompressedSizeInfo, 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.
compressColGroups(MatrixBlock, CompressedSizeInfo, CompressionSettings, ACostEstimate, int) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupFactory
 
COMPRESSED - org.apache.sysds.common.Types.FileFormat
 
COMPRESSED_COCODE - Static variable in class org.apache.sysds.conf.DMLConfig
 
COMPRESSED_COST_MODEL - Static variable in class org.apache.sysds.conf.DMLConfig
 
COMPRESSED_LINALG - Static variable in class org.apache.sysds.conf.DMLConfig
 
COMPRESSED_LOSSY - Static variable in class org.apache.sysds.conf.DMLConfig
 
COMPRESSED_OVERLAPPING - Static variable in class org.apache.sysds.conf.DMLConfig
 
COMPRESSED_SAMPLING_RATIO - Static variable in class org.apache.sysds.conf.DMLConfig
 
COMPRESSED_SOFT_REFERENCE_COUNT - Static variable in class org.apache.sysds.conf.DMLConfig
 
COMPRESSED_TRANSFORMENCODE - Static variable in class org.apache.sysds.conf.DMLConfig
 
COMPRESSED_TRANSPOSE - Static variable in class org.apache.sysds.conf.DMLConfig
 
COMPRESSED_VALID_COMPRESSIONS - Static variable in class org.apache.sysds.conf.DMLConfig
 
compressedCost - Variable in class org.apache.sysds.runtime.compress.CompressionStatistics
Cost of the compressed representation
CompressedEncode - Class in org.apache.sysds.runtime.transform.encode
 
compressedInitialCost - Variable in class org.apache.sysds.runtime.compress.CompressionStatistics
Compressed cost after compression but before finalize
compressedInitialSize - Variable in class org.apache.sysds.runtime.compress.CompressionStatistics
Compression size after compressing but before finalize
CompressedInputOutputInfo - Static variable in class org.apache.sysds.runtime.io.InputOutputInfo
 
CompressedMatrixBlock - Class in org.apache.sysds.runtime.compress
 
CompressedMatrixBlock() - Constructor for class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
CompressedMatrixBlock(int, int) - Constructor for class org.apache.sysds.runtime.compress.CompressedMatrixBlock
Main constructor for building a block from scratch.
CompressedMatrixBlock(int, int, long, boolean, List<AColGroup>) - Constructor for class org.apache.sysds.runtime.compress.CompressedMatrixBlock
Direct constructor with everything.
CompressedMatrixBlock(CompressedMatrixBlock) - Constructor for class org.apache.sysds.runtime.compress.CompressedMatrixBlock
Copy constructor taking that CompressedMatrixBlock and populate this new compressedMatrixBlock with pointers to the same columnGroups.
CompressedMatrixBlockFactory - Class in org.apache.sysds.runtime.compress
Factory pattern to compress a Matrix Block into a CompressedMatrixBlock.
compressedSize - Variable in class org.apache.sysds.runtime.compress.CompressionStatistics
Compressed size
compressedSize() - Method in class org.apache.sysds.hops.Hop
 
CompressedSizeInfo - Class in org.apache.sysds.runtime.compress.estim
A helper reusable object for maintaining information about estimated compression
CompressedSizeInfo(List<CompressedSizeInfoColGroup>) - Constructor for class org.apache.sysds.runtime.compress.estim.CompressedSizeInfo
 
CompressedSizeInfo(CompressedSizeInfoColGroup) - 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(IColIndex, int) - Constructor for class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
Create empty.
CompressedSizeInfoColGroup(IColIndex, int, int, AColGroup.CompressionType) - Constructor for class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
 
CompressedSizeInfoColGroup(IColIndex, EstimationFactors, long, AColGroup.CompressionType) - Constructor for class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
 
CompressedSizeInfoColGroup(IColIndex, EstimationFactors, AColGroup.CompressionType) - Constructor for class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
 
CompressedWriteBlock - Class in org.apache.sysds.runtime.compress.io
Write block for serializing either a instance of MatrixBlock or CompressedMatrixBlock, To allow spark to read in either or.
CompressedWriteBlock() - Constructor for class org.apache.sysds.runtime.compress.io.CompressedWriteBlock
Write block used to point to a underlying instance of CompressedMatrixBlock or MatrixBlock, Unfortunately spark require a specific object type to serialize therefore we use this class.
CompressedWriteBlock(MatrixBlock) - Constructor for class org.apache.sysds.runtime.compress.io.CompressedWriteBlock
 
Compression - Class in org.apache.sysds.lops
 
Compression - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
Compression - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
Compression(Lop, Types.DataType, Types.ValueType, Types.ExecType, int) - 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
 
CompressionSPInstruction.CompressionWorkloadFunction - Class in org.apache.sysds.runtime.instructions.spark
 
CompressionSPInstruction.SizeFunction - Class in org.apache.sysds.runtime.instructions.spark
 
CompressionStatistics - Class in org.apache.sysds.runtime.compress
Compression Statistics contain the main information gathered from the compression, such as sizes of the original matrix, vs the compressed representation at different stages of the compression.
CompressionStatistics() - Constructor for class org.apache.sysds.runtime.compress.CompressionStatistics
 
CompressionWorkloadFunction(CostEstimatorBuilder) - Constructor for class org.apache.sysds.runtime.instructions.spark.CompressionSPInstruction.CompressionWorkloadFunction
 
compressRun(ExecutionContext, long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedWorkloadAnalyzer
 
CompressUnwrap - Class in org.apache.sysds.runtime.compress.io
 
CompressUnwrap() - Constructor for class org.apache.sysds.runtime.compress.io.CompressUnwrap
 
CompressWrap - Class in org.apache.sysds.runtime.compress.io
 
CompressWrap() - Constructor for class org.apache.sysds.runtime.compress.io.CompressWrap
 
ComputationCostEstimator - Class in org.apache.sysds.runtime.compress.cost
 
ComputationCostEstimator(int, int, int, int, int, int, int, int, boolean) - Constructor for class org.apache.sysds.runtime.compress.cost.ComputationCostEstimator
 
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
 
computeBins(double, double) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
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[], int) - Static method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBroadcast
 
computeBlocksPerPartition(long, long, long) - 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
 
computeCacheFullTime() - Static method in class org.apache.sysds.runtime.lineage.LineageEstimator
 
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.
computeColSums(double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Compute the column sum
computeColSums(double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupValue
 
computeColSums(double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
computeColSums(double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
computeColSums(double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
computeColSums(double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
computeColSums(double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
computeColSums(double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
computeColSums(double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
computeColSums(double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
computeCompressedSizeInfos(int) - Method in class org.apache.sysds.runtime.compress.estim.AComEst
Multi threaded version of extracting compression size info
ComputeCost - Class in org.apache.sysds.hops.cost
Class with methods estimating compute costs of operations.
ComputeCost() - Constructor for class org.apache.sysds.hops.cost.ComputeCost
 
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() - Method in class org.apache.sysds.parser.Identifier
 
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.
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(int, int, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.IndexFunction
 
computeDimension(int, int, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.OffsetColumnIndex
 
computeDimension(int, int, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.ReduceAll
 
computeDimension(int, int, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.ReduceCol
 
computeDimension(int, int, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.ReduceDiag
 
computeDimension(int, int, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.ReduceRow
 
computeDimension(int, int, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.RevIndex
 
computeDimension(int, int, MatrixValue.CellIndex) - 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.DiagIndex
 
computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.IndexFunction
 
computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.OffsetColumnIndex
 
computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.ReduceAll
 
computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.ReduceCol
 
computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.ReduceDiag
 
computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.ReduceRow
 
computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.RevIndex
 
computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.SortIndex
 
computeDimension(DataCharacteristics, DataCharacteristics) - Method in class org.apache.sysds.runtime.functionobjects.SwapIndex
 
computeHDF5Size(List<Path>, FileSystem, String) - Static method in class org.apache.sysds.runtime.io.ReaderHDF5
 
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.ReorgOp
 
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(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(int[], 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(String[], 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(SparseBlock, int[], int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
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
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
 
computeRCDMapSizeEstimate(CacheBlock<?>, int[]) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
computeRCDMapSizeEstimate(CacheBlock<?>, int[]) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
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, Types.ValueType, Types.ValueType, boolean) - Static method in class org.apache.sysds.parser.Expression
 
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.
computeZeroIndicatorVector() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
 
CONCAT - org.apache.sysds.common.Types.OpOp2
 
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
Concat the input parts with the value type delimiter.
concatOperands(String...) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
Concat the inputs as operands to generate the instruction string.
concatStrings(String...) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
 
CONCURRENTGPUEVICTION - Static variable in class org.apache.sysds.runtime.lineage.LineageCacheConfig
 
CONDITIONALAND - org.apache.sysds.parser.Expression.BooleanOp
 
CONDITIONALOR - org.apache.sysds.parser.Expression.BooleanOp
 
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
 
CONFUSIONMATRIX - org.apache.sysds.common.Builtins
 
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) - 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.
CONST - org.apache.sysds.runtime.compress.colgroup.AColGroup.CompressionType
 
CONSTANT - org.apache.sysds.hops.codegen.SpoofCompiler.PlanCachePolicy
 
CONSTANT - org.apache.sysds.runtime.transform.encode.EncoderMVImpute.MVMethod
 
Constants - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers
 
Constants - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories
 
Constants() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.Constants
 
Constants() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.Constants
 
ConstDoubleIdExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.ConstDoubleIdExpressionContext
 
ConstEncoding - Class in org.apache.sysds.runtime.compress.estim.encoding
Const encoding for cases where the entire group of columns is the same value
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
 
CONSTRAINED - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.POptMode
 
constructAndSetLopsDataFlowProperties() - Method in class org.apache.sysds.hops.Hop
 
constructBinaryInstString(String, String, CPOperand, CPOperand, CPOperand) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
 
constructCompilerConfig(CompilerConfig, DMLConfig) - Static method in class org.apache.sysds.hops.OptimizerUtils
 
constructCompilerConfig(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(Types.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
 
constructHopsNR(LineageItem, Map<Long, Hop>, Hop, ArrayList<String>) - Static method in class org.apache.sysds.runtime.util.AutoDiff
 
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.ColumnEncoderRecode
Returns the Recode map entry which consists of concatenation of code, delimiter and token.
constructSortByValueLop(Lop, Lop, SortKeys.OperationTypes, Types.DataType, Types.ValueType, Types.ExecType, int) - Static method in class org.apache.sysds.lops.SortKeys
 
constructSortByValueLop(Lop, SortKeys.OperationTypes, Types.DataType, Types.ValueType, Types.ExecType, int) - 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
 
constructTernaryString(String, CPOperand, CPOperand, CPOperand, CPOperand) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
 
constructUnaryInstString(String, String, CPOperand, CPOperand) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
 
ConstScheme - Class in org.apache.sysds.runtime.compress.colgroup.scheme
 
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(double) - Method in class org.apache.sysds.runtime.data.DenseBlock
Checks if the block contains at least one value of the given pattern.
contains(double) - Method in class org.apache.sysds.runtime.data.SparseBlock
Checks if the block contains at least one value of the given pattern.
contains(double) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
contains(long) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
 
contains(long[]) - Method in class org.apache.sysds.runtime.privacy.finegrained.DataRange
Returns true if the given index is in the data range.
contains(long, boolean, 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, TemplateBase.TemplateType) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
 
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(String) - Static method in enum org.apache.sysds.parser.BuiltinConstant
 
contains(String) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
contains(String, boolean, boolean) - Static method in enum org.apache.sysds.common.Builtins
 
contains(Collection<ParForStatementBlock.ResultVar>, String) - Static method in class org.apache.sysds.parser.ParForStatementBlock.ResultVar
 
contains(ColIndexes, ColIndexes) - Method in class org.apache.sysds.runtime.compress.cocode.ColIndexes
 
contains(IColIndex, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.AColIndex
 
contains(IColIndex, IColIndex) - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex
This contains method is not strict since it only verifies one element is contained from each a and b.
contains(CPOperand) - Method in class org.apache.sysds.runtime.lineage.Lineage
 
contains(CPOperand) - Method in class org.apache.sysds.runtime.lineage.LineageMap
 
contains(Data) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
CONTAINS - org.apache.sysds.common.Builtins
 
CONTAINS - org.apache.sysds.common.Types.ParamBuiltinOp
 
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
 
containsEncoderForID(int, Class<T>) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
containsFunCID(String, long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedLookupTable
Check if there is a mapped ExecutionContextMap for the coordinator with the given host and pid.
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, boolean) - Method in class org.apache.sysds.runtime.controlprogram.Program
 
containsFunctionProgramBlock(String, String) - Method in class org.apache.sysds.runtime.controlprogram.Program
 
containsFunctionProgramBlock(String, String, boolean) - Method in class org.apache.sysds.runtime.controlprogram.Program
 
containsFusedRowVecAgg(CNodeTpl) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
containsHop(Hop) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
 
containsHop(Hop) - Method in class org.apache.sysds.hops.fedplanner.MemoTable
Checks if root hop has been added to memo.
containsHopRel(HopRel) - Method in class org.apache.sysds.hops.fedplanner.MemoTable
Checks if given HopRel has been added to memo.
containsID() - Method in class org.apache.sysds.runtime.instructions.spark.data.DatasetObject
 
containsInfOrNan(double, double[]) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupUtils
 
containsInput(Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
containsKey(int) - Method in class org.apache.sysds.runtime.compress.SingletonLookupHashMap
 
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
 
containsNull() - Method in class org.apache.sysds.runtime.frame.data.columns.Array
analyze if the array contains null values.
containsNull() - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
containsNull() - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
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
 
containsRemoteParfor() - Method in class org.apache.sysds.parser.DMLProgram
 
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(ArrayList<Instruction>, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
 
containsSparkInstruction(BasicProgramBlock, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
 
containsStrict(IColIndex, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.AColIndex
 
containsStrict(IColIndex, IColIndex) - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex
This contains both a and b ...
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.compress.colgroup.AColGroup
Detect if the column group contains a specific value.
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Detect if the dictionary contains a specific value.
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
containsValue(double) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
containsValue(double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
containsValueWithReference(double, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Detect if the dictionary contains a specific value with reference offset.
containsValueWithReference(double, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
containsValueWithReference(double, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
containsValueWithReference(double, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
containsValueWithReference(double, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
containsVariable(String) - Method in class org.apache.sysds.parser.VariableSet
 
containsVariable(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
containsVariable(CPOperand) - 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.bitmap.ABitmap
Find out if the map contains zeros.
containsZero(double[], int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
containsZeros() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
 
containZerosTuples() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupOffset
 
CONTROL_PROGRAM - org.apache.sysds.runtime.instructions.Instruction.IType
 
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.
CONV2D - org.apache.sysds.common.Builtins
 
CONV2D - org.apache.sysds.common.Types.OpOpDnn
 
CONV2D_BACKWARD_DATA - org.apache.sysds.common.Builtins
 
CONV2D_BACKWARD_DATA - org.apache.sysds.common.Types.OpOpDnn
 
CONV2D_BACKWARD_FILTER - org.apache.sysds.common.Builtins
 
CONV2D_BACKWARD_FILTER - org.apache.sysds.common.Types.OpOpDnn
 
CONV2D_BIAS_ADD - org.apache.sysds.common.Types.OpOpDnn
 
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(long) - Static method in class org.apache.sysds.runtime.io.hdf5.H5BufferBuilder
 
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(MatrixIndexes, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.BinaryBlockToTextCellConverter
Before calling convert, please make sure to setBlockSize(blen, blen);
CONVERT_MCSR_TO_CSR_ON_DEEP_SERIALIZE - Static variable in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
CONVERT_NESTED_REMOTE_PARFOR - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
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, boolean, Types.ValueType) - 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
 
convertSciPyCOOToMB(byte[], byte[], byte[], int, int, int) - Static method in class org.apache.sysds.runtime.util.Py4jConverterUtils
 
convertStringToDoubleArray(String[]) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
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(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(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(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(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(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.
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(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.
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, int) - Static method in class org.apache.sysds.runtime.frame.data.lib.FrameFromMatrixBlock
 
convertToFrameBlock(MatrixBlock, int) - 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 value type given.
convertToFrameBlock(MatrixBlock, Types.ValueType[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
Converts a matrix block into a frame block of with the given schema
convertToFrameBlock(MatrixBlock, Types.ValueType[], int) - Static method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
convertToFrameBlock(MatrixBlock, Types.ValueType[], int) - Static method in class org.apache.sysds.runtime.frame.data.lib.FrameFromMatrixBlock
 
convertToFrameBlock(MatrixBlock, Types.ValueType[], int) - Static method in class org.apache.sysds.runtime.util.DataConverter
Converts a matrix block into a frame block of with the given schema
convertToFrameBlock(MatrixBlock, Types.ValueType, int) - Static method in class org.apache.sysds.runtime.frame.data.lib.FrameFromMatrixBlock
 
convertToFrameBlock(MatrixBlock, Types.ValueType, int) - Static method in class org.apache.sysds.runtime.util.DataConverter
Converts a matrix block into a frame block of a given value type.
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(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.
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(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.
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(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(int[][]) - Static method in class org.apache.sysds.runtime.util.DataConverter
Converts an Integer matrix to an MatrixBlock
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(RealMatrix) - Static method in class org.apache.sysds.runtime.util.DataConverter
 
convertToMatrixBlock(FrameBlock) - Static method in interface org.apache.sysds.runtime.frame.data.lib.MatrixBlockFromFrame
Converts a frame block with arbitrary schema into a matrix block.
convertToMatrixBlock(FrameBlock) - Static method in class org.apache.sysds.runtime.util.DataConverter
Converts a frame block with arbitrary schema into a matrix block.
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
convertToMatrixBlockPartitions(MatrixBlock, boolean) - Static method in class org.apache.sysds.runtime.util.DataConverter
 
convertToSparkCtx() - Method in class org.apache.sysds.runtime.controlprogram.federated.ExecutionContextMap
 
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(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(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(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
 
convertVectorToIndexList(MatrixBlock) - Static method in class org.apache.sysds.runtime.util.DataConverter
 
COO - org.apache.sysds.runtime.data.SparseBlock.Type
 
COORDINATE - org.apache.sysds.runtime.io.FileFormatPropertiesMM.MMFormat
 
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
 
CoordinatorConnectionModel - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.models
 
CoordinatorConnectionModel() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.CoordinatorConnectionModel
 
CoordinatorController - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers
 
CoordinatorController() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.CoordinatorController
 
coordinatorId - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.CoordinatorConnectionModel
 
CoordinatorModel - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.models
 
CoordinatorModel() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.CoordinatorModel
 
CoordinatorModel(Long) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.CoordinatorModel
 
CoordinatorModel(Long, String, String, Long) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.CoordinatorModel
 
CoordinatorService - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.services
 
CoordinatorService() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.CoordinatorService
 
coordinatorsTrafficBytes - Variable in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics.FedStatsCollection
 
copy() - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
copy() - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
copy(int[], int[], BasicTensorBlock) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
Copy a part of another BasicTensorBlock
copy(int[], int[], DataTensorBlock) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
Copy a part of another DataTensorBlock
copy(int[], int[], TensorBlock) - Method in class org.apache.sysds.runtime.data.TensorBlock
Copy a part of another TensorBlock
copy(int, int, int, int, FrameBlock) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
Copy src matrix into the index range of the existing current matrix.
copy(int, int, int, int, MatrixBlock, boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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(AMapToData) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Copy the values in this map into another mapping object.
copy(AMapToData) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
copy(BasicTensorBlock) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
 
copy(DataTensorBlock) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
 
copy(SparseRow) - Method in class org.apache.sysds.runtime.data.SparseRowVector
 
copy(TensorBlock) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
copy(FrameBlock) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
copy(MatrixValue) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
copy(MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
 
copy(MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
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 that MatrixValue into this 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
 
copy(MatrixValue, boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
copy(MatrixValue, boolean) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
 
copy(MatrixValue, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
copy(MatrixValue, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
copy(MatrixValue, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
Copy that MatrixValue into this MatrixValue.
COPY - org.apache.sysds.runtime.controlprogram.caching.MatrixObject.UpdateType
 
COPY_EVAL_FUNCTIONS - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
copyAsStringToArray(String[], Object) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
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
 
copyBit(BitSet) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
 
copyBit(BitSet) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
copyBit(BitSet) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
copyBit(BitSet) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
copyBit(BitSet) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
copyBit(BitSet) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
copyBit(BitSet) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
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
 
copyInt(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
 
copyInt(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
copyInt(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
copyInt(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
copyInt(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
copyInt(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
copyInt(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
copyLineNumbers(Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
copyLineNumbers(MatrixObject, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
copyLineNumbers(MatrixBlock, 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
 
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, int, MatrixBlock, long, long, long) - 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, 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.compress.CompressedMatrixBlock
 
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
 
copyToHostCache(LineageCacheEntry, String, boolean) - Static method in class org.apache.sysds.runtime.lineage.LineageGPUCacheEviction
 
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.
copyValuesColGroupMatrixBlocks(AColGroup, AColGroup, MatrixBlock, MatrixBlock) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupUtils
Copy values from tmpResult into correct positions of result (according to colIndexes in lhs and rhs)
CopyVariable - org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
 
copyWithNewID() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
Copy the federation map with the next available federated ID as reference to the federated data.
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(long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
Copy the federation map with the given ID as reference to the federated data.
copyWithNewID(long, long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
Copy the federation map with the given ID as reference to the federated data and with given clen as end dimension for the columns in the range.
copyWithNewIDAndRange(int[][], long, FTypes.FType) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
copyWithNewIDAndRange(long, long, long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
Copy federated mapping while giving the federated data new IDs and setting the ranges from zero to row and column ends specified.
copyWithNewIDAndRange(long, long, long, FTypes.FType) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
COR - org.apache.sysds.common.Builtins
 
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
 
correctionByte(int, int) - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory
 
correctionChar(int, int) - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory
 
CORRECTTYPOS - org.apache.sysds.common.Builtins
 
CORRECTTYPOSAPPLY - org.apache.sysds.common.Builtins
 
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
COS - org.apache.sysds.common.Builtins
 
COS - org.apache.sysds.common.Types.OpOp1
 
COS - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
COS - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
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
COSH - org.apache.sysds.common.Builtins
 
COSH - org.apache.sysds.common.Types.OpOp1
 
COSH - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
COSH - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
COST - org.apache.sysds.lops.Compression.CompressConfig
 
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
 
costComputationType - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
The cost computation type for the compression
costEstimate(HopRel, MemoTable) - Static method in class org.apache.sysds.hops.cost.FederatedCostEstimator
Return cost estimate in bytes of Hop DAG starting from given root HopRel.
costEstimate(Hop) - Method in class org.apache.sysds.hops.cost.FederatedCostEstimator
Return cost estimate in bytes of Hop DAG starting from given root.
costEstimate(DMLProgram) - Method in class org.apache.sysds.hops.cost.FederatedCostEstimator
Estimate cost of given DML program in bytes.
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 - 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.hops.cost.CostEstimator
 
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
 
CostEstimatorBuilder - Class in org.apache.sysds.runtime.compress.cost
 
CostEstimatorBuilder(InstructionTypeCounter) - Constructor for class org.apache.sysds.runtime.compress.cost.CostEstimatorBuilder
 
CostEstimatorBuilder(WTreeRoot) - Constructor for class org.apache.sysds.runtime.compress.cost.CostEstimatorBuilder
 
CostEstimatorFactory - Interface in org.apache.sysds.runtime.compress.cost
Factory class for the construction of cost estimators for compression
CostEstimatorFactory.CostType - Enum in org.apache.sysds.runtime.compress.cost
 
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
 
COSTNSIZE - org.apache.sysds.runtime.lineage.LineageCacheConfig.LineageCachePolicy
 
count - Variable in class org.apache.sysds.runtime.compress.utils.DArrCounts
 
count - Variable in class org.apache.sysds.runtime.compress.utils.DCounts
 
count - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.HeavyHitterModel
 
count - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.RequestModel
 
COUNT - org.apache.sysds.runtime.matrix.operators.CMOperator.AggregateOperationTypes
 
COUNT - org.apache.sysds.runtime.matrix.operators.CountDistinctOperatorTypes
 
COUNT_DISTINCT - org.apache.sysds.common.Builtins
 
COUNT_DISTINCT - org.apache.sysds.common.Types.AggOp
 
COUNT_DISTINCT - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
COUNT_DISTINCT - org.apache.sysds.runtime.instructions.cp.AggregateUnaryCPInstruction.AUType
 
COUNT_DISTINCT_APPROX - org.apache.sysds.common.Builtins
 
COUNT_DISTINCT_APPROX - org.apache.sysds.common.Types.AggOp
 
COUNT_DISTINCT_APPROX - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
COUNT_DISTINCT_APPROX - org.apache.sysds.runtime.instructions.cp.AggregateUnaryCPInstruction.AUType
 
COUNT_DISTINCT_APPROX_COL - org.apache.sysds.common.Builtins
 
COUNT_DISTINCT_APPROX_COL - org.apache.sysds.common.Types.AggOp
 
COUNT_DISTINCT_APPROX_ROW - org.apache.sysds.common.Builtins
 
COUNT_DISTINCT_APPROX_ROW - org.apache.sysds.common.Types.AggOp
 
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
 
CountDistinctFunctionSketch - Class in org.apache.sysds.runtime.matrix.data.sketch.countdistinct
 
CountDistinctFunctionSketch(Operator) - Constructor for class org.apache.sysds.runtime.matrix.data.sketch.countdistinct.CountDistinctFunctionSketch
 
CountDistinctOperator - Class in org.apache.sysds.runtime.matrix.operators
 
CountDistinctOperator(AggregateUnaryCPInstruction.AUType, Types.Direction, IndexFunction) - Constructor for class org.apache.sysds.runtime.matrix.operators.CountDistinctOperator
 
CountDistinctOperator(CountDistinctOperatorTypes, Types.Direction, IndexFunction, Hash.HashType) - Constructor for class org.apache.sysds.runtime.matrix.operators.CountDistinctOperator
 
CountDistinctOperatorTypes - Enum in org.apache.sysds.runtime.matrix.operators
 
CountDistinctSketch - Class in org.apache.sysds.runtime.matrix.data.sketch
 
CountDistinctSketch(Operator) - Constructor for class org.apache.sysds.runtime.matrix.data.sketch.CountDistinctSketch
 
countDistinctValuesFromSketch(CountDistinctOperator, CorrMatrixBlock) - Static method in interface org.apache.sysds.runtime.matrix.data.LibMatrixCountDistinct
 
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.
countNNZColumns(MatrixBlock, int, ExecutorService) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
 
countNNZColumnsFuture(MatrixBlock, int, ExecutorService) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
 
countNnzPerColumn(MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
 
countNnzPerColumn(MatrixBlock, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
 
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() - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
 
countNonZeros() - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
 
countNonZeros(double[], int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
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) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
 
countNonZeros(int) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
 
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(int, int, int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
 
countNonZeros(int, int, int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
 
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
 
countRuns() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Count the number of runs inside the map.
countRuns() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
countRuns() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
countRuns() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
countRuns() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
countRuns() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
countRuns() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
countRuns(AOffset) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Count the number of runs inside the map, but sparse with offsets.
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.
COV - org.apache.sysds.common.Builtins
 
COV - org.apache.sysds.common.Types.OpOp2
 
COV - org.apache.sysds.common.Types.OpOp3
 
Covariance - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
Covariance - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
Covariance - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
CoVariance - Class in org.apache.sysds.lops
Lop to compute covariance between two 1D matrices
CoVariance - org.apache.sysds.lops.Lop.Type
 
CoVariance(Lop, Lop, Types.DataType, Types.ValueType, int, Types.ExecType) - Constructor for class org.apache.sysds.lops.CoVariance
 
CoVariance(Lop, Lop, Lop, Types.DataType, Types.ValueType, int, Types.ExecType) - Constructor for class org.apache.sysds.lops.CoVariance
 
CovarianceCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
CovarianceFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
CovarianceSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
covOperations(COVOperator, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
covOperations(COVOperator, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
covOperations(COVOperator, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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
 
COVOperator(COV, int) - Constructor for class org.apache.sysds.runtime.matrix.operators.COVOperator
 
COX - org.apache.sysds.common.Builtins
 
CP - org.apache.sysds.common.Types.ExecType
 
CP - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.ExecType
 
CP_APPEND - org.apache.sysds.hops.BinaryOp.AppendMethod
 
CP_BINARY - org.apache.sysds.hops.BinaryOp.MMBinaryMethod
 
CP_CHILD_THREAD - Static variable in class org.apache.sysds.lops.Lop
 
CP_FILE - org.apache.sysds.common.Types.ExecType
 
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
 
CPMM - org.apache.sysds.hops.AggBinaryOp.MMultMethod
 
CPMM - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
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(String, Data) - Constructor for class org.apache.sysds.runtime.instructions.cp.CPOperand
 
CPOperand(CPOperand) - Constructor for class org.apache.sysds.runtime.instructions.cp.CPOperand
 
CPOperand(ScalarObject) - Constructor for class org.apache.sysds.runtime.instructions.cp.CPOperand
 
CPThreshold - Static variable in class org.apache.sysds.hops.Hop
 
cpuUsage - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.UtilizationModel
 
create() - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
Create the CompressionSettings object to use in the compression.
create() - Static method in class org.apache.sysds.runtime.compress.io.ReaderCompressed
 
create(boolean[]) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
create(char[]) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
create(double[]) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
Generate a constant column group.
create(double[]) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
create(double[]) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
create(float[]) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
create(int) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
create(int) - Static method in interface org.apache.sysds.runtime.compress.colgroup.indexes.ColIndexFactory
 
create(int[]) - Static method in interface org.apache.sysds.runtime.compress.colgroup.indexes.ColIndexFactory
 
create(int[]) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
create(int, boolean, IntArrayList[]) - Static method in interface org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory
 
create(int, double) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
Generate a constant column group.
create(int, int) - Static method in interface org.apache.sysds.runtime.compress.colgroup.indexes.ColIndexFactory
 
create(int, int) - Static method in interface org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory
Create and allocate a map with the given size and support for upto the num tuples argument of values
create(int, int[], int) - Static method in interface org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory
 
create(int, int, IntArrayList[], InsertionSorterFactory.SORT_TYPE) - Static method in interface org.apache.sysds.runtime.compress.colgroup.insertionsort.InsertionSorterFactory
 
create(int, ABitmap) - Static method in interface org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory
 
create(int, ADictionary) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
Generate a constant column group.
create(int, MapToFactory.MAP_TYPE) - Static method in interface org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory
 
create(int, IntArrayList[], InsertionSorterFactory.SORT_TYPE) - Static method in interface org.apache.sysds.runtime.compress.colgroup.insertionsort.InsertionSorterFactory
 
create(long[]) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
create(String[]) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
create(BitSet, int) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
create(ABitmap) - Static method in interface org.apache.sysds.runtime.compress.colgroup.dictionary.DictionaryFactory
 
create(ABitmap, double) - Static method in interface org.apache.sysds.runtime.compress.colgroup.dictionary.DictionaryFactory
 
create(ABitmap, double, boolean) - Static method in interface org.apache.sysds.runtime.compress.colgroup.dictionary.DictionaryFactory
 
create(ABitmap, int, double[], double, boolean) - Static method in interface org.apache.sysds.runtime.compress.colgroup.dictionary.DictionaryFactory
 
create(ColGroupConst) - Static method in class org.apache.sysds.runtime.compress.colgroup.scheme.ConstScheme
 
create(ColGroupDDC) - Static method in class org.apache.sysds.runtime.compress.colgroup.scheme.DDCScheme
Create a scheme for the DDC compression given
create(ColGroupEmpty) - Static method in class org.apache.sysds.runtime.compress.colgroup.scheme.EmptyScheme
 
create(IColIndex, double) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
Generate a constant column group.
create(IColIndex, double[]) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
Generate a constant column group.
create(IColIndex, double[], int) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
Generate a linear functional column group.
create(IColIndex, int, ADictionary, double[], AOffset, int[]) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
create(IColIndex, int, ADictionary, double[], AOffset, AMapToData, int[]) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
create(IColIndex, int, ADictionary, AOffset, int[]) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
create(IColIndex, int, ADictionary, AOffset, AMapToData, int[]) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
create(IColIndex, int, ADictionary, AOffset, AMapToData, int[], double[]) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
create(IColIndex, ADictionary, AMapToData, int[]) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
create(IColIndex, ADictionary, AMapToData, int[], double[]) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
create(IColIndex, MatrixBlock, boolean) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
Main constructor for Uncompressed ColGroup.
create(CompressionSettings, CostEstimatorBuilder, int, int, double) - Static method in interface org.apache.sysds.runtime.compress.cost.CostEstimatorFactory
Create a cost estimator to enable comparison of different suggested compression formats
create(DblArrayCountHashMap, int, boolean, double) - Static method in interface org.apache.sysds.runtime.compress.colgroup.dictionary.DictionaryFactory
 
create(DoubleCountHashMap) - Static method in interface org.apache.sysds.runtime.compress.colgroup.dictionary.DictionaryFactory
 
create(IntArrayList) - Static method in interface org.apache.sysds.runtime.compress.colgroup.indexes.ColIndexFactory
 
create(CoordinatorModel) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.CoordinatorService
 
create(WorkerModel) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.WorkerService
 
create(Request) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.CoordinatorController
 
create(Request) - Method in interface org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.IController
 
create(Request) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.StatisticsController
 
create(Request) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.WorkerController
 
create(ListObject, String, Statement.PSUpdateType, Statement.PSFrequency, ExecutionContext, int, String, int, MatrixObject, MatrixObject, int, boolean, int) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.LocalParamServer
 
create(ListObject, String, Statement.PSUpdateType, Statement.PSFrequency, ExecutionContext, int, String, int, MatrixObject, MatrixObject, int, int) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.HEParamServer
 
create(FileFormatProperties) - Static method in class org.apache.sysds.runtime.compress.io.WriterCompressed
 
create(MatrixBlock) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
create(MatrixBlock) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
create(MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinct.CountDistinctFunctionSketch
 
create(MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox.KMVSketch
 
create(MatrixBlock) - Method in interface org.apache.sysds.runtime.matrix.data.sketch.MatrixSketch
Create an initial sketch of a given block.
create(MatrixBlock, boolean) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
create(T[]) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
CREATE_UNSCOPED_RESULTVARS - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
createAbstractOptNodes(ArrayList<Hop>, LocalVariableMap, OptTreePlanMappingAbstract, Set<String>) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
 
createAbstractOptTree(int, double, ParForStatementBlock, ParForProgramBlock, OptTreePlanMappingAbstract, 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.frame.data.FrameBlock
 
createColNames(int) - Static method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
createColNames(int, int) - Static method in class org.apache.sysds.runtime.frame.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
 
createConstant(int, int, double) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
Method for constructing a compressed matrix out of an constant input.
createContext() - 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
 
createContext(boolean, boolean, Program, Types.ExecMode) - 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(Types.ExecMode) - 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(Program) - Static method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContextFactory
 
createCUDAInstrcution(Integer, SpoofCUDAOperator.PrecisionProxy) - Method in class org.apache.sysds.runtime.codegen.SpoofCellwise
 
createCUDAInstrcution(Integer, SpoofCUDAOperator.PrecisionProxy) - Method in class org.apache.sysds.runtime.codegen.SpoofMultiAggregate
 
createCUDAInstrcution(Integer, SpoofCUDAOperator.PrecisionProxy) - Method in class org.apache.sysds.runtime.codegen.SpoofOperator
 
createCUDAInstrcution(Integer, SpoofCUDAOperator.PrecisionProxy) - Method in class org.apache.sysds.runtime.codegen.SpoofOuterProduct
 
createCUDAInstrcution(Integer, SpoofCUDAOperator.PrecisionProxy) - Method in class org.apache.sysds.runtime.codegen.SpoofRowwise
 
createCutVarName(boolean) - Static method in class org.apache.sysds.hops.rewrite.StatementBlockRewriteRule
 
createDataGenOp(Hop, boolean, Hop, boolean, double) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
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
 
createDataGenOpByVal(ArrayList<LiteralOp>, long, long) - 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
 
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
 
createDeepCopyFunctionProgramBlock(FunctionProgramBlock, Set<String>, Set<String>, long) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
 
createDeepCopyFunctionProgramBlock(FunctionProgramBlock, Set<String>, Set<String>, long, int, boolean) - 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(double[], 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[]) - 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(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(int, 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(String[], 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(Types.ValueType, 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
 
createDependencyList(List<? extends Callable<?>>, Map<Integer[], Integer[]>, List<List<? extends Callable<?>>>) - Static method in class org.apache.sysds.runtime.util.DependencyThreadPool
 
createDependencyTask(Callable<?>) - Static method in class org.apache.sysds.runtime.util.DependencyThreadPool
 
createDependencyTasks(List<? extends Callable<?>>, List<List<? extends Callable<?>>>) - Static method in class org.apache.sysds.runtime.util.DependencyThreadPool
 
createDictionary(double[], int, boolean) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
createDirIfNotExistOnHDFS(String, String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
createDirIfNotExistOnHDFS(Path) - 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.stats.SparkStatistics
 
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
 
createEntity(T) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.DerbyRepository
 
createEntity(T) - Method in interface org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.IRepository
 
createEstimator(MatrixBlock, CompressionSettings, int) - Static method in interface org.apache.sysds.runtime.compress.estim.ComEstFactory
Create an estimator for the input data with the given settings and parallelization degree.
createEstimator(MatrixBlock, CompressionSettings, int, int) - Static method in interface org.apache.sysds.runtime.compress.estim.ComEstFactory
Create an estimator for the input data with the given settings and parallelization degree.
createExecutionContext(ExecutionContext, LocalVariableMap, String, String, int) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
 
createExecutionContext(ExecutionContext, LocalVariableMap, String, String, int, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
 
createForStatementBlockCopy(ForStatementBlock, boolean) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
 
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
 
createFrameObject(DataCharacteristics) - 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
 
createFromMatrixBlock(MatrixBlock, boolean, int) - Static method in interface org.apache.sysds.runtime.compress.estim.encoding.EncodingFactory
Create encoding of a single specific column inside the matrix input.
createFromMatrixBlock(MatrixBlock, boolean, IColIndex) - Static method in interface org.apache.sysds.runtime.compress.estim.encoding.EncodingFactory
Encode a list of columns together from the input matrix, as if it is cocoded.
createFromMatrixBlockDelta(MatrixBlock, boolean, IColIndex) - Static method in interface org.apache.sysds.runtime.compress.estim.encoding.EncodingFactory
Encode a full delta representation of the matrix input taking all rows into account.
createFromMatrixBlockDelta(MatrixBlock, boolean, IColIndex, int) - Static method in interface org.apache.sysds.runtime.compress.estim.encoding.EncodingFactory
Encode a delta representation of the matrix input taking the first "sampleSize" rows into account.
createGlobalEncoderWithEquiHeight(ExecutionContext, FrameObject, String) - Method in class org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction
 
createGPUObject(MatrixObject) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
Instantiates a new GPUObject initialized with the given MatrixObject.
createHistogram(CacheableData<?>, int, double, double, int, int, boolean) - Method in class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction
 
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) - 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(int) - Static method in class org.apache.sysds.runtime.transform.decode.DecoderFactory
 
createInstance(int) - Static method in class org.apache.sysds.runtime.transform.encode.EncoderFactory
 
createInstance(Class<?>) - Static method in class org.apache.sysds.runtime.codegen.CodegenUtils
 
createInternalRepresentation(FrameBlock, DocumentRepresentation[]) - Method in class org.apache.sysds.runtime.transform.tokenize.builder.TokenizerBuilder
 
createInternalRepresentation(FrameBlock, DocumentRepresentation[], int, int) - Method in class org.apache.sysds.runtime.transform.tokenize.builder.TokenizerBuilder
 
createInternalRepresentation(FrameBlock, DocumentRepresentation[], int, int) - Method in class org.apache.sysds.runtime.transform.tokenize.builder.TokenizerBuilderNgram
 
createInternalRepresentation(FrameBlock, DocumentRepresentation[], int, int) - Method in class org.apache.sysds.runtime.transform.tokenize.builder.TokenizerBuilderWhitespaceSplit
 
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(Types.ValueType, String) - Static method in class org.apache.sysds.runtime.instructions.cp.ScalarObjectFactory
 
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
 
createLiteralOperand(String, Types.ValueType) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
 
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
 
CreateMatrixFromFrame(long, long, int) - Constructor for class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction.CreateMatrixFromFrame
 
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
 
createMatrixObject(DataCharacteristics) - 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
 
createNamespace(String) - Method in class org.apache.sysds.parser.DMLProgram
 
createNary(Types.OpOpN, Hop...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
createNegative(int, int, IntArrayList[], int, InsertionSorterFactory.SORT_TYPE) - Static method in interface org.apache.sysds.runtime.compress.colgroup.insertionsort.InsertionSorterFactory
 
createNegative(int, IntArrayList[], int, InsertionSorterFactory.SORT_TYPE) - Static method in interface org.apache.sysds.runtime.compress.colgroup.insertionsort.InsertionSorterFactory
 
createNoCheck(double[]) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
createOffset(int) - Static method in class org.apache.sysds.utils.Explain
 
createOffset(int[]) - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory
Main factory pattern creator for Offsets.
createOffset(int[], int, int) - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory
Create a Offset based on a subset of the indexes given.
createOffset(int[], int, int, OffsetFactory.OFF_TYPE) - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory
 
createOffset(int[], OffsetFactory.OFF_TYPE) - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory
try to create a specific type of offset.
createOffset(IntArrayList) - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory
Create the offsets based on our primitive IntArrayList.
createOffsetLop(Hop, boolean) - Static method in class org.apache.sysds.hops.Hop
 
createOperand(CPOperand) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
 
createOptNode(Instruction, LocalVariableMap, OptTreePlanMappingRuntime, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
 
createOptNodes(ArrayList<Instruction>, LocalVariableMap, OptTreePlanMappingRuntime, 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
 
createReader(MatrixBlock, IColIndex, boolean) - Static method in class org.apache.sysds.runtime.compress.readers.ReaderColumnSelection
 
createReader(MatrixBlock, IColIndex, boolean, int, int) - Static method in class org.apache.sysds.runtime.compress.readers.ReaderColumnSelection
 
createReference(int, double) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupUtils
 
createReorg(ArrayList<Hop>, Types.ReOrgOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
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
 
createReport() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.stat.StatisticMonitor
Creates a nested statistic report of all parfor and parworker instances.
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
 
createScalarLineageItem(LiteralOp) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
 
createScalarObject(String) - 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, Object) - Static method in class org.apache.sysds.runtime.instructions.cp.ScalarObjectFactory
 
createScalarObject(Types.ValueType, String) - 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
 
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
 
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
 
createSeqDataGenOp(Hop, Hop, Hop, Hop) - 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
 
createSketch(CountDistinctOperator, MatrixBlock) - Static method in interface org.apache.sysds.runtime.matrix.data.LibMatrixCountDistinct
 
createSparkExecutionContext() - Static method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContextFactory
 
createSparkPSProxy(SparkConf, int, LongAccumulator) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcFactory
 
createSparse(AMapToData, AOffset, int) - Static method in interface org.apache.sysds.runtime.compress.estim.encoding.EncodingFactory
 
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.RewriteRemoveForLoopEmptySequence
 
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
 
createSubBuffer(ByteBuffer, int) - Static method in class org.apache.sysds.runtime.io.hdf5.Utils
 
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() - 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.TaskPartitioner
Creates set of all tasks for given problem, but streams them directly into task queue.
createTasks(LocalTaskQueue<Task>) - Method in class org.apache.sysds.runtime.controlprogram.parfor.TaskPartitionerFactoring
 
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
 
createTokenizer(String, int) - Static method in class org.apache.sysds.runtime.transform.tokenize.TokenizerFactory
 
createTransientRead(String, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
createTransientRead(String, MatrixObject) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
createTransientRead(String, MatrixBlock) - 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
 
CreateVariable - org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
 
createVarname() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
 
createWhileStatementBlockCopy(WhileStatementBlock, boolean) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
 
createWithAppendedZeroTuple(ABitmap, double) - Static method in interface org.apache.sysds.runtime.compress.colgroup.dictionary.DictionaryFactory
 
createWorkGroup() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
 
createWorkingDirectory() - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
 
createWorkingDirectoryWithUUID(String) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
 
Creation - org.apache.sysds.runtime.lineage.LineageItem.LineageItemType
 
CriticalValue(double, int) - Constructor for class org.apache.sysds.runtime.compress.estim.sample.ShlosserJackknifeEstimator.CriticalValue
 
crossProduct(int, Long...) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntrySet
 
CSLH - org.apache.sysds.hops.codegen.SpoofCompiler.PlanCachePolicy
 
CSPLINE - org.apache.sysds.common.Builtins
 
CSPLINE_CG - org.apache.sysds.common.Builtins
 
CSPLINE_DS - org.apache.sysds.common.Builtins
 
CSR - org.apache.sysds.runtime.data.SparseBlock.Type
 
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.
CSV - org.apache.sysds.api.mlcontext.FrameFormat
Comma-separated value format (dense).
CSV - org.apache.sysds.api.mlcontext.MatrixFormat
Comma-separated value format (dense).
CSV - org.apache.sysds.common.Types.FileFormat
 
CSV_QUOTE_CHAR - Static variable in class org.apache.sysds.runtime.io.IOUtilFunctions
 
CSVInputOutputInfo - Static variable in class org.apache.sysds.runtime.io.InputOutputInfo
 
CSVReblock - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
CSVReblock - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
CSVReBlock - Class in org.apache.sysds.lops
Lop to convert CSV data into SystemDS data format
CSVReBlock - org.apache.sysds.lops.Lop.Type
 
CSVReBlock(Lop, int, Types.DataType, Types.ValueType, Types.ExecType) - Constructor for class org.apache.sysds.lops.CSVReBlock
 
CSVReblockSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
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, 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, boolean, String, boolean, double, Set<String>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
 
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
 
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 - org.apache.sysds.lops.Lop.Type
 
Ctable - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
Ctable - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
Ctable - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
Ctable(Lop[], Ctable.OperationTypes, Types.DataType, Types.ValueType, boolean, boolean, Types.ExecType) - Constructor for class org.apache.sysds.lops.Ctable
 
Ctable(Lop[], Ctable.OperationTypes, Types.DataType, Types.ValueType, Types.ExecType) - Constructor for class org.apache.sysds.lops.Ctable
 
CTable - Class in org.apache.sysds.runtime.functionobjects
 
CTABLE - org.apache.sysds.common.Types.OpOp3
 
CTABLE_EXPAND_SCALAR_WEIGHT - org.apache.sysds.lops.Ctable.OperationTypes
 
CTABLE_TRANSFORM - org.apache.sysds.lops.Ctable.OperationTypes
 
CTABLE_TRANSFORM_HISTOGRAM - org.apache.sysds.lops.Ctable.OperationTypes
 
CTABLE_TRANSFORM_SCALAR_WEIGHT - org.apache.sysds.lops.Ctable.OperationTypes
 
CTABLE_TRANSFORM_WEIGHTED_HISTOGRAM - org.apache.sysds.lops.Ctable.OperationTypes
 
Ctable.OperationTypes - Enum in org.apache.sysds.lops
 
CtableCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
CtableFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
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, double, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
ctableOperations(Operator, double, double, 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.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, double, double, 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.MatrixValue
 
ctableOperations(Operator, double, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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, MatrixValue, 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.MatrixValue
 
ctableOperations(Operator, MatrixIndexes, double, boolean, int, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
ctableOperations(Operator, MatrixIndexes, double, boolean, int, 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.MatrixBlock
Specific ctable case of ctable(seq(...),X), where X is the only matrix input.
ctableOperations(Operator, MatrixIndexes, double, boolean, int, 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.MatrixValue
 
ctableOperations(Operator, MatrixValue, double, boolean, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
ctableOperations(Operator, MatrixValue, double, boolean, 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.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, double, boolean, 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.MatrixValue
 
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.compress.CompressedMatrixBlock
 
ctableOperations(Operator, MatrixValue, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
 
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, MatrixValue, CTableMap, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
 
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)
ctableSeqOperations(MatrixValue, double, MatrixBlock, boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
ctableSeqOperations(MatrixValue, double, MatrixBlock, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
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
 
CUDA - org.apache.sysds.hops.codegen.SpoofCompiler.GeneratorAPI
 
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 - Static variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
 
CudaSupportFunctions - Interface in org.apache.sysds.runtime.matrix.data
DESIGN DOCUMENTATION FOR SUPPORTING LOWER PRECISION: 1.
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
 
CUMMAX - org.apache.sysds.common.Builtins
 
CUMMAX - org.apache.sysds.common.Types.OpOp1
 
CUMMAX - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
CUMMIN - org.apache.sysds.common.Builtins
 
CUMMIN - org.apache.sysds.common.Types.OpOp1
 
CUMMIN - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
CUMPROD - org.apache.sysds.common.Builtins
 
CUMPROD - org.apache.sysds.common.Types.OpOp1
 
CUMPROD - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
CUMSUM - org.apache.sysds.common.Builtins
 
CUMSUM - org.apache.sysds.common.Types.OpOp1
 
CUMSUM - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
CumsumAggregate - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
CumsumOffset - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
CumsumOffset - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
CUMSUMPROD - org.apache.sysds.common.Builtins
 
CUMSUMPROD - org.apache.sysds.common.Types.OpOp1
 
CUMSUMPROD - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
CumulativeAggregate - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
CumulativeAggregateSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
CumulativeOffsetBinary - Class in org.apache.sysds.lops
 
CumulativeOffsetBinary - org.apache.sysds.lops.Lop.Type
 
CumulativeOffsetBinary(Lop, Lop, Types.DataType, Types.ValueType, double, boolean, Types.AggOp, Types.ExecType) - Constructor for class org.apache.sysds.lops.CumulativeOffsetBinary
 
CumulativeOffsetBinary(Lop, Lop, Types.DataType, Types.ValueType, Types.AggOp, Types.ExecType) - Constructor for class org.apache.sysds.lops.CumulativeOffsetBinary
 
CumulativeOffsetFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
CumulativeOffsetSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
CumulativePartialAggregate - Class in org.apache.sysds.lops
 
CumulativePartialAggregate - org.apache.sysds.lops.Lop.Type
 
CumulativePartialAggregate(Lop, Types.DataType, Types.ValueType, Types.AggOp, Types.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
CumulativeSplitAggregate - org.apache.sysds.lops.Lop.Type
 
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.
customKernelSuffix - Static variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
 
CustomProperties - Class in org.apache.sysds.runtime.iogen
 
CustomProperties() - Constructor for class org.apache.sysds.runtime.iogen.CustomProperties
 
CustomProperties(CustomProperties.GRPattern, String, String, int) - Constructor for class org.apache.sysds.runtime.iogen.CustomProperties
 
CustomProperties(CustomProperties.GRPattern, String, HashSet<String>) - Constructor for class org.apache.sysds.runtime.iogen.CustomProperties
 
CustomProperties(CustomProperties.GRSymmetry, String, int, int) - Constructor for class org.apache.sysds.runtime.iogen.CustomProperties
 
CVLM - org.apache.sysds.common.Builtins
 
CYCLE_AVG - org.apache.sysds.parser.Statement.PSRuntimeBalancing
 
CYCLE_MAX - org.apache.sysds.parser.Statement.PSRuntimeBalancing
 
CYCLE_MIN - org.apache.sysds.parser.Statement.PSRuntimeBalancing
 

D

D2HCOPY - Static variable in class org.apache.sysds.runtime.lineage.LineageCacheConfig
 
D2HMAXBANDWIDTH - Static variable in class org.apache.sysds.runtime.lineage.LineageCacheConfig
 
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
 
DAG_LINEARIZATION - Static variable in class org.apache.sysds.conf.DMLConfig
 
DAGHEIGHT - org.apache.sysds.runtime.lineage.LineageCacheConfig.LineageCachePolicy
 
DArrayIListEntry(DblArray, IntArrayList) - Constructor for class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap.DArrayIListEntry
 
DArrCounts - Class in org.apache.sysds.runtime.compress.utils
 
DArrCounts(DblArray, int) - Constructor for class org.apache.sysds.runtime.compress.utils.DArrCounts
 
DASH - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
 
Data - Class in org.apache.sysds.lops
Lop to represent data objects.
Data - Class in org.apache.sysds.runtime.instructions.cp
 
Data - org.apache.sysds.lops.Lop.Type
 
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_FIELD_DELIM - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
 
DATA_LAYOUT_MESSAGE - Static variable in class org.apache.sysds.runtime.io.hdf5.H5Constants
 
DATA_PARTITION_COND - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.ParamType
 
DATA_PARTITION_COND_MEM - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.ParamType
 
DATA_PARTITION_FORMAT - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.ParamType
 
DATA_PARTITIONER - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.ParamType
 
DATA_PARTITIONER - Static variable in class org.apache.sysds.parser.ParForStatementBlock
 
DATA_SPACE_MESSAGE - Static variable in class org.apache.sysds.runtime.io.hdf5.H5Constants
 
DATA_TYPE_MESSAGE - Static variable in class org.apache.sysds.runtime.io.hdf5.H5Constants
 
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(ParserRuleContext, Expression.DataOp, HashMap<String, Expression>, String) - Constructor for class org.apache.sysds.parser.DataExpression
 
DataExpression(Expression.DataOp, HashMap<String, Expression>, ParseInfo) - 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, boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
 
dataFrameToBinaryBlock(JavaSparkContext, Dataset<Row>, DataCharacteristics, boolean, Pair<String[], Types.ValueType[]>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
 
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 - org.apache.sysds.lops.Lop.Type
 
DataGen(Types.OpOpDG, DataIdentifier, HashMap<String, Lop>, String, Types.DataType, Types.ValueType, Types.ExecType) - Constructor for class org.apache.sysds.lops.DataGen
Creates a new Rand-LOP.
DataGenCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
DataGenCPInstruction(Operator, Types.OpOpDG, CPOperand, CPOperand, CPOperand, String, String, String, String) - Constructor for class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
 
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) - Constructor for class org.apache.sysds.hops.DataGenOp
 
DataGenOp(Types.OpOpDG, DataIdentifier, HashMap<String, Hop>) - Constructor for class org.apache.sysds.hops.DataGenOp
Creates a new Rand HOP.
dataIdentifier - Variable in class org.apache.sysds.parser.dml.DmlParser.FunctionCallMultiAssignmentStatementContext
 
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() - 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.FunctionCallMultiAssignmentStatementContext
 
dataIdentifier(int) - Method in class org.apache.sysds.parser.dml.DmlParser.IfdefAssignmentStatementContext
 
DataIdentifier - Class in org.apache.sysds.parser
 
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(DataIdentifier) - Constructor for class org.apache.sysds.parser.DataIdentifier
 
DataIdentifierContext() - Constructor for class org.apache.sysds.parser.dml.DmlParser.DataIdentifierContext
 
DataIdentifierContext(ParserRuleContext, int) - 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
 
DataObjectModel - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.models
 
DataObjectModel() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.DataObjectModel
 
DataObjectModel(Long, String, String, String, Long) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.DataObjectModel
 
DataObjectModel(String, String, String, Long) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.DataObjectModel
 
dataObjects - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.StatisticsModel
 
dataObjects - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.StatisticsOptions
 
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, Types.OpOpData, Hop, HashMap<String, Hop>) - Constructor for class org.apache.sysds.hops.DataOp
WRITE operation for Matrix This constructor supports expression in parameters
DataOp(String, Types.DataType, Types.ValueType, Hop, Types.OpOpData, String) - Constructor for class org.apache.sysds.hops.DataOp
 
DataPartition - org.apache.sysds.lops.Lop.Type
 
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
 
DataPartitionFederatedScheme - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
 
DataPartitionFederatedScheme() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionFederatedScheme
 
DataPartitionFederatedScheme.BalanceMetrics - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
 
DataPartitionFederatedScheme.Result - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
 
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 CacheableData 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(double) - 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[], String[][]) - Constructor for class org.apache.sysds.runtime.data.DataTensorBlock
 
DataTensorBlock(Types.ValueType, int[]) - Constructor for class org.apache.sysds.runtime.data.DataTensorBlock
 
DataTensorBlock(BasicTensorBlock) - Constructor for class org.apache.sysds.runtime.data.DataTensorBlock
 
DataTensorBlock(DataTensorBlock) - Constructor for class org.apache.sysds.runtime.data.DataTensorBlock
 
dataType - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.DataObjectModel
 
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() - Constructor for class org.apache.sysds.parser.dml.DmlParser.DataTypeContext
 
DataTypeContext(ParserRuleContext, int) - Constructor for class org.apache.sysds.parser.dml.DmlParser.DataTypeContext
 
DATATYPEPARAM - Static variable in class org.apache.sysds.parser.DataExpression
 
dateFormat(long, String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
dateFormat(String, String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
dateFormat(String, String, String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
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
 
DblArrayCountHashMap - Class in org.apache.sysds.runtime.compress.utils
 
DblArrayCountHashMap(int, int) - Constructor for class org.apache.sysds.runtime.compress.utils.DblArrayCountHashMap
 
DblArrayIntListHashMap - Class in org.apache.sysds.runtime.compress.utils
 
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
 
DBSCAN - org.apache.sysds.common.Builtins
 
DBSCANAPPLY - org.apache.sysds.common.Builtins
 
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
 
DCounts - Class in org.apache.sysds.runtime.compress.utils
 
DCounts(double, int) - Constructor for class org.apache.sysds.runtime.compress.utils.DCounts
 
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
 
DDC - org.apache.sysds.runtime.compress.colgroup.AColGroup.CompressionType
 
DDCFOR - org.apache.sysds.runtime.compress.colgroup.AColGroup.CompressionType
 
DDCScheme - Class in org.apache.sysds.runtime.compress.colgroup.scheme
 
deactivatePrefetch() - Method in class org.apache.sysds.hops.Hop
 
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
 
DECISIONTREE - org.apache.sysds.common.Builtins
 
DECISIONTREEPREDICT - org.apache.sysds.common.Builtins
 
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() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
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.
DecoderComposite() - Constructor for class org.apache.sysds.runtime.transform.decode.DecoderComposite
 
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
 
DecoderFactory.DecoderType - Enum in org.apache.sysds.runtime.transform.decode
 
DecoderPassThrough - Class in org.apache.sysds.runtime.transform.decode
Simple atomic decoder for passing through numeric columns to the output.
DecoderPassThrough() - Constructor for class org.apache.sysds.runtime.transform.decode.DecoderPassThrough
 
DecoderRecode - Class in org.apache.sysds.runtime.transform.decode
Simple atomic decoder for recoded columns.
DecoderRecode() - Constructor for class org.apache.sysds.runtime.transform.decode.DecoderRecode
 
decompress() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
Decompress block into a MatrixBlock
decompress(int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
Decompress block into a MatrixBlock
decompress(CompressedMatrixBlock, int) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibDecompress
 
DECOMPRESS - org.apache.sysds.common.Builtins
 
DECOMPRESS - org.apache.sysds.common.Types.OpOp1
 
DeCompression - Class in org.apache.sysds.lops
 
DeCompression - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
DeCompression - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
DeCompression(Lop, Types.DataType, Types.ValueType, Types.ExecType) - Constructor for class org.apache.sysds.lops.DeCompression
 
DeCompression.CompressConfig - Enum in org.apache.sysds.lops
 
DeCompressionCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
DeCompressionFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.DeCompressionSPInstruction.DeCompressionFunction
 
DeCompressionSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
DeCompressionSPInstruction.DeCompressionFunction - Class in org.apache.sysds.runtime.instructions.spark
 
decompressTo(CompressedMatrixBlock, MatrixBlock, int, int, int) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibDecompress
 
decompressToDenseBlock(DenseBlock, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Decompress a range of rows into a dense block
decompressToDenseBlock(DenseBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Decompress into the DenseBlock.
decompressToDenseBlock(DenseBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ADictBasedColGroup
 
decompressToDenseBlock(DenseBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
decompressToDenseBlock(DenseBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
decompressToDenseBlock(DenseBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
decompressToDenseBlock(DenseBlock, int, int, int, int, AIterator) - Method in class org.apache.sysds.runtime.compress.colgroup.ASDCZero
 
decompressToDenseBlockDenseDictionary(DenseBlock, int, int, int, int, AIterator) - Method in class org.apache.sysds.runtime.compress.colgroup.ASDCZero
 
decompressToDenseBlockDenseDictionaryWithProvidedIterator(DenseBlock, int, int, int, int, double[], AIterator) - Method in class org.apache.sysds.runtime.compress.colgroup.ASDCZero
 
decompressToDenseBlockDenseDictionaryWithProvidedIterator(DenseBlock, int, int, int, int, double[], AIterator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
decompressToDenseBlockDenseDictionaryWithProvidedIterator(DenseBlock, int, int, int, int, double[], AIterator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
decompressToSparseBlock(SparseBlock, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Decompress a range of rows into a sparse block Note that this is using append, so the sparse column indexes need to be sorted afterwards.
decompressToSparseBlock(SparseBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Decompress into the SparseBlock.
decompressToSparseBlock(SparseBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ADictBasedColGroup
 
decompressToSparseBlock(SparseBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
decompressToSparseBlock(SparseBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
decompressToSparseBlock(SparseBlock, int, int, int, 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 - org.apache.sysds.runtime.lineage.LineageItem.LineageItemType
 
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.
DEEPWALK - org.apache.sysds.common.Builtins
 
DEFAULT - org.apache.sysds.runtime.instructions.cp.AggregateUnaryCPInstruction.AUType
 
DEFAULT_BATCH_SIZE - Static variable in class org.apache.sysds.runtime.instructions.cp.ParamservBuiltinCPInstruction
 
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_CP_OPCODE - Static variable in class org.apache.sysds.lops.Checkpoint
 
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_INITIALIZATION_TIMEOUT - Static variable in class org.apache.sysds.conf.DMLConfig
 
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_LIBSVM_INDEX_DELIM - Static variable in class org.apache.sysds.parser.DataExpression
 
DEFAULT_LOOP_REPETITIONS - Static variable in class org.apache.sysds.parser.StatementBlock
 
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_MEM_UTIL_FACTOR - Static variable in class org.apache.sysds.hops.OptimizerUtils
Default buffer pool sizes for static (15%) and unified (85%) memory
DEFAULT_MEMORY_ESTIMATE - Static variable in class org.apache.sysds.hops.cost.FederatedCostEstimator
 
DEFAULT_NA_STRINGS - Static variable in class org.apache.sysds.parser.DataExpression
 
DEFAULT_NAMESPACE - Static variable in class org.apache.sysds.parser.DMLProgram
 
DEFAULT_NBATCHES - Static variable in class org.apache.sysds.runtime.instructions.cp.ParamservBuiltinCPInstruction
 
DEFAULT_NUM_BACKUP_WORKERS - Static variable in class org.apache.sysds.runtime.instructions.cp.ParamservBuiltinCPInstruction
 
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_SCHEMAPARAM - Static variable in class org.apache.sysds.parser.DataExpression
 
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_UMM_UTIL_FACTOR - Static variable in class org.apache.sysds.hops.OptimizerUtils
 
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
 
defaultNullValue(Types.ValueType) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
defaultOptions - Static variable in class org.apache.sysds.api.DMLOptions
 
delete(Request, Long) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.CoordinatorController
 
delete(Request, Long) - Method in interface org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.IController
 
delete(Request, Long) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.StatisticsController
 
delete(Request, Long) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.WorkerController
 
deleteAll() - Method in class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
Removes all cache blocks from all memory areas and deletes all evicted representations (files in local FS).
deleteBlock(String) - Static method in class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
 
deleteBlock(String) - Static method in class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
 
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.
deleteFile(String) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheMaintenanceService
 
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) - Method in class org.apache.sysds.runtime.data.SparseRowVector
 
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
 
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
 
Delta - org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary.DictType
 
DeltaDDC - org.apache.sysds.runtime.compress.colgroup.AColGroup.CompressionType
 
DeltaDictionary - Class in org.apache.sysds.runtime.compress.colgroup.dictionary
This dictionary class is a specialization for the DeltaDDCColgroup.
DeltaDictionary(double[], int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.dictionary.DeltaDictionary
 
DENIALCONSTRAINTS - org.apache.sysds.common.Builtins
 
DENSE - org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator.DataFormat
 
DENSE_BLOCK - org.apache.sysds.common.Types.BlockType
 
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[], boolean[]) - Constructor for class org.apache.sysds.runtime.data.DenseBlockBool
 
DenseBlockBool(int[], BitSet) - 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.
DenseEncoding - Class in org.apache.sysds.runtime.compress.estim.encoding
 
DenseEncoding(AMapToData) - Constructor for class org.apache.sysds.runtime.compress.estim.encoding.DenseEncoding
 
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
 
denseSize - Variable in class org.apache.sysds.runtime.compress.CompressionStatistics
Size if the input is dense
denseToSparse() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
Converts this GPUObject from dense to sparse format.
denseToSparse(boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
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
 
DependencyTask<E> - Class in org.apache.sysds.runtime.util
 
DependencyTask(Callable<E>, List<DependencyTask<?>>) - Constructor for class org.apache.sysds.runtime.util.DependencyTask
 
DependencyThreadPool - Class in org.apache.sysds.runtime.util
 
DependencyThreadPool(int) - Constructor for class org.apache.sysds.runtime.util.DependencyThreadPool
 
DependencyWrapperTask<E> - Class in org.apache.sysds.runtime.util
 
DependencyWrapperTask(DependencyThreadPool) - Constructor for class org.apache.sysds.runtime.util.DependencyWrapperTask
 
DEPTH_FIRST - org.apache.sysds.lops.compile.linearization.ILinearize.DagLinearization
 
dequeueTask() - Method in class org.apache.sysds.runtime.controlprogram.parfor.LocalTaskQueue
Synchronized read and delete from the top of the FIFO queue.
DerbyRepository - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories
 
DerbyRepository() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.DerbyRepository
 
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
 
desanitizeSpaces(String) - Static method in class org.apache.sysds.runtime.transform.TfUtils
 
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(Map<String, String>) - Static method in class org.apache.sysds.runtime.lineage.Lineage
 
deserialize(MatrixBlock) - Method in class org.apache.sysds.runtime.io.BinaryBlockSerialization.MatrixBlockDeserializer
 
deserializeBlock() - Method in class org.apache.sysds.runtime.controlprogram.caching.ByteBuffer
 
deserializeSingleTrace(String) - Static method in class org.apache.sysds.runtime.lineage.Lineage
 
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(double, int) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
detectSchema(int) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
detectSchema(SparkExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.UnaryFrameSPInstruction
 
detectSchema(FrameBlock, double, int) - Static method in class org.apache.sysds.runtime.frame.data.lib.FrameLibDetectSchema
 
detectSchema(FrameBlock, int) - Static method in class org.apache.sysds.runtime.frame.data.lib.FrameLibDetectSchema
 
DETECTSCHEMA - org.apache.sysds.common.Builtins
 
DETECTSCHEMA - org.apache.sysds.common.Types.OpOp1
 
DETECTSCHEMA - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
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 - org.apache.sysds.api.mlcontext.FrameFormat
DataFrame without a row index.
DF_DOUBLES - org.apache.sysds.api.mlcontext.MatrixFormat
DataFrame of doubles with no row index.
DF_DOUBLES_WITH_INDEX - org.apache.sysds.api.mlcontext.MatrixFormat
DataFrame of doubles with a row index.
DF_ID_COLUMN - Static variable in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
 
DF_VECTOR - org.apache.sysds.api.mlcontext.MatrixFormat
Vector DataFrame with no row index.
DF_VECTOR_WITH_INDEX - org.apache.sysds.api.mlcontext.MatrixFormat
Vector DataFrame with a row index.
DF_WITH_INDEX - org.apache.sysds.api.mlcontext.FrameFormat
DataFrame with a row index.
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
 
DIAG - org.apache.sysds.common.Builtins
 
DIAG - org.apache.sysds.common.Types.ReOrgOp
 
DIAG - org.apache.sysds.hops.estim.SparsityEstimator.OpCode
 
DiagIndex - Class in org.apache.sysds.runtime.functionobjects
 
Dict - org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary.DictType
 
Dictionary - Class in org.apache.sysds.runtime.compress.colgroup.dictionary
This dictionary class aims to encapsulate the storage and operations over unique floating point values of a column group.
DictionaryFactory - Interface in org.apache.sysds.runtime.compress.colgroup.dictionary
 
DictionaryFactory.Type - Enum in org.apache.sysds.runtime.compress.colgroup.dictionary
 
DictLibMatrixMult - Class in org.apache.sysds.runtime.compress.colgroup.dictionary
Utility interface for dictionary matrix multiplication
DIGIT - Static variable in class org.apache.sysds.parser.dml.DmlLexer
 
DIGIT - Static variable in class org.apache.sysds.parser.dml.DmlParser
 
DIGIT - Static variable in class org.apache.sysds.runtime.util.DMVUtils
 
DIListEntry(double, IntArrayList) - Constructor for class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap.DIListEntry
 
dim() - Method in class org.apache.sysds.runtime.compress.workload.Op
 
dimsKnown() - 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() - 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.hops.Hop
 
dimsKnown(boolean) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
 
dimsKnown(boolean) - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
 
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.
disableUMM() - Static method in class org.apache.sysds.hops.OptimizerUtils
Disable unified memory manager and fallback to static partitioning.
DISCOVER_FD - org.apache.sysds.common.Builtins
 
DISCOVER_MD - org.apache.sysds.common.Builtins
 
DISJOINT_CONTIGUOUS - org.apache.sysds.parser.Statement.PSScheme
 
DISJOINT_RANDOM - org.apache.sysds.parser.Statement.PSScheme
 
DISJOINT_ROUND_ROBIN - org.apache.sysds.parser.Statement.PSScheme
 
display() - Static method in class org.apache.sysds.hops.fedplanner.FederatedCompilationTimer
 
display() - Static method in class org.apache.sysds.runtime.privacy.CheckedConstraintsLog
Get string representing all contents of the checked constraints log.
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
display(StringBuilder) - Static method in class org.apache.sysds.utils.DMLCompressionStatistics
 
display(DMLProgram, Program, Explain.ExplainType, Explain.ExplainCounts) - Static method in class org.apache.sysds.utils.Explain
 
displayComputeTime() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
displayComputeTime() - Static method in class org.apache.sysds.runtime.lineage.LineageEstimatorStatistics
 
displayFedIOExecStatistics() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
displayFedLookupTableStats() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
displayFedLookupTableStats(long, long, double) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
displayFedPutLineageStats() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
displayFedPutLineageStats(long, long) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
displayFedReuseReadStats() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
displayFedReuseReadStats(long, long) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
displayFedSerializationReuseStats() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
displayFedSerializationReuseStats(long, long) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
displayFedWorkers() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
displayFedWorkerStats() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
displayFloStatistics() - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
displayFSTime() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
displayGpuStats() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
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() - Method in class org.apache.sysds.api.mlcontext.Script
Display the script inputs.
displayInputs(String, Map<String, Object>, LocalVariableMap) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
Obtain a display of script inputs.
displayInputVariables() - Method in class org.apache.sysds.api.mlcontext.Script
Display the script input variables.
displayLineageEstimates() - Static method in class org.apache.sysds.runtime.lineage.LineageEstimatorStatistics
 
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
 
displayNetworkTrafficStatistics() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
displayOutputs() - Method in class org.apache.sysds.api.mlcontext.Script
Display the script outputs.
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.
displayOutputVariables() - Method in class org.apache.sysds.api.mlcontext.Script
Display the script output variables.
displayReusableInsts() - Static method in class org.apache.sysds.runtime.lineage.LineageEstimatorStatistics
 
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
displaySize() - Static method in class org.apache.sysds.runtime.lineage.LineageEstimatorStatistics
 
displaySparkStats() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
displayStatistics() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
displayStatistics() - Static method in class org.apache.sysds.utils.stats.NativeStatistics
 
displayStatistics() - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
displayStatistics() - Static method in class org.apache.sysds.utils.stats.ParForStatistics
 
displayStatistics() - Static method in class org.apache.sysds.utils.stats.RecompileStatistics
 
displayStatistics() - Static method in class org.apache.sysds.utils.stats.SparkStatistics
 
displayStatistics() - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
displayStatistics(int) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
displayStatistics(FederatedStatistics.FedStatsCollection, int) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
displaySymbolTable() - Method in class org.apache.sysds.api.mlcontext.Script
Display the script symbol table.
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
displayTime() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
 
displayWrites() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
 
displayWtrites() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
DIST - org.apache.sysds.common.Builtins
 
distFunc - Variable in class org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin
 
DISTINCT - org.apache.sysds.runtime.compress.cost.CostEstimatorFactory.CostType
 
DistinctCostEstimator - Class in org.apache.sysds.runtime.compress.cost
A Cost based estimator that based the compression and co-coding cost on the number of distinct elements in the column groups.
DistinctCostEstimator(int, CompressionSettings, double) - Constructor for class org.apache.sysds.runtime.compress.cost.DistinctCostEstimator
 
distinctCount(int[], int, int, SampleEstimatorFactory.EstimationType) - Static method in interface org.apache.sysds.runtime.compress.estim.sample.SampleEstimatorFactory
Estimate a distinct number of values based on frequencies.
distinctCount(int[], int, int, SampleEstimatorFactory.EstimationType, HashMap<Integer, Double>) - Static method in interface org.apache.sysds.runtime.compress.estim.sample.SampleEstimatorFactory
Estimate a distinct number of values based on frequencies.
distinctCount(int, int[], int[], int, int) - Static method in interface org.apache.sysds.runtime.compress.estim.sample.ShlosserJackknifeEstimator
Peter J.
distinctCount(int, int[], int, int) - Static method in interface org.apache.sysds.runtime.compress.estim.sample.SmoothedJackknifeEstimator
Peter J.
distinctCount(int, int[], int, int, HashMap<Integer, Double>) - Static method in interface org.apache.sysds.runtime.compress.estim.sample.HassAndStokes
Haas, Peter J., and Lynne Stokes.
distinctCount(long, int[], long, long) - Static method in interface org.apache.sysds.runtime.compress.estim.sample.ShlosserEstimator
Peter J.
DIV - org.apache.sysds.common.Types.OpOp2
 
DIV - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
DIV - org.apache.sysds.lops.WeightedUnaryMM.WUMMType
 
DIV - org.apache.sysds.parser.Expression.BinaryOp
 
DIV_LEFT - org.apache.sysds.lops.WeightedDivMM.WDivMMType
 
DIV_LEFT_EPS - org.apache.sysds.lops.WeightedDivMM.WDivMMType
 
DIV_RIGHT - org.apache.sysds.lops.WeightedDivMM.WDivMMType
 
DIV_RIGHT_EPS - org.apache.sysds.lops.WeightedDivMM.WDivMMType
 
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 - org.apache.sysds.hops.FunctionOp.FunctionType
 
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.compress
 
DMLCompressionException(String) - Constructor for exception org.apache.sysds.runtime.compress.DMLCompressionException
 
DMLCompressionException(String, Exception) - Constructor for exception org.apache.sysds.runtime.compress.DMLCompressionException
 
DMLCompressionStatistics - Class in org.apache.sysds.utils
 
DMLCompressionStatistics() - Constructor for class org.apache.sysds.utils.DMLCompressionStatistics
 
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(DMLConfig) - Constructor for class org.apache.sysds.conf.DMLConfig
 
DMLConfig(Element) - 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(String, Throwable) - Constructor for exception org.apache.sysds.api.DMLException
 
DMLException(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(Exception) - Constructor for exception org.apache.sysds.runtime.DMLRuntimeException
 
DMLRuntimeException(String) - 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
 
DMV - org.apache.sysds.common.Builtins
 
DMVUtils - Class in org.apache.sysds.runtime.util
 
DMVUtils() - Constructor for class org.apache.sysds.runtime.util.DMVUtils
 
DMVUtils.LEVEL_ENUM - Enum in org.apache.sysds.runtime.util
 
Dnn - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
Dnn - org.apache.sysds.runtime.instructions.gpu.GPUInstruction.GPUINSTRUCTION_TYPE
 
Dnn - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
DnnCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
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, 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, 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, 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, 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, CPOperand, CPOperand, String, String, 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
 
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
 
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(int, int, int, int, int, int, int, int, int, int, int, int) - Constructor for class org.apache.sysds.runtime.matrix.data.DnnParameters
 
DnnParameters(long, long, long, long, long, long, long, long, long, long, long, 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, Types.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, Types.ExecType, int) - Constructor for class org.apache.sysds.lops.DnnTransform
 
DnnTransform(Lop, Lop, Lop, Types.OpOpDnn, Types.DataType, Types.ValueType, Types.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
 
DocumentRepresentation - Class in org.apache.sysds.runtime.transform.tokenize
 
DocumentRepresentation(List<Object>, List<Token>) - Constructor for class org.apache.sysds.runtime.transform.tokenize.DocumentRepresentation
 
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.
DONE - org.apache.sysds.lops.Lop.VisitStatus
 
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, int, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionSparkScheme
 
doPartitioning(int, int, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DCSparkScheme
 
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, int, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.ORSparkScheme
 
doPartitioning(int, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionLocalScheme
 
doPartitioning(int, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DCLocalScheme
 
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, 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, MatrixBlock, MatrixBlock, long) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.SparkDataPartitioner
 
doPartitioning(MatrixObject, MatrixObject) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.FederatedDataPartitioner
 
doPartitionOnSpark(SparkExecutionContext, MatrixObject, MatrixObject, Statement.PSScheme, int) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.SparkParamservUtils
 
DOT - Static variable in class org.apache.sysds.runtime.util.DMVUtils
 
DOT_PRODUCT - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
dotProduct(double[], double[], int[], 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.matrix.data.LibMatrixMult
 
dotProduct(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
 
dotProduct(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
 
dotSplitPattern - Static variable in interface org.apache.sysds.runtime.frame.data.lib.FrameUtil
 
DOUBLE - Static variable in class org.apache.sysds.parser.dml.DmlLexer
 
DOUBLE - Static variable in class org.apache.sysds.parser.dml.DmlParser
 
DOUBLE() - Method in class org.apache.sysds.parser.dml.DmlParser.ConstDoubleIdExpressionContext
 
DOUBLE_EPS - Static variable in class org.apache.sysds.runtime.util.UtilFunctions
 
double_exponential_smoothing(Double[], Double, Double) - Static method in class org.apache.sysds.runtime.util.EMAUtils
 
DOUBLE_SIZE - Static variable in class org.apache.sysds.hops.OptimizerUtils
 
DOUBLE_VALUE_TYPE - Static variable in class org.apache.sysds.parser.Statement
 
double2float(GPUContext, Pointer, Pointer, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
 
DoubleArray - Class in org.apache.sysds.runtime.frame.data.columns
 
DoubleArray(double[]) - Constructor for class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
doubleArrayCost(long) - Static method in class org.apache.sysds.utils.MemoryEstimates
Get the worst case memory usage of an array of doubles.
DoubleCountHashMap - Class in org.apache.sysds.runtime.compress.utils
 
DoubleCountHashMap(int) - Constructor for class org.apache.sysds.runtime.compress.utils.DoubleCountHashMap
 
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(ParserRuleContext, double, String) - Constructor for class org.apache.sysds.parser.DoubleIdentifier
 
DoubleIdentifier(DoubleIdentifier, ParseInfo) - 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
 
DoublePrecision() - Constructor for class org.apache.sysds.runtime.instructions.gpu.SpoofCUDAInstruction.DoublePrecision
 
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
 
DRB - org.apache.sysds.runtime.data.DenseBlock.Type
 
DRIVER - org.apache.sysds.api.mlcontext.MLContext.ExecutionType
 
DRIVER_AND_HADOOP - org.apache.sysds.api.mlcontext.MLContext.ExecutionType
 
DRIVER_AND_SPARK - org.apache.sysds.api.mlcontext.MLContext.ExecutionType
 
driverInformationBlockAddress - Variable in class org.apache.sysds.runtime.io.hdf5.H5Superblock
 
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
 
DROP_INVALID_LENGTH - org.apache.sysds.common.Builtins
 
DROP_INVALID_LENGTH - org.apache.sysds.common.Types.OpOp2
 
DROP_INVALID_LENGTH - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
DROP_INVALID_TYPE - org.apache.sysds.common.Builtins
 
DROP_INVALID_TYPE - org.apache.sysds.common.Types.OpOp2
 
DROP_INVALID_TYPE - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
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.frame.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.compress.CompressedMatrixBlock
 
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)
Dummycode - org.apache.sysds.runtime.transform.decode.DecoderFactory.DecoderType
 
Dummycode - org.apache.sysds.runtime.transform.encode.ColumnEncoder.EncoderType
 
DUMMYCODE - org.apache.sysds.runtime.transform.TfUtils.TfMethod
 
duration - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.HeavyHitterModel
 
dxDesc - Variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNPoolingDescriptors
 
dyDesc - Variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNPoolingDescriptors
 

E

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
 
EIGEN - org.apache.sysds.common.Builtins
 
EIGEN - org.apache.sysds.common.Types.OpOp1
 
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
 
EMA - org.apache.sysds.common.Builtins
 
EMAUtils - Class in org.apache.sysds.runtime.util
 
EMAUtils() - Constructor for class org.apache.sysds.runtime.util.EMAUtils
 
EMPTY - org.apache.sysds.runtime.compress.colgroup.AColGroup.CompressionType
 
EMPTY - org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory.OFF_TYPE_SPECIALIZATIONS
 
EMPTY - org.apache.sysds.runtime.controlprogram.caching.CacheableData.CacheStatus
 
EMPTY - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
 
EMPTY_BLOCK - org.apache.sysds.common.Types.BlockType
 
EMPTY_TEXT_LINE - Static variable in class org.apache.sysds.runtime.io.IOUtilFunctions
 
EMPTY_TOKEN - Static variable in class org.apache.sysds.runtime.transform.tokenize.Token
 
EmptyEncoding - Class in org.apache.sysds.runtime.compress.estim.encoding
Empty encoding for cases where the entire group of columns is zero
EmptyEncoding() - Constructor for class org.apache.sysds.runtime.compress.estim.encoding.EmptyEncoding
 
emptyMatrixMult(MatrixBlock, MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
 
EmptyScheme - Class in org.apache.sysds.runtime.compress.colgroup.scheme
 
ENABLE_DEBUG_DATA - Static variable in class org.apache.sysds.runtime.util.DependencyTask
 
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
 
enableUMM() - Static method in class org.apache.sysds.hops.OptimizerUtils
Enable unified memory manager and initialize with the default size (85%).
encode(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
encode(CacheBlock<?>, boolean) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
encode(CacheBlock<?>, int) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
encode(CacheBlock<?>, int, boolean) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
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.LegacyEncoder
Block encode: build and apply (transform encode).
encode(MatrixBlock) - Method in class org.apache.sysds.runtime.compress.colgroup.scheme.ConstScheme
 
encode(MatrixBlock) - Method in class org.apache.sysds.runtime.compress.colgroup.scheme.DDCScheme
 
encode(MatrixBlock) - Method in class org.apache.sysds.runtime.compress.colgroup.scheme.EmptyScheme
 
encode(MatrixBlock) - Method in interface org.apache.sysds.runtime.compress.colgroup.scheme.ICLAScheme
Encode the given matrix block into the scheme provided in the instance.
encode(MatrixBlock, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.scheme.ConstScheme
 
encode(MatrixBlock, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.scheme.DDCScheme
 
encode(MatrixBlock, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.scheme.EmptyScheme
 
encode(MatrixBlock, IColIndex) - Method in interface org.apache.sysds.runtime.compress.colgroup.scheme.ICLAScheme
Encode a given matrix block into the scheme provided in the instance but overwrite what columns to use.
encode(MultiColumnEncoder, FrameBlock, int) - Static method in class org.apache.sysds.runtime.transform.encode.CompressedEncode
 
encodeFederatedFrames(FederationMap, MultiColumnEncoder, MatrixObject) - Static method in class org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction
 
Encoder - Interface in org.apache.sysds.runtime.transform.encode
 
encodeRawString(String) - Static method in class org.apache.sysds.runtime.util.DMVUtils
 
EncoderFactory - Class in org.apache.sysds.runtime.transform.encode
 
EncoderFactory() - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderFactory
 
EncoderMVImpute - Class in org.apache.sysds.runtime.transform.encode
 
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(JSONObject, String[], int, int, 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() - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderOmit
 
EncoderOmit(boolean) - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderOmit
 
EncoderOmit(int[], int) - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderOmit
 
EncoderOmit(JSONObject, String[], int, int, int) - Constructor for class org.apache.sysds.runtime.transform.encode.EncoderOmit
 
EncodingFactory - Interface in org.apache.sysds.runtime.compress.estim.encoding
 
encrypt(long, double[]) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.NativeHEHelper
encrypts data with public key stored in client setPublicKey() must have been called before calling this
encrypt(MatrixObject) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.homomorphicEncryption.SEALClient
encrypts one block of data with public key stored statically and returns it setPublicKey() must have been called before calling this
Encrypted - Class in org.apache.sysds.runtime.instructions.cp
This class abstracts over an encrypted data.
Encrypted(int[], DataCharacteristics, byte[], Types.DataType) - Constructor for class org.apache.sysds.runtime.instructions.cp.Encrypted
 
ENCRYPTED_CIPHER - org.apache.sysds.common.Types.DataType
 
ENCRYPTED_PLAIN - org.apache.sysds.common.Types.DataType
 
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
 
endOfFileAddress - Variable in class org.apache.sysds.runtime.io.hdf5.H5Superblock
 
endTime - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.EventStageModel
 
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.frame.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.frame.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
Enter a parse tree produced by the AddSubExpression labeled alternative in DmlParser.expression().
enterAddSubExpression(DmlParser.AddSubExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the AddSubExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by the AssignmentStatement labeled alternative in DmlParser.statement().
enterAssignmentStatement(DmlParser.AssignmentStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the AssignmentStatement labeled alternative in DmlParser.statement().
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
Enter a parse tree produced by the AtomicExpression labeled alternative in DmlParser.expression().
enterAtomicExpression(DmlParser.AtomicExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the AtomicExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by the BooleanAndExpression labeled alternative in DmlParser.expression().
enterBooleanAndExpression(DmlParser.BooleanAndExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the BooleanAndExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by the BooleanNotExpression labeled alternative in DmlParser.expression().
enterBooleanNotExpression(DmlParser.BooleanNotExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the BooleanNotExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by the BooleanOrExpression labeled alternative in DmlParser.expression().
enterBooleanOrExpression(DmlParser.BooleanOrExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the BooleanOrExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by the BuiltinFunctionExpression labeled alternative in DmlParser.expression().
enterBuiltinFunctionExpression(DmlParser.BuiltinFunctionExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the BuiltinFunctionExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by the CommandlineParamExpression labeled alternative in DmlParser.dataIdentifier().
enterCommandlineParamExpression(DmlParser.CommandlineParamExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the CommandlineParamExpression labeled alternative in DmlParser.dataIdentifier().
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
Enter a parse tree produced by the CommandlinePositionExpression labeled alternative in DmlParser.dataIdentifier().
enterCommandlinePositionExpression(DmlParser.CommandlinePositionExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the CommandlinePositionExpression labeled alternative in DmlParser.dataIdentifier().
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
Enter a parse tree produced by the ConstDoubleIdExpression labeled alternative in DmlParser.expression().
enterConstDoubleIdExpression(DmlParser.ConstDoubleIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the ConstDoubleIdExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by the ConstFalseExpression labeled alternative in DmlParser.expression().
enterConstFalseExpression(DmlParser.ConstFalseExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the ConstFalseExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by the ConstIntIdExpression labeled alternative in DmlParser.expression().
enterConstIntIdExpression(DmlParser.ConstIntIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the ConstIntIdExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by the ConstStringIdExpression labeled alternative in DmlParser.expression().
enterConstStringIdExpression(DmlParser.ConstStringIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the ConstStringIdExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by the ConstTrueExpression labeled alternative in DmlParser.expression().
enterConstTrueExpression(DmlParser.ConstTrueExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the ConstTrueExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by the DataIdExpression labeled alternative in DmlParser.expression().
enterDataIdExpression(DmlParser.DataIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the DataIdExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by the ExternalFunctionDefExpression labeled alternative in DmlParser.functionStatement().
enterExternalFunctionDefExpression(DmlParser.ExternalFunctionDefExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the ExternalFunctionDefExpression labeled alternative in DmlParser.functionStatement().
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
Enter a parse tree produced by the ForStatement labeled alternative in DmlParser.statement().
enterForStatement(DmlParser.ForStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the ForStatement labeled alternative in DmlParser.statement().
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
Enter a parse tree produced by the IfStatement labeled alternative in DmlParser.statement().
enterIfStatement(DmlParser.IfStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the IfStatement labeled alternative in DmlParser.statement().
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
Enter a parse tree produced by the ImportStatement labeled alternative in DmlParser.statement().
enterImportStatement(DmlParser.ImportStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the ImportStatement labeled alternative in DmlParser.statement().
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
Enter a parse tree produced by the IndexedExpression labeled alternative in DmlParser.dataIdentifier().
enterIndexedExpression(DmlParser.IndexedExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the IndexedExpression labeled alternative in DmlParser.dataIdentifier().
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
Enter a parse tree produced by the InternalFunctionDefExpression labeled alternative in DmlParser.functionStatement().
enterInternalFunctionDefExpression(DmlParser.InternalFunctionDefExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the InternalFunctionDefExpression labeled alternative in DmlParser.functionStatement().
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
Enter a parse tree produced by the IterablePredicateColonExpression labeled alternative in DmlParser.iterablePredicate().
enterIterablePredicateColonExpression(DmlParser.IterablePredicateColonExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the IterablePredicateColonExpression labeled alternative in DmlParser.iterablePredicate().
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
Enter a parse tree produced by the IterablePredicateSeqExpression labeled alternative in DmlParser.iterablePredicate().
enterIterablePredicateSeqExpression(DmlParser.IterablePredicateSeqExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the IterablePredicateSeqExpression labeled alternative in DmlParser.iterablePredicate().
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
Enter a parse tree produced by the MatrixDataTypeCheck labeled alternative in DmlParser.dataType().
enterMatrixDataTypeCheck(DmlParser.MatrixDataTypeCheckContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the MatrixDataTypeCheck labeled alternative in DmlParser.dataType().
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
Enter a parse tree produced by the MatrixMulExpression labeled alternative in DmlParser.expression().
enterMatrixMulExpression(DmlParser.MatrixMulExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the MatrixMulExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by DmlParser.ml_type().
enterMl_type(DmlParser.Ml_typeContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by DmlParser.ml_type().
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
Enter a parse tree produced by the ModIntDivExpression labeled alternative in DmlParser.expression().
enterModIntDivExpression(DmlParser.ModIntDivExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the ModIntDivExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by the MultDivExpression labeled alternative in DmlParser.expression().
enterMultDivExpression(DmlParser.MultDivExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the MultDivExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by the MultiIdExpression labeled alternative in DmlParser.expression().
enterMultiIdExpression(DmlParser.MultiIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the MultiIdExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by DmlParser.parameterizedExpression().
enterParameterizedExpression(DmlParser.ParameterizedExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by DmlParser.parameterizedExpression().
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
Enter a parse tree produced by the ParForStatement labeled alternative in DmlParser.statement().
enterParForStatement(DmlParser.ParForStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the ParForStatement labeled alternative in DmlParser.statement().
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
Enter a parse tree produced by the PathStatement labeled alternative in DmlParser.statement().
enterPathStatement(DmlParser.PathStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the PathStatement labeled alternative in DmlParser.statement().
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
Enter a parse tree produced by the PowerExpression labeled alternative in DmlParser.expression().
enterPowerExpression(DmlParser.PowerExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the PowerExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by DmlParser.programroot().
enterProgramroot(DmlParser.ProgramrootContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by DmlParser.programroot().
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
Enter a parse tree produced by the RelationalExpression labeled alternative in DmlParser.expression().
enterRelationalExpression(DmlParser.RelationalExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the RelationalExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by the SimpleDataIdentifierExpression labeled alternative in DmlParser.dataIdentifier().
enterSimpleDataIdentifierExpression(DmlParser.SimpleDataIdentifierExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the SimpleDataIdentifierExpression labeled alternative in DmlParser.dataIdentifier().
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
Enter a parse tree produced by DmlParser.strictParameterizedExpression().
enterStrictParameterizedExpression(DmlParser.StrictParameterizedExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by DmlParser.strictParameterizedExpression().
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
Enter a parse tree produced by DmlParser.strictParameterizedKeyValueString().
enterStrictParameterizedKeyValueString(DmlParser.StrictParameterizedKeyValueStringContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by DmlParser.strictParameterizedKeyValueString().
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
Enter a parse tree produced by DmlParser.typedArgAssign().
enterTypedArgAssign(DmlParser.TypedArgAssignContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by DmlParser.typedArgAssign().
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
Enter a parse tree produced by DmlParser.typedArgNoAssign().
enterTypedArgNoAssign(DmlParser.TypedArgNoAssignContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by DmlParser.typedArgNoAssign().
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
Enter a parse tree produced by the UnaryExpression labeled alternative in DmlParser.expression().
enterUnaryExpression(DmlParser.UnaryExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the UnaryExpression labeled alternative in DmlParser.expression().
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
Enter a parse tree produced by DmlParser.valueType().
enterValueType(DmlParser.ValueTypeContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by DmlParser.valueType().
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
Enter a parse tree produced by the WhileStatement labeled alternative in DmlParser.statement().
enterWhileStatement(DmlParser.WhileStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Enter a parse tree produced by the WhileStatement labeled alternative in DmlParser.statement().
enterWhileStatement(DmlParser.WhileStatementContext) - Method in class org.apache.sysds.parser.dml.DmlPreprocessor
 
enterWhileStatement(DmlParser.WhileStatementContext) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
 
ENTITY_ADDRESS_COL - Static variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.Constants
 
ENTITY_CLASS_SUFFIX - Static variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.Constants
 
ENTITY_DOUBLE_COL - Static variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.Constants
 
ENTITY_EVENT_ID_COL - Static variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.Constants
 
ENTITY_ID_COL - Static variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.Constants
 
ENTITY_MONITORING_KEY_COL - Static variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.Constants
 
ENTITY_NAME_COL - Static variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.Constants
 
ENTITY_NUMBER_COL - Static variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.Constants
 
ENTITY_STRING_COL - Static variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.Constants
 
ENTITY_TIMESTAMP_COL - Static variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.Constants
 
ENTITY_WORKER_ID_COL - Static variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.Constants
 
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
 
EPOCH - org.apache.sysds.parser.Statement.PSCheckpointing
 
EPOCH - org.apache.sysds.parser.Statement.PSFrequency
 
EPOCH10 - org.apache.sysds.parser.Statement.PSCheckpointing
 
EQUAL - org.apache.sysds.common.Types.OpOp2
 
EQUAL - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
EQUAL - org.apache.sysds.parser.Expression.RelationalOp
 
equalDims(Object) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
 
equalDims(Object) - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
 
equalDims(Object) - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
 
equalPlanRefs(CPlanMemoTable.MemoTableEntry) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
 
equals(double[], int) - Method in class org.apache.sysds.runtime.data.SparseBlock
Get if the dense double array is equivalent to this sparse Block.
equals(double[], int, double) - Method in class org.apache.sysds.runtime.data.SparseBlock
Get if the dense double array is equivalent to this sparse Block.
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.ColIndexes
 
equals(Object) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
 
equals(Object) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.AColIndex
 
equals(Object) - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex
 
equals(Object) - Method in class org.apache.sysds.runtime.compress.utils.DblArray
 
equals(Object) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
 
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.DenseBlock
 
equals(Object) - Method in class org.apache.sysds.runtime.data.SparseBlock
 
equals(Object) - Method in class org.apache.sysds.runtime.data.TensorIndexes
 
equals(Object) - Method in class org.apache.sysds.runtime.frame.data.columns.ColumnMetadata
 
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(Object) - Method in class org.apache.sysds.runtime.privacy.PrivacyConstraint
 
equals(Object) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
equals(Object) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
equals(Object) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
equals(Object) - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
 
equals(List<T>, List<T>) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
 
equals(ADictionary) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
 
equals(ADictionary) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
equals(ADictionary) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
equals(ADictionary) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
equals(ADictionary) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
equals(ADictionary) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
equals(IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.ArrayIndex
 
equals(IColIndex) - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex
 
equals(IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.RangeIndex
 
equals(IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.SingleIndex
 
equals(IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.TwoIndex
 
equals(AIterator) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AIterator
Unsafe version of equals, note that it should only compare iterators stemming from the same Offset Object.
equals(AOffset) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
 
equals(DblArray) - Method in class org.apache.sysds.runtime.compress.utils.DblArray
 
equals(DenseBlock, double) - Method in class org.apache.sysds.runtime.data.DenseBlock
Verify if the values in this dense block is equivalent to that dense block, not taking into account the dimensions of the contained values.
equals(SparseBlock, double) - Method in class org.apache.sysds.runtime.data.SparseBlock
Verify if the values in this sparse block is equivalent to that sparse block, not taking into account the dimensions of the contained values.
equals(ColumnMetadata) - Method in class org.apache.sysds.runtime.frame.data.columns.ColumnMetadata
 
equals(MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Analyze if the matrixBlocks are equivalent, the comparsion supports if the differnet sides are differently allocated such as sparse and dense.
equals(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixEquals
Analyze if the two matrix blocks are equivalent, this functions even if the underlying allocation and data structure varies.
equals(MatrixBlock, MatrixBlock, double) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixEquals
Analyze if the two matrix blocks are equivalent, this functions even if the underlying allocation and data structure varies.
Equals - Class in org.apache.sysds.runtime.functionobjects
 
EQUI_HEIGHT - org.apache.sysds.runtime.transform.encode.ColumnEncoderBin.BinMethod
 
EQUI_WIDTH - org.apache.sysds.runtime.transform.encode.ColumnEncoderBin.BinMethod
 
EQZERO - org.apache.sysds.hops.estim.SparsityEstimator.OpCode
 
ERROR - org.apache.sysds.runtime.controlprogram.federated.FederatedResponse.ResponseType
 
ERROR - org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcResponse.Type
 
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(MMNode) - Method in class org.apache.sysds.hops.estim.EstimatorBasicWorst
 
estim(MMNode) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM
 
estim(MMNode) - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap
 
estim(MMNode) - Method in class org.apache.sysds.hops.estim.EstimatorLayeredGraph
 
estim(MMNode) - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram
 
estim(MMNode) - Method in class org.apache.sysds.hops.estim.EstimatorSample
 
estim(MMNode) - 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(MMNode, boolean) - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram
 
estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorBasicAvg
 
estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorBasicWorst
 
estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM
 
estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap
 
estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorLayeredGraph
 
estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram
 
estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorSample
 
estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorSampleRa
 
estim(MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.SparsityEstimator
Estimates the output sparsity for a given unary operation.
estim(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorBasicAvg
 
estim(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorBasicWorst
 
estim(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM
 
estim(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap
 
estim(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorLayeredGraph
 
estim(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram
 
estim(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorSample
 
estim(MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.hops.estim.EstimatorSampleRa
 
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.EstimatorBasicAvg
 
estim(MatrixBlock, MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorBasicWorst
 
estim(MatrixBlock, MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM
 
estim(MatrixBlock, MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap
 
estim(MatrixBlock, MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorLayeredGraph
 
estim(MatrixBlock, MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram
 
estim(MatrixBlock, MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorSample
 
estim(MatrixBlock, MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.EstimatorSampleRa
 
estim(MatrixBlock, MatrixBlock, SparsityEstimator.OpCode) - Method in class org.apache.sysds.hops.estim.SparsityEstimator
Estimates the output sparsity for a given binary operation.
estimateCompressedSizeInMemory() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
Obtain an upper bound on the memory used to store the compressed block.
estimatedCostCoCoded - Variable in class org.apache.sysds.runtime.compress.CompressionStatistics
Summed cost after cocoding
estimatedCostCols - Variable in class org.apache.sysds.runtime.compress.CompressionStatistics
Summed cost estimated from individual columns
estimateDistinctValues(MatrixBlock, CountDistinctOperator) - Static method in interface 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
 
estimatedSizeCoCoded - Variable in class org.apache.sysds.runtime.compress.CompressionStatistics
Estimated size of compressing after co-coding
estimatedSizeCols - Variable in class org.apache.sysds.runtime.compress.CompressionStatistics
Estimated size of compressing individual columns
estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Get the upper bound estimate of in memory allocation for the column group.
estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupOffset
 
estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupValue
 
estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.ADictBasedColGroup
 
estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.ArrayIndex
 
estimateInMemorySize() - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex
Get the in memory size of this object.
estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.RangeIndex
 
estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.SingleIndex
 
estimateInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.TwoIndex
 
estimateInMemorySize() - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetEmpty
 
estimateInMemorySize() - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetSingle
 
estimateInMemorySize() - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetTwo
 
estimateInMemorySize(int) - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetByte
 
estimateInMemorySize(int) - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetChar
 
estimateInMemorySize(int) - Static method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
estimateInMemorySize(int) - Static method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
estimateInMemorySize(int, int) - Static method in interface org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory
 
estimateInMemorySize(int, int) - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory
Avg diff only works assuming a normal distribution of the offsets.
estimateInMemorySizeCONST(int, boolean, double, boolean) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
 
estimateInMemorySizeDDC(int, boolean, int, int, double, boolean) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
 
estimateInMemorySizeEMPTY(int, boolean) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
 
estimateInMemorySizeGroup(int, boolean) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
 
estimateInMemorySizeGroupValue(int, boolean, int, double, boolean) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
 
estimateInMemorySizeLinearFunctional(int, boolean) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
 
estimateInMemorySizeOffset(int, boolean, int, int, int, double, boolean) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
 
estimateInMemorySizeOLE(int, boolean, int, int, int, double, boolean) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
 
estimateInMemorySizeRLE(int, boolean, int, int, int, double, boolean) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
 
estimateInMemorySizeSDC(int, boolean, int, int, int, double, boolean, boolean) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
 
estimateInMemorySizeStatic() - Static method in class org.apache.sysds.runtime.compress.colgroup.indexes.RangeIndex
 
estimateInMemorySizeStatic() - Static method in class org.apache.sysds.runtime.compress.colgroup.indexes.SingleIndex
 
estimateInMemorySizeStatic() - Static method in class org.apache.sysds.runtime.compress.colgroup.indexes.TwoIndex
 
estimateInMemorySizeStatic(int) - Static method in class org.apache.sysds.runtime.compress.colgroup.indexes.ArrayIndex
 
estimateInMemorySizeUncompressed(int, boolean, int, double) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
 
estimateMemory(long, long) - Static method in class org.apache.sysds.runtime.data.DenseBlock
 
estimateMemory(long, long) - Static method in class org.apache.sysds.runtime.data.DenseBlockFP64
 
estimateMemoryCost(int, boolean) - Static method in interface org.apache.sysds.runtime.compress.colgroup.indexes.ColIndexFactory
 
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
 
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.
estimatePartitionedSizeExactSparsity(long, long, long, double, boolean) - Static method in class org.apache.sysds.hops.OptimizerUtils
 
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, long, boolean) - Static method in class org.apache.sysds.hops.OptimizerUtils
 
estimatePartitionedSizeExactSparsity(Hop) - 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 hops dimensions and number of non-zeros nnz.
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(DataCharacteristics, boolean) - Static method in class org.apache.sysds.hops.OptimizerUtils
 
estimateSerializationBufferSize() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
 
estimateSerializationBufferSize() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedResponse
 
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
estimateSize(DataCharacteristics) - Static method in class org.apache.sysds.hops.OptimizerUtils
 
estimateSizeDenseInMemory() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
estimateSizeDenseInMemory(long, long) - Static method in class org.apache.sysds.runtime.data.DenseBlockFactory
 
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(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.
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(DataCharacteristics) - Static method in class org.apache.sysds.hops.OptimizerUtils
 
estimateSizeInMemory() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
estimateSizeInMemory() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
estimateSizeInMemory(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.
estimateSizeInMemory(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.
estimateSizeInMemory(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.
estimateSizeInMemory(long, long, double) - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
estimateSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
estimateSizeSparseInMemory(long, long, double) - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
estimateSizeSparseInMemory(long, long, double, boolean) - 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
 
estimateSizeSparseInMemory(SparseBlock.Type) - 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
 
estimateSizeTextOutput(int[], long, Types.FileFormat) - Static method in class org.apache.sysds.hops.OptimizerUtils
 
estimateSizeTextOutput(long, long, long, Types.FileFormat) - Static method in class org.apache.sysds.hops.OptimizerUtils
 
EstimationFactors - Class in org.apache.sysds.runtime.compress.estim
Compressed Size Estimation factors.
EstimationFactors(int, int) - Constructor for class org.apache.sysds.runtime.compress.estim.EstimationFactors
 
EstimationFactors(int, int, double) - Constructor for class org.apache.sysds.runtime.compress.estim.EstimationFactors
 
EstimationFactors(int, int, int, double) - Constructor for class org.apache.sysds.runtime.compress.estim.EstimationFactors
 
EstimationFactors(int, int, int, int[], int, int, boolean, boolean, double, double) - Constructor for class org.apache.sysds.runtime.compress.estim.EstimationFactors
 
EstimationFactors(int, int, int, int[], int, int, int, boolean, boolean, double, double) - Constructor for class org.apache.sysds.runtime.compress.estim.EstimationFactors
 
estimationType - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
The sample type used for sampling
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
 
EVAL - org.apache.sysds.common.Builtins
 
EVAL - org.apache.sysds.common.Types.OpOpN
 
EVAL - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
EVALLIST - org.apache.sysds.common.Builtins
 
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.compress.CompressedMatrixBlock
 
evalSparseFormatInMemory() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Evaluates if this matrix block should be in sparse format in memory.
evalSparseFormatInMemory(boolean) - 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.
evalSparseFormatInMemory(long, long, long, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
evalSparseFormatInMemory(DataCharacteristics) - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
evalSparseFormatOnDisk() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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).
eventId - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.EventStageModel
 
EventModel - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.models
 
EventModel() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.EventModel
 
EventModel(Long, Long) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.EventModel
 
EventModel(Long, Long, Long) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.EventModel
 
events - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.StatisticsModel
 
events - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.StatisticsOptions
 
EventStageModel - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.models
 
EventStageModel() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.EventStageModel
 
EventStageModel(Long, Long, String) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.EventStageModel
 
EventStageModel(Long, String) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.EventStageModel
 
evictBuffer(String) - Method in class org.apache.sysds.runtime.controlprogram.caching.ByteBuffer
 
evictFromDeviceToHostMB(String, boolean) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
 
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
 
EXACT_DYNAMIC_BUFF - org.apache.sysds.hops.codegen.SpoofCompiler.RegisterAlloc
 
EXACT_STATIC_BUFF - org.apache.sysds.hops.codegen.SpoofCompiler.RegisterAlloc
 
examSparsity() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Evaluates if this matrix block should be in sparse format in memory.
examSparsity(boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.FederatedMonitoringServerHandler
 
exchangeChild(OptNode, OptNode) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
 
exec(SpoofCUDAOperator) - Method in class org.apache.sysds.runtime.codegen.SpoofCUDAOperator.PrecisionProxy
 
exec(SpoofCUDAOperator) - Method in class org.apache.sysds.runtime.instructions.gpu.SpoofCUDAInstruction.DoublePrecision
 
exec(SpoofCUDAOperator) - Method in class org.apache.sysds.runtime.instructions.gpu.SpoofCUDAInstruction.SinglePrecision
 
EXEC_INST - org.apache.sysds.runtime.controlprogram.federated.FederatedRequest.RequestType
 
EXEC_MODE - Static variable in class org.apache.sysds.parser.ParForStatementBlock
 
EXEC_TIME - org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator.TestMeasure
 
EXEC_TIME_THRESHOLD - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerHeuristic
 
EXEC_UDF - org.apache.sysds.runtime.controlprogram.federated.FederatedRequest.RequestType
 
execCleanup(long, long...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
execMode - Variable in class org.apache.sysds.api.DMLOptions
 
execute() - Method in class org.apache.sysds.api.mlcontext.Script
Execute the script and return the results as an MLResults object.
execute(boolean) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
 
execute(boolean) - Method in class org.apache.sysds.runtime.functionobjects.Not
 
execute(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.And
 
execute(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
 
execute(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.Or
 
execute(boolean, boolean) - Method in class org.apache.sysds.runtime.functionobjects.Xor
 
execute(double) - Method in class org.apache.sysds.runtime.functionobjects.Builtin
 
execute(double) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
 
execute(double) - Method in class org.apache.sysds.runtime.functionobjects.Multiply2
 
execute(double) - Method in class org.apache.sysds.runtime.functionobjects.Not
 
execute(double) - Method in class org.apache.sysds.runtime.functionobjects.Power2
 
execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.And
 
execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.BitwAnd
 
execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.BitwOr
 
execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.BitwShiftL
 
execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.BitwShiftR
 
execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.BitwXor
 
execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Builtin
 
execute(double, double) - 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(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) - Method in class org.apache.sysds.runtime.functionobjects.IntegerDivide
 
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(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Minus
 
execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Minus1Multiply
 
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(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Modulus
 
execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Multiply
 
execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Multiply2
 
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(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Or
 
execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Plus
 
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(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Power2
 
execute(double, double) - Method in class org.apache.sysds.runtime.functionobjects.Xor
 
execute(double, double, double) - Method in class org.apache.sysds.runtime.functionobjects.IfElse
 
execute(double, double, double) - Method in class org.apache.sysds.runtime.functionobjects.MinusMultiply
 
execute(double, double, double) - Method in class org.apache.sysds.runtime.functionobjects.PlusMultiply
 
execute(double, double, double) - Method in class org.apache.sysds.runtime.functionobjects.TernaryValueFunction
 
execute(double, double, double, boolean, CTableMap) - Method in class org.apache.sysds.runtime.functionobjects.CTable
 
execute(double, double, double, boolean, CTableMap, MatrixBlock) - 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, int[], double[]) - Method in class org.apache.sysds.runtime.functionobjects.CTable
 
execute(int, int) - Method in interface org.apache.sysds.runtime.matrix.data.LibMatrixDNNRotate180.Rotate180Worker
 
execute(long) - Method in class org.apache.sysds.runtime.functionobjects.Builtin
 
execute(long) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
 
execute(long, boolean, FederatedRange[], FederatedRequest, FederatedRequest[], FederatedRequest[], FederatedRequest...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
execute(long, boolean, FederatedRange[], FederatedRequest, FederatedRequest, FederatedRequest, 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, boolean, FederatedRequest[], FederatedRequest...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
execute(long, boolean, FederatedRequest[], FederatedRequest[], FederatedRequest...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
execute(long, double, double) - Method in class org.apache.sysds.runtime.functionobjects.CTable
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.BitwAnd
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.BitwOr
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.BitwShiftL
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.BitwShiftR
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.BitwXor
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Builtin
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Divide
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.IntegerDivide
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Minus
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Minus1Multiply
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.MinusNz
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Modulus
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Multiply
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Multiply2
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Plus
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Power
 
execute(long, long) - Method in class org.apache.sysds.runtime.functionobjects.Power2
 
execute(long, 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(Runnable) - Method in class org.apache.sysds.runtime.util.CommonThreadPool
 
execute(String) - Method in class org.apache.sysds.runtime.functionobjects.Builtin
 
execute(String) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
 
execute(String, String) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
 
execute(String, String) - Method in class org.apache.sysds.runtime.functionobjects.Plus
 
execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>) - 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.SpoofCellwise
 
execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, int) - Method in class org.apache.sysds.runtime.codegen.SpoofOperator
 
execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, 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>, 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) - 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) - Method in class org.apache.sysds.runtime.codegen.SpoofOuterProduct
 
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.SpoofCellwise
 
execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock, int) - Method in class org.apache.sysds.runtime.codegen.SpoofMultiAggregate
 
execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock, int) - Method in class org.apache.sysds.runtime.codegen.SpoofOperator
 
execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock, int) - Method in class org.apache.sysds.runtime.codegen.SpoofOuterProduct
 
execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock, int) - Method in class org.apache.sysds.runtime.codegen.SpoofRowwise
 
execute(ArrayList<MatrixBlock>, ArrayList<ScalarObject>, MatrixBlock, int, long) - 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.SpoofMultiAggregate
 
execute(HashMap<String, String>) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
 
execute(HashMap<String, String>) - Method in class org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin
 
execute(Script) - Method in class org.apache.sysds.api.mlcontext.MLContext
Execute a DML or PYDML Script.
execute(Script) - Method in class org.apache.sysds.api.mlcontext.ScriptExecutor
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(ExecutionContext) - Method in class org.apache.sysds.runtime.controlprogram.BasicProgramBlock
 
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(ExecutionContext, ArrayList<MatrixObject>, ArrayList<ScalarObject>) - Method in class org.apache.sysds.runtime.codegen.SpoofCUDACellwise
 
execute(ExecutionContext, ArrayList<MatrixObject>, ArrayList<ScalarObject>) - Method in interface org.apache.sysds.runtime.codegen.SpoofCUDAOperator
 
execute(ExecutionContext, ArrayList<MatrixObject>, ArrayList<ScalarObject>) - Method in class org.apache.sysds.runtime.codegen.SpoofCUDARowwise
 
execute(ExecutionContext, ArrayList<MatrixObject>, ArrayList<ScalarObject>, String) - Method in class org.apache.sysds.runtime.codegen.SpoofCUDACellwise
 
execute(ExecutionContext, ArrayList<MatrixObject>, ArrayList<ScalarObject>, String) - Method in interface org.apache.sysds.runtime.codegen.SpoofCUDAOperator
 
execute(ExecutionContext, ArrayList<MatrixObject>, ArrayList<ScalarObject>, String) - Method in class org.apache.sysds.runtime.codegen.SpoofCUDARowwise
 
execute(ExecutionContext, Data...) - Method in class org.apache.sysds.hops.fedplanner.PrivacyConstraintLoader.PrivacyConstraintRetriever
Reads metadata JSON object, parses privacy constraint and returns the constraint in FederatedResponse.
execute(ExecutionContext, Data...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics.FedStatsCollectFunction
 
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(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(ExecutionContext, Data...) - Method in class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction.CreateMatrixFromFrame
 
execute(ExecutionContext, Data...) - Method in class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction.GetHistogram
 
execute(ExecutionContext, Data...) - Method in class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction.GetValuesInRange
 
execute(ExecutionContext, Data...) - Method in class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction.GetValuesInRanges
 
execute(ExecutionContext, Data...) - Method in class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction.MinMax
 
execute(ExecutionContext, Data...) - Method in class org.apache.sysds.runtime.instructions.fed.ReorgFEDInstruction.DiagMatrix
 
execute(ExecutionContext, Data...) - Method in class org.apache.sysds.runtime.instructions.fed.ReorgFEDInstruction.Rdiag
 
execute(Data, double) - Method in class org.apache.sysds.runtime.functionobjects.CM
Special case for weights w2==1
execute(Data, double) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
 
execute(Data, 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.CM
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, double, double) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
 
execute(Data, double, double) - Method in class org.apache.sysds.runtime.functionobjects.KahanPlus
 
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(Data, double, double) - Method in class org.apache.sysds.runtime.functionobjects.Mean
 
execute(Data, double, double, double) - Method in class org.apache.sysds.runtime.functionobjects.COV
General case for arbitrary weights w2
execute(Data, double, double, double) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
 
execute(Data, Data) - Method in class org.apache.sysds.runtime.functionobjects.CM
Combining stats from two partitions of the data.
execute(Data, Data) - Method in class org.apache.sysds.runtime.functionobjects.COV
 
execute(Data, Data) - Method in class org.apache.sysds.runtime.functionobjects.FunctionObject
 
execute(MatrixBlock, MatrixBlock, MatrixBlock, CTableMap, int) - Method in class org.apache.sysds.runtime.functionobjects.CTable
 
execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.DiagIndex
 
execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.IndexFunction
 
execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.OffsetColumnIndex
 
execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.ReduceAll
 
execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.ReduceCol
 
execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.ReduceDiag
 
execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.ReduceRow
 
execute(MatrixIndexes, MatrixIndexes) - Method in class org.apache.sysds.runtime.functionobjects.RevIndex
 
execute(MatrixIndexes, MatrixIndexes) - 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.DiagIndex
 
execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.IndexFunction
 
execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.OffsetColumnIndex
 
execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.ReduceAll
 
execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.ReduceCol
 
execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.ReduceDiag
 
execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.ReduceRow
 
execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.RevIndex
 
execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.SortIndex
 
execute(MatrixValue.CellIndex, MatrixValue.CellIndex) - Method in class org.apache.sysds.runtime.functionobjects.SwapIndex
 
execute_d(long) - Static method in class org.apache.sysds.runtime.codegen.SpoofCUDACellwise
 
execute_d(long) - Static method in class org.apache.sysds.runtime.codegen.SpoofCUDARowwise
 
execute_dp(long) - Method in class org.apache.sysds.runtime.codegen.SpoofCUDACellwise
 
execute_dp(long) - Method in interface org.apache.sysds.runtime.codegen.SpoofCUDAOperator
 
execute_dp(long) - Method in class org.apache.sysds.runtime.codegen.SpoofCUDARowwise
 
execute_f(long) - Static method in class org.apache.sysds.runtime.codegen.SpoofCUDACellwise
 
execute_f(long) - Static method in class org.apache.sysds.runtime.codegen.SpoofCUDARowwise
 
EXECUTE_PIPELINE - org.apache.sysds.common.Builtins
 
execute_sp(long) - Method in class org.apache.sysds.runtime.codegen.SpoofCUDACellwise
 
execute_sp(long) - Method in interface org.apache.sysds.runtime.codegen.SpoofCUDAOperator
 
execute_sp(long) - Method in class org.apache.sysds.runtime.codegen.SpoofCUDARowwise
 
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(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.FederatedData
 
executeFederatedOperation(FederatedRequest...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedLocalData
 
ExecuteFrameEncoder(long, long, MultiColumnEncoder) - Constructor for class org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction.ExecuteFrameEncoder
 
executeInMemoryReblock(ExecutionContext, String, String) - Static method in class org.apache.sysds.hops.recompile.Recompiler
 
executeInMemoryReblock(ExecutionContext, String, String, LineageItem) - Static method in class org.apache.sysds.hops.recompile.Recompiler
 
executeMultipleSlices(long, boolean, FederatedRequest[][], FederatedRequest[]) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
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.ResultMergeFrameLocalMemory
 
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() - 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.
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)
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.ResultMergeFrameLocalMemory
 
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) - 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) - 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
 
existingCostPointer(long) - Method in class org.apache.sysds.hops.cost.HopRel
Checks if another Hop is refering to this HopRel in memo table.
EXISTS - org.apache.sysds.common.Builtins
 
EXISTS - org.apache.sysds.common.Types.OpOp1
 
EXISTS - org.apache.sysds.runtime.instructions.cp.AggregateUnaryCPInstruction.AUType
 
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
Exit a parse tree produced by the AddSubExpression labeled alternative in DmlParser.expression().
exitAddSubExpression(DmlParser.AddSubExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the AddSubExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by the AssignmentStatement labeled alternative in DmlParser.statement().
exitAssignmentStatement(DmlParser.AssignmentStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the AssignmentStatement labeled alternative in DmlParser.statement().
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
Exit a parse tree produced by the AtomicExpression labeled alternative in DmlParser.expression().
exitAtomicExpression(DmlParser.AtomicExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the AtomicExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by the BooleanAndExpression labeled alternative in DmlParser.expression().
exitBooleanAndExpression(DmlParser.BooleanAndExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the BooleanAndExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by the BooleanNotExpression labeled alternative in DmlParser.expression().
exitBooleanNotExpression(DmlParser.BooleanNotExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the BooleanNotExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by the BooleanOrExpression labeled alternative in DmlParser.expression().
exitBooleanOrExpression(DmlParser.BooleanOrExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the BooleanOrExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by the BuiltinFunctionExpression labeled alternative in DmlParser.expression().
exitBuiltinFunctionExpression(DmlParser.BuiltinFunctionExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the BuiltinFunctionExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by the CommandlineParamExpression labeled alternative in DmlParser.dataIdentifier().
exitCommandlineParamExpression(DmlParser.CommandlineParamExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the CommandlineParamExpression labeled alternative in DmlParser.dataIdentifier().
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
Exit a parse tree produced by the CommandlinePositionExpression labeled alternative in DmlParser.dataIdentifier().
exitCommandlinePositionExpression(DmlParser.CommandlinePositionExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the CommandlinePositionExpression labeled alternative in DmlParser.dataIdentifier().
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
Exit a parse tree produced by the ConstDoubleIdExpression labeled alternative in DmlParser.expression().
exitConstDoubleIdExpression(DmlParser.ConstDoubleIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the ConstDoubleIdExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by the ConstFalseExpression labeled alternative in DmlParser.expression().
exitConstFalseExpression(DmlParser.ConstFalseExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the ConstFalseExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by the ConstIntIdExpression labeled alternative in DmlParser.expression().
exitConstIntIdExpression(DmlParser.ConstIntIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the ConstIntIdExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by the ConstStringIdExpression labeled alternative in DmlParser.expression().
exitConstStringIdExpression(DmlParser.ConstStringIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the ConstStringIdExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by the ConstTrueExpression labeled alternative in DmlParser.expression().
exitConstTrueExpression(DmlParser.ConstTrueExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the ConstTrueExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by the DataIdExpression labeled alternative in DmlParser.expression().
exitDataIdExpression(DmlParser.DataIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the DataIdExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by the ExternalFunctionDefExpression labeled alternative in DmlParser.functionStatement().
exitExternalFunctionDefExpression(DmlParser.ExternalFunctionDefExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the ExternalFunctionDefExpression labeled alternative in DmlParser.functionStatement().
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
Exit a parse tree produced by the ForStatement labeled alternative in DmlParser.statement().
exitForStatement(DmlParser.ForStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the ForStatement labeled alternative in DmlParser.statement().
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
Exit a parse tree produced by the IfdefAssignmentStatement labeled alternative in DmlParser.statement().
exitIfdefAssignmentStatement(DmlParser.IfdefAssignmentStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the IfdefAssignmentStatement labeled alternative in DmlParser.statement().
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
Exit a parse tree produced by the IfStatement labeled alternative in DmlParser.statement().
exitIfStatement(DmlParser.IfStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the IfStatement labeled alternative in DmlParser.statement().
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
Exit a parse tree produced by the ImportStatement labeled alternative in DmlParser.statement().
exitImportStatement(DmlParser.ImportStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the ImportStatement labeled alternative in DmlParser.statement().
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
Exit a parse tree produced by the IndexedExpression labeled alternative in DmlParser.dataIdentifier().
exitIndexedExpression(DmlParser.IndexedExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the IndexedExpression labeled alternative in DmlParser.dataIdentifier().
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
Exit a parse tree produced by the InternalFunctionDefExpression labeled alternative in DmlParser.functionStatement().
exitInternalFunctionDefExpression(DmlParser.InternalFunctionDefExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the InternalFunctionDefExpression labeled alternative in DmlParser.functionStatement().
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
Exit a parse tree produced by the IterablePredicateColonExpression labeled alternative in DmlParser.iterablePredicate().
exitIterablePredicateColonExpression(DmlParser.IterablePredicateColonExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the IterablePredicateColonExpression labeled alternative in DmlParser.iterablePredicate().
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
Exit a parse tree produced by the IterablePredicateSeqExpression labeled alternative in DmlParser.iterablePredicate().
exitIterablePredicateSeqExpression(DmlParser.IterablePredicateSeqExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the IterablePredicateSeqExpression labeled alternative in DmlParser.iterablePredicate().
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
Exit a parse tree produced by the MatrixDataTypeCheck labeled alternative in DmlParser.dataType().
exitMatrixDataTypeCheck(DmlParser.MatrixDataTypeCheckContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the MatrixDataTypeCheck labeled alternative in DmlParser.dataType().
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
Exit a parse tree produced by the MatrixMulExpression labeled alternative in DmlParser.expression().
exitMatrixMulExpression(DmlParser.MatrixMulExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the MatrixMulExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by DmlParser.ml_type().
exitMl_type(DmlParser.Ml_typeContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by DmlParser.ml_type().
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
Exit a parse tree produced by the ModIntDivExpression labeled alternative in DmlParser.expression().
exitModIntDivExpression(DmlParser.ModIntDivExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the ModIntDivExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by the MultDivExpression labeled alternative in DmlParser.expression().
exitMultDivExpression(DmlParser.MultDivExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the MultDivExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by the MultiIdExpression labeled alternative in DmlParser.expression().
exitMultiIdExpression(DmlParser.MultiIdExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the MultiIdExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by DmlParser.parameterizedExpression().
exitParameterizedExpression(DmlParser.ParameterizedExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by DmlParser.parameterizedExpression().
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
Exit a parse tree produced by the ParForStatement labeled alternative in DmlParser.statement().
exitParForStatement(DmlParser.ParForStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the ParForStatement labeled alternative in DmlParser.statement().
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
Exit a parse tree produced by the PathStatement labeled alternative in DmlParser.statement().
exitPathStatement(DmlParser.PathStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the PathStatement labeled alternative in DmlParser.statement().
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
Exit a parse tree produced by the PowerExpression labeled alternative in DmlParser.expression().
exitPowerExpression(DmlParser.PowerExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the PowerExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by DmlParser.programroot().
exitProgramroot(DmlParser.ProgramrootContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by DmlParser.programroot().
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
Exit a parse tree produced by the RelationalExpression labeled alternative in DmlParser.expression().
exitRelationalExpression(DmlParser.RelationalExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the RelationalExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by the SimpleDataIdentifierExpression labeled alternative in DmlParser.dataIdentifier().
exitSimpleDataIdentifierExpression(DmlParser.SimpleDataIdentifierExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the SimpleDataIdentifierExpression labeled alternative in DmlParser.dataIdentifier().
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
Exit a parse tree produced by DmlParser.strictParameterizedExpression().
exitStrictParameterizedExpression(DmlParser.StrictParameterizedExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by DmlParser.strictParameterizedExpression().
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
Exit a parse tree produced by DmlParser.strictParameterizedKeyValueString().
exitStrictParameterizedKeyValueString(DmlParser.StrictParameterizedKeyValueStringContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by DmlParser.strictParameterizedKeyValueString().
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
Exit a parse tree produced by DmlParser.typedArgAssign().
exitTypedArgAssign(DmlParser.TypedArgAssignContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by DmlParser.typedArgAssign().
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
Exit a parse tree produced by DmlParser.typedArgNoAssign().
exitTypedArgNoAssign(DmlParser.TypedArgNoAssignContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by DmlParser.typedArgNoAssign().
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
Exit a parse tree produced by the UnaryExpression labeled alternative in DmlParser.expression().
exitUnaryExpression(DmlParser.UnaryExpressionContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the UnaryExpression labeled alternative in DmlParser.expression().
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
Exit a parse tree produced by DmlParser.valueType().
exitValueType(DmlParser.ValueTypeContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by DmlParser.valueType().
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
Exit a parse tree produced by the WhileStatement labeled alternative in DmlParser.statement().
exitWhileStatement(DmlParser.WhileStatementContext) - Method in interface org.apache.sysds.parser.dml.DmlListener
Exit a parse tree produced by the WhileStatement labeled alternative in DmlParser.statement().
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
EXP - org.apache.sysds.common.Builtins
 
EXP - org.apache.sysds.common.Types.OpOp1
 
EXP - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
EXP - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
EXP - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ProbabilityDistributionCode
 
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.
ExpHash - org.apache.sysds.utils.Hash.HashType
 
explain() - Method in class org.apache.sysds.api.jmlc.PreparedScript
Explain the DML/PyDML program and view result as a string.
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(int, boolean) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
Explain tool: prints the hierarchical plan to stdout.
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(CNode) - Static method in class org.apache.sysds.utils.Explain
 
explain(CNode, int) - 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(DMLProgram) - Static method in 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(StatementBlock) - Static method in class org.apache.sysds.utils.Explain
 
explain(Program) - Static method in class org.apache.sysds.utils.Explain
 
explain(ProgramBlock) - Static method in class org.apache.sysds.utils.Explain
 
explain(Program, Explain.ExplainCounts) - Static method in class org.apache.sysds.utils.Explain
 
explain(Instruction) - Static method in class org.apache.sysds.utils.Explain
 
explain(LineageItem) - Static method in class org.apache.sysds.utils.Explain
 
Explain - Class in org.apache.sysds.utils
 
Explain() - Constructor for class org.apache.sysds.utils.Explain
 
EXPLAIN - Static variable in class org.apache.sysds.api.DMLScript
 
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
 
explainFunctionCallGraph(FunctionCallGraph, HashSet<String>, String, int) - 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
 
explainTaskGraph(List<DependencyTask<?>>) - Static method in class org.apache.sysds.runtime.util.DependencyThreadPool
 
explainType - Variable in class org.apache.sysds.api.DMLOptions
 
exponentialMovingAverageImputation(FrameBlock, int, String, int, Double, Double, Double) - Static method in class org.apache.sysds.runtime.util.EMAUtils
 
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, int, FileFormatProperties) - 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).
exportData(String, String, FileFormatProperties) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
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>) - 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 - Variable in class org.apache.sysds.parser.dml.DmlParser.MultiIdExpressionContext
 
expression() - Method in class org.apache.sysds.parser.dml.DmlParser.AccumulatorAssignmentStatementContext
 
expression() - 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() - Method in class org.apache.sysds.parser.dml.DmlParser.BooleanNotExpressionContext
 
expression() - 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() - Method in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateColonExpressionContext
 
expression() - Method in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateSeqExpressionContext
 
expression() - Method in class org.apache.sysds.parser.dml.DmlParser.MatrixMulExpressionContext
 
expression() - Method in class org.apache.sysds.parser.dml.DmlParser.ModIntDivExpressionContext
 
expression() - Method in class org.apache.sysds.parser.dml.DmlParser.MultDivExpressionContext
 
expression() - 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() - 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(int) - Method in class org.apache.sysds.parser.dml.DmlParser.AddSubExpressionContext
 
expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.BooleanAndExpressionContext
 
expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.BooleanOrExpressionContext
 
expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.IndexedExpressionContext
 
expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateColonExpressionContext
 
expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateSeqExpressionContext
 
expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.MatrixMulExpressionContext
 
expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.ModIntDivExpressionContext
 
expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.MultDivExpressionContext
 
expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.MultiIdExpressionContext
 
expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.PowerExpressionContext
 
expression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.RelationalExpressionContext
 
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() - Constructor for class org.apache.sysds.parser.dml.DmlParser.ExpressionContext
 
ExpressionContext(ParserRuleContext, int) - 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
 
EXT_SPACE - Static variable in class org.apache.sysds.runtime.transform.TfUtils
 
EXTERNAL - org.apache.sysds.parser.Expression.FunctCallOp
 
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(IColIndex, MatrixBlock, boolean, int, boolean) - Static method in class org.apache.sysds.runtime.compress.bitmap.BitmapEncoder
Generate uncompressed bitmaps for a set of columns in an uncompressed matrix block.
extractBitmap(IColIndex, MatrixBlock, int, CompressionSettings) - Static method in class org.apache.sysds.runtime.compress.bitmap.BitmapEncoder
 
ExtractBlockForBinaryReblock - Class in org.apache.sysds.runtime.instructions.spark.functions
 
ExtractBlockForBinaryReblock(DataCharacteristics, DataCharacteristics) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.ExtractBlockForBinaryReblock
 
extractCommon(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.AMorphingMMColGroup
extract common value from group and return non morphing group
extractCommon(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
extractCommon(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
extractCommon(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
extractCommon(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
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
 
extractFacts(int, double, double, CompressionSettings) - Method in class org.apache.sysds.runtime.compress.estim.encoding.ConstEncoding
 
extractFacts(int, double, double, CompressionSettings) - Method in class org.apache.sysds.runtime.compress.estim.encoding.DenseEncoding
 
extractFacts(int, double, double, CompressionSettings) - Method in class org.apache.sysds.runtime.compress.estim.encoding.EmptyEncoding
 
extractFacts(int, double, double, CompressionSettings) - Method in interface org.apache.sysds.runtime.compress.estim.encoding.IEncode
Extract the compression facts for this column group.
extractFacts(int, double, double, CompressionSettings) - Method in class org.apache.sysds.runtime.compress.estim.encoding.SparseEncoding
 
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
 
extractMostCommonValueInColumns(MatrixBlock) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupUtils
 
extractTriangular(MatrixBlock, boolean, boolean, boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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.DblArrayCountHashMap
 
extractValues() - Method in class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap
 
extractValues() - Method in class org.apache.sysds.runtime.compress.utils.DoubleCountHashMap
 
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
 
extractValues(double[], IColIndex) - Static method in interface org.apache.sysds.runtime.compress.utils.Util
 

F

F - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ProbabilityDistributionCode
 
FACTOR_NUM_ITERATIONS - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator
 
FACTORING - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PTaskPartitioner
 
FACTORING_CMAX - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PTaskPartitioner
 
FACTORING_CMIN - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PTaskPartitioner
 
FAIR_SCHEDULER_MODE - Static variable in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
 
FALSE - org.apache.sysds.lops.Compression.CompressConfig
 
FALSE - org.apache.sysds.lops.DeCompression.CompressConfig
 
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.iogen
 
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
FastStringTokenizer(String) - Constructor for class org.apache.sysds.runtime.iogen.FastStringTokenizer
 
FCall - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
FCALL - org.apache.sysds.runtime.compress.workload.AWTreeNode.WTNodeType
 
FeatureHash - org.apache.sysds.runtime.transform.encode.ColumnEncoder.EncoderType
 
FeatureHashSparseApplyTask(ColumnEncoderFeatureHash, CacheBlock<?>, MatrixBlock, int) - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderFeatureHash.FeatureHashSparseApplyTask
 
FeatureHashSparseApplyTask(ColumnEncoderFeatureHash, CacheBlock<?>, MatrixBlock, int, int, int) - Constructor for class org.apache.sysds.runtime.transform.encode.ColumnEncoderFeatureHash.FeatureHashSparseApplyTask
 
FED - org.apache.sysds.common.Types.ExecType
 
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_LOCAL_OBJECT - Static variable in class org.apache.sysds.parser.DataExpression
 
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_STATISTICS - Static variable in class org.apache.sysds.api.DMLScript
 
FED_STATISTICS_COUNT - Static variable in class org.apache.sysds.api.DMLScript
 
FED_TYPE - Static variable in class org.apache.sysds.parser.DataExpression
 
FED_WORKER - Static variable in class org.apache.sysds.api.DMLScript
 
Federated - Class in org.apache.sysds.lops
 
Federated - org.apache.sysds.lops.Lop.Type
 
Federated(HashMap<String, Lop>, Types.DataType, Types.ValueType) - Constructor for class org.apache.sysds.lops.Federated
 
FEDERATED - org.apache.sysds.common.Types.FileFormat
 
FEDERATED - org.apache.sysds.common.Types.OpOpData
 
FEDERATED - org.apache.sysds.parser.Expression.DataOp
 
FEDERATED - org.apache.sysds.parser.Statement.PSModeType
 
FEDERATED - org.apache.sysds.runtime.instructions.Instruction.IType
 
FEDERATED_COMPILATION - Static variable in class org.apache.sysds.hops.OptimizerUtils
Compile federated instructions based on input federation state and privacy constraints.
FEDERATED_INST_PREFIX - Static variable in class org.apache.sysds.runtime.instructions.Instruction
 
FEDERATED_MONITOR_FREQUENCY - Static variable in class org.apache.sysds.conf.DMLConfig
Trigger frequency of the collecting and parsing statistics process on registered workers for monitoring in seconds
FEDERATED_PAR_CONN - Static variable in class org.apache.sysds.conf.DMLConfig
 
FEDERATED_PAR_INST - Static variable in class org.apache.sysds.conf.DMLConfig
 
FEDERATED_PLANNER - Static variable in class org.apache.sysds.conf.DMLConfig
 
FEDERATED_READCACHE - Static variable in class org.apache.sysds.conf.DMLConfig
 
FEDERATED_RUNTIME - org.apache.sysds.conf.CompilerConfig.ConfigType
 
FEDERATED_SPECS - Static variable in class org.apache.sysds.hops.OptimizerUtils
 
FEDERATED_TIMEOUT - Static variable in class org.apache.sysds.conf.DMLConfig
 
FEDERATED_VALID_PARAM_NAMES - Static variable in class org.apache.sysds.parser.DataExpression
 
federatedCompilation - Variable in class org.apache.sysds.api.DMLOptions
 
FederatedCompilationTimer - Class in org.apache.sysds.hops.fedplanner
 
FederatedCompilationTimer() - Constructor for class org.apache.sysds.hops.fedplanner.FederatedCompilationTimer
 
FederatedCompilationTimer.TimeEntry - Class in org.apache.sysds.hops.fedplanner
 
FederatedCost - Class in org.apache.sysds.hops.cost
Class storing execution cost estimates for federated executions with cost estimates split into different categories such as compute, read, and transfer cost.
FederatedCost() - Constructor for class org.apache.sysds.hops.cost.FederatedCost
 
FederatedCost(double, double, double, double, double, double) - Constructor for class org.apache.sysds.hops.cost.FederatedCost
 
FederatedCostEstimator - Class in org.apache.sysds.hops.cost
Cost estimator for federated executions with methods and constants for going through DML programs to estimate costs.
FederatedCostEstimator() - Constructor for class org.apache.sysds.hops.cost.FederatedCostEstimator
 
federatedCostInitialized() - Method in class org.apache.sysds.hops.Hop
Check if federated cost has been initialized for this Hop.
FederatedData - Class in org.apache.sysds.runtime.controlprogram.federated
 
FederatedData(Types.DataType, InetSocketAddress, String) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedData
 
FederatedData(Types.DataType, InetSocketAddress, String, long) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedData
 
FederatedData.FederatedRequestEncoder - Class in org.apache.sysds.runtime.controlprogram.federated
 
FederatedDataPartitioner - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
 
FederatedDataPartitioner(Statement.FederatedPSScheme, int) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.FederatedDataPartitioner
 
FederatedLocalData - Class in org.apache.sysds.runtime.controlprogram.federated
 
FederatedLocalData(long, CacheableData<?>) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedLocalData
 
FederatedLookupTable - Class in org.apache.sysds.runtime.controlprogram.federated
Lookup table mapping from a FedUniqueCoordID (funCID) to an ExecutionContextMap (ECM) so that every coordinator can address federated variables with its own local sequential variable IDs.
FederatedLookupTable() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedLookupTable
 
FederatedMonitoringServer - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring
 
FederatedMonitoringServer(int, boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.FederatedMonitoringServer
 
FederatedMonitoringServerHandler - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring
 
FederatedMonitoringServerHandler() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.FederatedMonitoringServerHandler
 
FederatedPlannerCostbased - Class in org.apache.sysds.hops.fedplanner
 
FederatedPlannerCostbased() - Constructor for class org.apache.sysds.hops.fedplanner.FederatedPlannerCostbased
 
FederatedPlannerFedAll - Class in org.apache.sysds.hops.fedplanner
Baseline federated planner that compiles all hops that support federated execution on federated inputs to forced federated operations.
FederatedPlannerFedAll() - Constructor for class org.apache.sysds.hops.fedplanner.FederatedPlannerFedAll
 
FederatedPlannerFedHeuristic - Class in org.apache.sysds.hops.fedplanner
 
FederatedPlannerFedHeuristic() - Constructor for class org.apache.sysds.hops.fedplanner.FederatedPlannerFedHeuristic
 
FederatedPlannerUtils - Class in org.apache.sysds.hops.fedplanner
Utility class for federated planners.
FederatedPlannerUtils() - Constructor for class org.apache.sysds.hops.fedplanner.FederatedPlannerUtils
 
FederatedPSControlThread - Class in org.apache.sysds.runtime.controlprogram.paramserv
 
FederatedPSControlThread(int, String, Statement.PSFrequency, Statement.PSRuntimeBalancing, boolean, int, long, int, ExecutionContext, ParamServer, int, boolean, boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.FederatedPSControlThread
 
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
 
FederatedReadCache - Class in org.apache.sysds.runtime.controlprogram.federated
 
FederatedReadCache() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedReadCache
 
FederatedReadCache.ReadCacheEntry - Class in org.apache.sysds.runtime.controlprogram.federated
Class representing an entry of the federated read cache.
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(FederatedRequest.RequestType, LineageItem, long, Object...) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
 
FederatedRequest.RequestType - Enum in org.apache.sysds.runtime.controlprogram.federated
 
FederatedRequestEncoder() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedData.FederatedRequestEncoder
 
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(FederatedResponse.ResponseType, Object[], LineageItem) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedResponse
 
FederatedResponse(FederatedResponse.ResponseType, Object, LineageItem) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedResponse
 
FederatedResponse.ResponseType - Enum in org.apache.sysds.runtime.controlprogram.federated
 
FederatedResponseEncoder() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedWorker.FederatedResponseEncoder
 
FederatedStatistics - Class in org.apache.sysds.runtime.controlprogram.federated
 
FederatedStatistics() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
FederatedStatistics.FedStatsCollectFunction - Class in org.apache.sysds.runtime.controlprogram.federated
 
FederatedStatistics.FedStatsCollection - Class 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, boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedWorker
 
FederatedWorker.FederatedResponseEncoder - Class in org.apache.sysds.runtime.controlprogram.federated
 
FederatedWorkerHandler - Class in org.apache.sysds.runtime.controlprogram.federated
Note: federated worker handler created for every command; and concurrent parfor threads at coordinator need separate execution contexts at the federated sites too
FederatedWorkerHandler(FederatedLookupTable, FederatedReadCache, FederatedWorkloadAnalyzer) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedWorkerHandler
Create a Federated Worker Handler.
FederatedWorkerHandler(FederatedLookupTable, FederatedReadCache, FederatedWorkloadAnalyzer, Timing) - 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
Create new instance of FederatedWorkerHandlerException with a message and a throwable representing the original cause of the exception.
FederatedWorkloadAnalyzer - Class in org.apache.sysds.runtime.controlprogram.federated
 
FederatedWorkloadAnalyzer() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedWorkloadAnalyzer
 
federateFrame(FrameObject, List<Pair<FederatedRange, FederatedData>>) - Static method in class org.apache.sysds.runtime.instructions.fed.InitFEDInstruction
 
federateFrame(FrameObject, List<Pair<FederatedRange, FederatedData>>, CacheBlock<?>[]) - Static method in class org.apache.sysds.runtime.instructions.fed.InitFEDInstruction
 
federateLocalData(CacheableData<?>) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
federateMatrix(CacheableData<?>, List<Pair<FederatedRange, FederatedData>>) - Static method in class org.apache.sysds.runtime.instructions.fed.InitFEDInstruction
 
federateMatrix(CacheableData<?>, List<Pair<FederatedRange, FederatedData>>, CacheBlock<?>[]) - Static method in class org.apache.sysds.runtime.instructions.fed.InitFEDInstruction
 
FederationMap - Class in org.apache.sysds.runtime.controlprogram.federated
 
FederationMap(long, List<Pair<FederatedRange, FederatedData>>) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
FederationMap(long, List<Pair<FederatedRange, FederatedData>>, FTypes.FType) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
FederationMap(List<Pair<FederatedRange, FederatedData>>) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
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.FederatedOutput - Enum 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
 
fedMonitoring - Variable in class org.apache.sysds.api.DMLOptions
 
fedMonitoringAddress - Variable in class org.apache.sysds.api.DMLOptions
 
fedMonitoringPort - Variable in class org.apache.sysds.api.DMLOptions
 
fedStats - Variable in class org.apache.sysds.api.DMLOptions
 
FedStatsCollectFunction() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics.FedStatsCollectFunction
 
FedStatsCollection() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics.FedStatsCollection
 
fedStatsCount - Variable in class org.apache.sysds.api.DMLOptions
 
fedWorker - Variable in class org.apache.sysds.api.DMLOptions
 
fedWorkerPort - Variable in class org.apache.sysds.api.DMLOptions
 
FF_PREDICT - org.apache.sysds.common.Builtins
 
FF_TRAIN - org.apache.sysds.common.Builtins
 
FIFO - org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer.RPolicy
 
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
 
FileFormatProperties(int) - 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) - Constructor for class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
 
FileFormatPropertiesCSV(boolean, String, boolean, double, String) - Constructor for class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
 
FileFormatPropertiesHDF5 - Class in org.apache.sysds.runtime.io
 
FileFormatPropertiesHDF5() - Constructor for class org.apache.sysds.runtime.io.FileFormatPropertiesHDF5
 
FileFormatPropertiesHDF5(String) - Constructor for class org.apache.sysds.runtime.io.FileFormatPropertiesHDF5
 
FileFormatPropertiesLIBSVM - Class in org.apache.sysds.runtime.io
 
FileFormatPropertiesLIBSVM() - Constructor for class org.apache.sysds.runtime.io.FileFormatPropertiesLIBSVM
 
FileFormatPropertiesLIBSVM(String, String) - Constructor for class org.apache.sysds.runtime.io.FileFormatPropertiesLIBSVM
 
FileFormatPropertiesLIBSVM(String, String, boolean) - Constructor for class org.apache.sysds.runtime.io.FileFormatPropertiesLIBSVM
 
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
 
filePath - Variable in class org.apache.sysds.api.DMLOptions
 
filePath - Variable in class org.apache.sysds.parser.dml.DmlParser.ImportStatementContext
 
fill(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Fill the map with a given value.
fill(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
fill(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
fill(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
fill(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
fill(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
fill(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToUByte
 
fill(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
fill(Boolean) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
fill(Boolean) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
fill(Character) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
fill(Double) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
fill(Float) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
fill(Integer) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
fill(Long) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
fill(String) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
fill the entire array with specific value.
fill(String) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
fill(String) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
fill(String) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
fill(String) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
fill(String) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
fill(String) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
fill(String) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
fill(String) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
fill(String) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
fill(T) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
fill the entire array with specific value.
fill(T) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
FILL_VALUE_MESSAGE - Static variable in class org.apache.sysds.runtime.io.hdf5.H5Constants
 
fillBias(MatrixBlock, double[], int, int, int, int, int) - Static method in class org.apache.sysds.runtime.util.DnnUtils
 
fillData(ByteBuffer, double[]) - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
filter(IndexRange) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
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
 
findAtValue(ValueTrimFormat, int, int) - Method in class org.apache.sysds.runtime.iogen.RawRow
 
findAtValue(ValueTrimFormat, int, int, boolean) - Method in class org.apache.sysds.runtime.iogen.RawRow
 
findClass(String) - Method in class org.apache.sysds.runtime.codegen.ByteClassLoader
 
findCoCodesByPartitioning(AComEst, CompressedSizeInfo, int, ACostEstimate, CompressionSettings) - Static method in interface org.apache.sysds.runtime.compress.cocode.CoCoderFactory
Main entry point of CoCode.
findCtableOperationByInputDataTypes(Types.DataType, Types.DataType, Types.DataType) - Static method in class org.apache.sysds.lops.Ctable
 
findDominantPattern(Map<String, Double>, double) - Static method in class org.apache.sysds.runtime.util.DMVUtils
 
findEmpty(boolean[]) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Find the empty rows, it is assumed that the input is to be only modified to set variables to true.
findEmptyInverse(boolean[]) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Find the filled rows, it is assumed that the input i to be only modified to set variables to true;
findEmptyInverse(boolean[]) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
findIndex(int) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.ArrayIndex
 
findIndex(int) - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex
Find the index of the value given return negative if non existing.
findIndex(int) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.RangeIndex
 
findIndex(int) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.SingleIndex
 
findIndex(int) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.TwoIndex
 
findRemovableConditionalPatternInOuterProduct(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
findSequenceValues(ArrayList<ValueTrimFormat>, int, boolean) - Method in class org.apache.sysds.runtime.iogen.RawRow
 
findValue(ValueTrimFormat, boolean) - Method in class org.apache.sysds.runtime.iogen.RawRow
 
findValue(ValueTrimFormat, boolean, boolean) - Method in class org.apache.sysds.runtime.iogen.RawRow
 
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
 
firstOccurrenceOfNR(LineageItem, int) - Static method in class org.apache.sysds.runtime.lineage.LineageDebugger
 
FIT_PIPELINE - org.apache.sysds.common.Builtins
 
FIX_INVALID_LENGTHS - org.apache.sysds.common.Builtins
 
FIX_INVALID_LENGTHS_APPLY - org.apache.sysds.common.Builtins
 
FIXED - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PTaskPartitioner
 
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
 
FloatArray - Class in org.apache.sysds.runtime.frame.data.columns
 
FloatArray(float[]) - Constructor for class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
floatArrayCost(long) - Static method in class org.apache.sysds.utils.MemoryEstimates
Get the worst case memory usage of an array of integers.
FLOATING_POINT_PRECISION - Static variable in class org.apache.sysds.api.DMLScript
 
FLOATING_POINT_PRECISION - Static variable in class org.apache.sysds.conf.DMLConfig
 
floatPattern - Static variable in interface org.apache.sysds.runtime.frame.data.lib.FrameUtil
 
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
FLOOR - org.apache.sysds.common.Builtins
 
FLOOR - org.apache.sysds.common.Types.OpOp1
 
FLOOR - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
FLOOR - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
flush() - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
 
flushBufferToBinaryBlocks() - Method in class org.apache.sysds.runtime.instructions.spark.data.ReblockBuffer
 
flushBufferToBinaryBlocks(ArrayList<Pair<Long, FrameBlock>>) - Method in class org.apache.sysds.runtime.instructions.spark.data.FrameReblockBuffer
 
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.
FOR - org.apache.sysds.runtime.compress.workload.AWTreeNode.WTNodeType
 
FOR - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.NodeType
 
forbidden(String) - Static method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.Response
 
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.
forceEviction() - Static method in class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
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
 
FOUT - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FederatedOutput
 
FP32 - org.apache.sysds.common.Types.ValueType
 
FP32 - org.apache.sysds.runtime.frame.data.columns.ArrayFactory.FrameArrayType
 
FP64 - org.apache.sysds.common.Types.ValueType
 
FP64 - org.apache.sysds.runtime.frame.data.columns.ArrayFactory.FrameArrayType
 
FP64_DICT - org.apache.sysds.runtime.compress.colgroup.dictionary.DictionaryFactory.Type
 
Frame - Class in org.apache.sysds.api.mlcontext
Frame encapsulates a SystemDS frame.
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(Dataset<Row>) - 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>, FrameMetadata) - Constructor for class org.apache.sysds.api.mlcontext.Frame
Convert a Spark DataFrame to a SystemDS binary-block representation.
Frame(FrameObject, SparkExecutionContext) - Constructor for class org.apache.sysds.api.mlcontext.Frame
 
FRAME - org.apache.sysds.common.Types.DataType
 
FRAME - org.apache.sysds.parser.Expression.DataOp
 
FRAME_DATA_TYPE - Static variable in class org.apache.sysds.parser.Statement
 
FRAME_OPCODE - Static variable in class org.apache.sysds.lops.DataGen
 
FRAME_ROW_REPLICATE - org.apache.sysds.common.Builtins
 
FRAME_ROW_REPLICATE - org.apache.sysds.common.Types.OpOp2
 
FRAME_ROW_REPLICATE - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
FRAME_SORT - org.apache.sysds.common.Builtins
 
FRAME_VALID_PARAM_NAMES - Static variable in class org.apache.sysds.parser.DataExpression
 
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.frame.data
 
FrameBlock() - Constructor for class org.apache.sysds.runtime.frame.data.FrameBlock
 
FrameBlock(int, Types.ValueType) - Constructor for class org.apache.sysds.runtime.frame.data.FrameBlock
 
FrameBlock(Types.ValueType[]) - Constructor for class org.apache.sysds.runtime.frame.data.FrameBlock
 
FrameBlock(Types.ValueType[], int) - Constructor for class org.apache.sysds.runtime.frame.data.FrameBlock
 
FrameBlock(Types.ValueType[], String[]) - Constructor for class org.apache.sysds.runtime.frame.data.FrameBlock
 
FrameBlock(Types.ValueType[], String[][]) - Constructor for class org.apache.sysds.runtime.frame.data.FrameBlock
 
FrameBlock(Types.ValueType[], String[], int) - Constructor for class org.apache.sysds.runtime.frame.data.FrameBlock
 
FrameBlock(Types.ValueType[], String[], String[][]) - Constructor for class org.apache.sysds.runtime.frame.data.FrameBlock
allocate a FrameBlock with the given data arrays.
FrameBlock(Types.ValueType[], String[], ColumnMetadata[], Array<?>[]) - Constructor for class org.apache.sysds.runtime.frame.data.FrameBlock
 
FrameBlock(Types.ValueType[], String, int) - Constructor for class org.apache.sysds.runtime.frame.data.FrameBlock
FrameBlock constructor with constant
FrameBlock(FrameBlock) - Constructor for class org.apache.sysds.runtime.frame.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.FrameMapFunction - Class in org.apache.sysds.runtime.frame.data
 
frameBlockToFrameObject(String, FrameBlock, FrameMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
Convert a FrameBlock to a FrameObject.
FrameCompressionStatistics - Class in org.apache.sysds.runtime.frame.data.compress
 
FrameCompressionStatistics() - Constructor for class org.apache.sysds.runtime.frame.data.compress.FrameCompressionStatistics
 
FrameFormat - Enum in org.apache.sysds.api.mlcontext
FrameFormat represents the different frame formats supported by the MLContext API.
FrameFromMatrixBlock - Class in org.apache.sysds.runtime.frame.data.lib
 
FrameGenerateReader - Class in org.apache.sysds.runtime.iogen
 
FrameGenerateReader(CustomProperties) - Constructor for class org.apache.sysds.runtime.iogen.FrameGenerateReader
 
FrameGenerateReader.FrameReaderRowIrregular - Class in org.apache.sysds.runtime.iogen
 
FrameGenerateReader.FrameReaderRowRegularColIrregular - Class in org.apache.sysds.runtime.iogen
 
FrameGenerateReader.FrameReaderRowRegularColRegular - Class in org.apache.sysds.runtime.iogen
 
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.
FRAMEINIT - org.apache.sysds.common.Types.OpOpDG
 
FrameLibAppend - Class in org.apache.sysds.runtime.frame.data.lib
 
FrameLibAppend() - Constructor for class org.apache.sysds.runtime.frame.data.lib.FrameLibAppend
 
FrameLibApplySchema - Class in org.apache.sysds.runtime.frame.data.lib
 
FrameLibCompress - Class in org.apache.sysds.runtime.frame.data.lib
 
FrameLibCompress() - Constructor for class org.apache.sysds.runtime.frame.data.lib.FrameLibCompress
 
FrameLibDetectSchema - Class in org.apache.sysds.runtime.frame.data.lib
 
FrameLibRemoveEmpty - Class in org.apache.sysds.runtime.frame.data.lib
 
FrameMapFunction() - Constructor for class org.apache.sysds.runtime.frame.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(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(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(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(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(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) - 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, 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(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(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, 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, 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(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, 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, 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, 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, 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, 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, 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, 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(FrameSchema) - Constructor for class org.apache.sysds.api.mlcontext.FrameMetadata
Constructor to create a FrameMetadata object based on frame schema.
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.
FrameMetadata(DataCharacteristics) - Constructor for class org.apache.sysds.api.mlcontext.FrameMetadata
Constructor to create a FrameMetadata object based on 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
 
FrameReaderMapping(String, FrameBlock) - Constructor for class org.apache.sysds.runtime.iogen.ReaderMapping.FrameReaderMapping
 
FrameReaderProto - Class in org.apache.sysds.runtime.io
 
FrameReaderProto() - Constructor for class org.apache.sysds.runtime.io.FrameReaderProto
 
FrameReaderRowIrregular(CustomProperties) - Constructor for class org.apache.sysds.runtime.iogen.FrameGenerateReader.FrameReaderRowIrregular
 
FrameReaderRowRegularColIrregular(CustomProperties) - Constructor for class org.apache.sysds.runtime.iogen.FrameGenerateReader.FrameReaderRowRegularColIrregular
 
FrameReaderRowRegularColRegular(CustomProperties) - Constructor for class org.apache.sysds.runtime.iogen.FrameGenerateReader.FrameReaderRowRegularColRegular
 
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
 
frameRowReplication(FrameBlock) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
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(String) - Constructor for class org.apache.sysds.api.mlcontext.FrameSchema
Constructor that specifies the schema as a comma-separated string.
FrameSchema(List<Types.ValueType>) - Constructor for class org.apache.sysds.api.mlcontext.FrameSchema
Constructor that specifies the schema as a list of ValueType values.
FrameUtil - Interface in org.apache.sysds.runtime.frame.data.lib
 
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
 
FrameWriterCompressed - Class in org.apache.sysds.runtime.io
 
FrameWriterCompressed(boolean) - Constructor for class org.apache.sysds.runtime.io.FrameWriterCompressed
 
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(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.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(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
 
FREQUENCYENCODE - org.apache.sysds.common.Builtins
 
FREQUENCYENCODEAPPLY - org.apache.sysds.common.Builtins
 
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(List<Pair<Long, FrameBlock>>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
 
fromIndexedFrameBlock(Pair<Long, FrameBlock>) - 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
 
fromIndexedMatrixBlock(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
 
fromIndexedMatrixBlockToPair(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
 
FTypes - Class in org.apache.sysds.hops.fedplanner
 
FTypes() - Constructor for class org.apache.sysds.hops.fedplanner.FTypes
 
FTypes.AlignType - Enum in org.apache.sysds.hops.fedplanner
 
FTypes.FederatedPlanner - Enum in org.apache.sysds.hops.fedplanner
 
FTypes.FPartitioning - Enum in org.apache.sysds.hops.fedplanner
 
FTypes.FReplication - Enum in org.apache.sysds.hops.fedplanner
 
FTypes.FType - Enum in org.apache.sysds.hops.fedplanner
 
FULL - org.apache.sysds.hops.fedplanner.FTypes.AlignType
 
FULL - org.apache.sysds.hops.fedplanner.FTypes.FReplication
 
FULL - org.apache.sysds.hops.fedplanner.FTypes.FType
 
FULL_AGG - org.apache.sysds.runtime.codegen.SpoofCellwise.CellType
 
FULL_AGG - org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
 
FULL_T - org.apache.sysds.hops.fedplanner.FTypes.AlignType
 
FUNCCALL - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.NodeType
 
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 - org.apache.sysds.lops.Lop.Type
 
FunctionCallCP(ArrayList<Lop>, String, String, String[], String[], ArrayList<Hop>, boolean, Types.ExecType) - Constructor for class org.apache.sysds.lops.FunctionCallCP
 
FunctionCallCP(ArrayList<Lop>, String, String, String[], String[], Types.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
 
FunctionCallCPInstruction(String, String, boolean, CPOperand[], LineageItem[], List<String>, List<String>, String) - Constructor for class org.apache.sysds.runtime.instructions.cp.FunctionCallCPInstruction
 
FunctionCallCPSingle - org.apache.sysds.lops.Lop.Type
 
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[], boolean) - Constructor for class org.apache.sysds.hops.FunctionOp
 
FunctionOp(FunctionOp.FunctionType, String, String, String[], List<Hop>, String[], boolean, boolean) - Constructor for class org.apache.sysds.hops.FunctionOp
 
FunctionOp(FunctionOp.FunctionType, String, String, String[], List<Hop>, String[], ArrayList<Hop>) - Constructor for class org.apache.sysds.hops.FunctionOp
 
FunctionOp.FunctionType - Enum in org.apache.sysds.hops
 
FUNCTIONOUTPUT - org.apache.sysds.common.Types.OpOpData
 
FunctionProgramBlock - Class in org.apache.sysds.runtime.controlprogram
 
FunctionProgramBlock(Program, List<DataIdentifier>, List<DataIdentifier>) - Constructor for class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
 
functionStatement - Variable in class org.apache.sysds.parser.dml.DmlParser.ProgramrootContext
 
functionStatement() - Method in class org.apache.sysds.parser.dml.DmlParser
 
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() - Constructor for class org.apache.sysds.parser.dml.DmlParser.FunctionStatementContext
 
FunctionStatementContext(ParserRuleContext, int) - 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
 
FUSE_ALL - org.apache.sysds.hops.codegen.SpoofCompiler.PlanSelector
 
FUSE_COST_BASED - org.apache.sysds.hops.codegen.SpoofCompiler.PlanSelector
 
FUSE_COST_BASED_V2 - org.apache.sysds.hops.codegen.SpoofCompiler.PlanSelector
 
FUSE_NO_REDUNDANCY - org.apache.sysds.hops.codegen.SpoofCompiler.PlanSelector
 

G

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_MAX - Static variable in class org.apache.sysds.parser.Statement
 
GAGG_FN_MEAN - Static variable in class org.apache.sysds.parser.Statement
 
GAGG_FN_MIN - 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
 
GAlignedAppend - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
GAppend - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
GARCH - org.apache.sysds.common.Builtins
 
gatherMemStats(boolean) - Method in class org.apache.sysds.api.jmlc.Connection
Sets a boolean flag indicating if memory profiling statistics should be gathered.
GAUSSIAN_CLASSIFIER - org.apache.sysds.common.Builtins
 
genColsIndices(int) - Static method in interface org.apache.sysds.runtime.compress.utils.Util
 
genColsIndices(int, int) - Static method in interface org.apache.sysds.runtime.compress.utils.Util
 
genColsIndicesOffset(int, int) - Static method in interface org.apache.sysds.runtime.compress.utils.Util
 
GENERAL - org.apache.sysds.runtime.io.FileFormatPropertiesMM.MMSymmetry
 
generateA() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.HEParamServer
 
generateA() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.homomorphicEncryption.SEALServer
this generates the a constant.
generateA(long) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.NativeHEHelper
this generates the a constant.
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(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
 
generateCodeFromProgramBlock(ProgramBlock) - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
 
generateCodeFromStatementBlock(StatementBlock) - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
 
generateMonitoringKey() - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.CoordinatorModel
 
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.
generatePartialPublicKey() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.homomorphicEncryption.SEALClient
generates a partial public key stores a partial private key corresponding to the partial public key in ctx
generatePartialPublicKey(long) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.NativeHEHelper
generates a partial public key stores a partial private key corresponding to the partial public key in client
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
generateRandomFrameBlock(int, int, Types.ValueType[], Random) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
Generates a random FrameBlock with given parameters.
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
 
generateRandomValueFromValueType(Types.ValueType, Random) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
Generates a random value for a given Value Type
GenerateReader - Class in org.apache.sysds.runtime.iogen
 
GenerateReader(SampleProperties) - Constructor for class org.apache.sysds.runtime.iogen.GenerateReader
 
GenerateReader.GenerateReaderFrame - Class in org.apache.sysds.runtime.iogen
 
GenerateReader.GenerateReaderMatrix - Class in org.apache.sysds.runtime.iogen
 
GenerateReaderFrame(String, FrameBlock) - Constructor for class org.apache.sysds.runtime.iogen.GenerateReader.GenerateReaderFrame
 
GenerateReaderFrame(SampleProperties) - Constructor for class org.apache.sysds.runtime.iogen.GenerateReader.GenerateReaderFrame
 
GenerateReaderMatrix(String, MatrixBlock) - Constructor for class org.apache.sysds.runtime.iogen.GenerateReader.GenerateReaderMatrix
 
GenerateReaderMatrix(SampleProperties) - Constructor for class org.apache.sysds.runtime.iogen.GenerateReader.GenerateReaderMatrix
 
generateReplicationMatrix(int, int, long) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
Generates a matrix which when left multiplied with the input matrix will replicate n data rows
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.
generateSubsampleMatrix(int, int, long) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
Generates a matrix which when left multiplied with the input matrix will subsample
generateUniqueSeedPath(String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDatagen
 
GENERIC - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.NodeType
 
GENERIC_SUCCESS_MSG - Static variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.Constants
 
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.
genUncompressedCompressedMatrixBlock(MatrixBlock) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlockFactory
Generate a CompressedMatrixBlock Object that contains a single uncompressed matrix block column group.
get() - Method in enum org.apache.sysds.parser.BuiltinConstant
 
get() - Method in class org.apache.sysds.runtime.compress.io.CompressedWriteBlock
 
get() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedReadCache.ReadCacheEntry
 
get() - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Get the underlying array out of the column Group, it is the responsibility of the caller to know what type it is.
get() - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
get() - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
get() - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
get() - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
get() - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
get() - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
get() - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
get() - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
get() - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
get(boolean, boolean) - Static method in enum org.apache.sysds.hops.codegen.SpoofCompiler.PlanCachePolicy
 
get(double) - Method in class org.apache.sysds.runtime.compress.utils.DoubleCountHashMap
Get the value on a key, if the key is not inside a NullPointerException is thrown.
get(double) - Method in class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap
 
get(int) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.ArrayIndex
 
get(int) - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex
Get the index at a specific location, Note that many of the underlying implementations does not throw exceptions on indexes that are completely wrong, so all implementations that use this index should always be well behaved.
get(int) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.RangeIndex
 
get(int) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.SingleIndex
 
get(int) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.TwoIndex
 
get(int) - Method in class org.apache.sysds.runtime.compress.SingletonLookupHashMap
 
get(int) - Method in class org.apache.sysds.runtime.compress.utils.IntArrayList
 
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) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
get(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
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.frame.data.columns.Array
Get the value at a given index.
get(int) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
get(int) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
get(int) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
get(int) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
get(int) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
get(int) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
get(int) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
get(int) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
get(int) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
get(int) - Method in class org.apache.sysds.runtime.lineage.BooleanArray32
 
get(int) - Static method in class org.apache.sysds.runtime.util.CommonThreadPool
 
get(int[]) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
 
get(int[]) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
 
get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlock
Get the value of a given cell
get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
 
get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
 
get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
 
get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
 
get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
 
get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
 
get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
 
get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
 
get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
 
get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
 
get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
 
get(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlockString
 
get(int[]) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
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(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Get the value at a global row/column position.
get(int, int) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
 
get(int, int) - Method in interface org.apache.sysds.runtime.data.Block
Get value of matrix cell (r,c).
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, int) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
 
get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
 
get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
 
get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
 
get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
 
get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
 
get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
 
get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
 
get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
 
get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
 
get(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
 
get(int, 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, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
get(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
get(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
 
get(int, int) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
get(int, int) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
Gets a boxed object of the value in position (r,c).
get(long) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
 
get(long) - Method in class org.apache.sysds.runtime.controlprogram.federated.ExecutionContextMap
 
get(long, TemplateBase.TemplateType) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
 
get(Long) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.CoordinatorService
 
get(Long) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.WorkerService
 
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) - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
Retrieves the data object given its name.
get(String) - Method in class org.apache.sysds.runtime.lineage.Lineage
 
get(String) - Method in class org.apache.sysds.runtime.lineage.LineageMap
 
get(String, boolean) - Static method in enum org.apache.sysds.common.Builtins
 
get(String, boolean) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedReadCache
Get the data from the ReadCacheEntry corresponding to the specified filename, if the data from this filename has already been read.
get(Future<T>) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
 
get(Types.DataType, Types.FileFormat) - Static method in class org.apache.sysds.runtime.io.InputOutputInfo
 
get(ColIndexes) - Method in class org.apache.sysds.runtime.compress.cocode.Memorizer
 
get(DblArray) - Method in class org.apache.sysds.runtime.compress.utils.DblArrayCountHashMap
Get the value on a key, if the key is not inside a NullPointerException is thrown.
get(DblArray) - Method in class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap
 
get(Request, Long) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.CoordinatorController
 
get(Request, Long) - Method in interface org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.IController
 
get(Request, Long) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.StatisticsController
 
get(Request, Long) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.WorkerController
 
get(CPOperand) - Method in class org.apache.sysds.runtime.lineage.Lineage
 
get(CPOperand) - Method in class org.apache.sysds.runtime.lineage.LineageMap
 
get(Operator) - Static method in class org.apache.sysds.runtime.matrix.data.sketch.MatrixSketchFactory
 
get(JSONObject, String) - Static method in class org.apache.sysds.utils.JSONHelper
 
GET_ACCURACY - org.apache.sysds.common.Builtins
 
GET_VAR - org.apache.sysds.runtime.controlprogram.federated.FederatedRequest.RequestType
 
getAbstractPlanMapping() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTree
 
getACopy() - Method in class org.apache.sysds.runtime.iogen.ValueTrimFormat
 
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
 
getAddress() - Method in class org.apache.sysds.runtime.io.hdf5.H5SymbolTableEntry
 
getAddress() - Method in class org.apache.sysds.runtime.io.hdf5.message.H5DataLayoutMessage
 
getAddressOfDataSegment() - Method in class org.apache.sysds.runtime.io.hdf5.H5LocalHeap
 
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
 
getAggInst() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamServer
 
getAggOp() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
 
getAggOp() - Method in class org.apache.sysds.runtime.codegen.SpoofCellwise
 
getAggOp(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
 
getAggOp(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
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
 
getAggregationType(AggregateBinaryCPInstruction, ExecutionContext) - Static method in enum org.apache.sysds.runtime.privacy.propagation.OperatorType
Returns the operator type of AggregateBinaryCPInstruction based on the input data characteristics and the transpose.
getAggregationType(MMChainCPInstruction, ExecutionContext) - Static method in enum org.apache.sysds.runtime.privacy.propagation.OperatorType
Returns the operator type of MMChainCPInstruction based on the input data characteristics.
getAggregationType(MMTSJCPInstruction, ExecutionContext) - Static method in enum org.apache.sysds.runtime.privacy.propagation.OperatorType
Returns the operator type of MMTSJCPInstruction based on the input data characteristics and the MMTSJType.
getAggType() - Method in class org.apache.sysds.lops.Lop
Method to get aggregate type if applicable.
getAggType() - Method in class org.apache.sysds.lops.MapMult
 
getAggType() - Method in class org.apache.sysds.lops.MMCJ
 
getAggType() - Method in class org.apache.sysds.lops.PartialAggregate
 
getAggType() - Method in class org.apache.sysds.lops.RightIndex
 
getAggType() - Method in class org.apache.sysds.runtime.instructions.spark.AggregateUnarySPInstruction
 
getAggType() - Method in class org.apache.sysds.runtime.instructions.spark.CpmmSPInstruction
 
getAggType() - Method in class org.apache.sysds.runtime.instructions.spark.MapmmSPInstruction
 
getAlias() - Method in enum org.apache.sysds.common.Builtins
 
getAlignedBlockSizes(int, int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
getAll() - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.CoordinatorService
 
getAll() - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.WorkerService
 
getAll(Long, StatisticsOptions) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.StatisticsService
 
getAll(Request) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.CoordinatorController
 
getAll(Request) - Method in interface org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.IController
 
getAll(Request) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.StatisticsController
 
getAll(Request) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.WorkerController
 
getAllCandidateWorkloads(DMLProgram) - Static method in class org.apache.sysds.runtime.compress.workload.WorkloadAnalyzer
 
getAllCombinations(List<List<FTypes.FType>>) - Method in class org.apache.sysds.hops.fedplanner.FederatedPlannerCostbased
 
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
 
getAllEntities(Class<T>) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.DerbyRepository
 
getAllEntities(Class<T>) - Method in interface org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.IRepository
 
getAllEntitiesByField(String, Object, Class<T>) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.DerbyRepository
 
getAllEntitiesByField(String, Object, Class<T>) - Method in interface org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.IRepository
 
getAllEntitiesByField(String, Object, Class<T>, int) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.DerbyRepository
 
getAllEntitiesByField(String, Object, Class<T>, int) - Method in interface org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.IRepository
 
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
 
getAppendType() - Method in class org.apache.sysds.runtime.instructions.cp.AppendCPInstruction
 
getApplyTasks(CacheBlock<?>, MatrixBlock, int) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
getApplyTasks(CacheBlock<?>, MatrixBlock, int) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
getApplyTasks(DocumentRepresentation[], FrameBlock) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplier
 
getArity() - Method in class org.apache.sysds.runtime.instructions.gpu.BuiltinUnaryGPUInstruction
 
getAsByteArray() - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Return the current allocated Array as a byte[], this is used to serialize the allocated Arrays out to the PythonAPI.
getAsByteArray() - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
getAsByteArray() - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
getAsByteArray() - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
getAsByteArray() - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
getAsByteArray() - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
getAsByteArray() - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
getAsByteArray() - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
getAsByteArray() - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
getAsByteArray() - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
getAsciiAtIdx(String, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
getAsDouble(int) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
 
getAsDouble(int) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
getAsDouble(int) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
getAsDouble(int) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
getAsDouble(int) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
getAsDouble(int) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
getAsDouble(int) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
getAsDouble(int) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
getAsDouble(int) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
getAsDouble(int) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
getAsNaNDouble(int) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
 
getAsNaNDouble(int) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
getAsNaNDouble(int) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
getAsyncBroadcastCount() - Static method in class org.apache.sysds.utils.stats.SparkStatistics
 
getAsyncPrefetchCount() - Static method in class org.apache.sysds.utils.stats.SparkStatistics
 
getAsyncSparkOpCount() - Static method in class org.apache.sysds.utils.stats.SparkStatistics
 
getasyncTriggerCheckpointCount() - Static method in class org.apache.sysds.utils.stats.SparkStatistics
 
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.
getBackward(MatrixObject, ArrayList<Data>, ExecutionContext) - Static method in class org.apache.sysds.runtime.util.AutoDiff
 
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
 
getBestCompressionType(CompressionSettings) - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
 
getBinaryAccessType(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixBincell
 
getBinaryAccessTypeExtended(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
 
getBinMaxs() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
getBinMethod() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
getBinMins() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
getBitOffset() - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
getBitPrecision() - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
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[]) - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
 
getBlock(int[]) - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBroadcast
 
getBlock(int, 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
 
getBlockBounds(TensorIndexes, long[], int, int[], int[]) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
getBlockLength() - Method in class org.apache.sysds.runtime.instructions.spark.ReblockSPInstruction
 
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.CacheableData
 
getBlocksize() - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
 
getBlocksize() - Method in class org.apache.sysds.runtime.controlprogram.federated.MatrixLineagePair
 
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.io.FileFormatProperties
 
getBlocksize() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
 
getBlockSizes(int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
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
 
getBody() - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.Request
 
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() - Method in class org.apache.sysds.hops.LiteralOp
 
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
 
getBooleanValue(String) - Method in class org.apache.sysds.conf.DMLConfig
 
getBooleanValue(LiteralOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
getBooleanValueSafe(LiteralOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
getBoundOutputParamNames() - Method in class org.apache.sysds.runtime.instructions.cp.FunctionCallCPInstruction
 
getBroadcast() - Method in class org.apache.sysds.runtime.instructions.spark.CumulativeOffsetSPInstruction
 
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
 
getBroadcastInput() - Method in class org.apache.sysds.lops.AppendM
 
getBroadcastInput() - Method in class org.apache.sysds.lops.Binary
 
getBroadcastInput() - Method in class org.apache.sysds.lops.BinaryM
 
getBroadcastInput() - Method in class org.apache.sysds.lops.LeftIndex
 
getBroadcastInput() - Method in class org.apache.sysds.lops.Lop
Method to get the input to be broadcast.
getBroadcastInput() - Method in class org.apache.sysds.lops.MapMult
 
getBroadcastInput() - Method in class org.apache.sysds.lops.MapMultChain
 
getBroadcastInput() - Method in class org.apache.sysds.lops.PMMJ
 
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
 
getbTreeAddress() - Method in class org.apache.sysds.runtime.io.hdf5.H5SymbolTableEntry
 
getbTreeAddress() - Method in class org.apache.sysds.runtime.io.hdf5.message.H5SymbolTableMessage
 
getBufferedInputStream() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
getBufferedOutputStream() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
getBufferPoolLimit() - Static method in class org.apache.sysds.hops.OptimizerUtils
Returns buffer pool size as set in the config
getBuildTask(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
getBuildTask(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
getBuildTask(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
getBuildTasks(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
getBuildTasks(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
getBuildTasks(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
getBuildTasks(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderFeatureHash
 
getBuildTasks(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderPassThrough
 
getBuildTasks(CacheBlock<?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderUDF
 
getBuildTasks(FrameBlock) - Method in class org.apache.sysds.runtime.transform.tokenize.Tokenizer
 
getBuildTasks(DocumentRepresentation[]) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplier
 
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
 
getBuiltinFunctionDictionary() - Method in class org.apache.sysds.parser.DMLProgram
 
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
 
getCache() - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Get the current cached element.
getCacheableData(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
getCacheableData(CPOperand) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
getCacheBlockSize(CacheBlock<?>) - Static method in class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
 
getCacheBlockSize(CacheBlock<?>) - Static method in class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
 
getCachedDecompressed() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
Get the cached decompressed matrix (if it exists otherwise null).
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
 
getCacheLineage() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
getCachePolicy() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
 
getCacheStatus() - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
 
getCacheType() - Method in class org.apache.sysds.runtime.io.hdf5.H5SymbolTableEntry
 
getCacheType() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
 
getCalledFunctions(String) - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
Returns all functions called from the given function.
getCalledFunctions(String, 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
 
getCBind() - Method in class org.apache.sysds.runtime.instructions.spark.AppendSPInstruction
 
getCellType() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
 
getCellType() - Method in class org.apache.sysds.runtime.codegen.SpoofCellwise
 
getCellType(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
getChannelNames() - Method in class org.apache.sysds.parser.dml.DmlLexer
 
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
 
getChecksum(int) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
 
getChildAddresses() - Method in class org.apache.sysds.runtime.io.hdf5.H5BTree
 
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
 
getChildNodes() - Method in class org.apache.sysds.runtime.compress.workload.AWTreeNode
 
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
 
getClassBits() - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
getClassCompile() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
getClassCompileTime() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
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
 
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(CM) - Static method in class org.apache.sysds.runtime.functionobjects.CM
 
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
 
getCodegenLTrace(String) - Static method in class org.apache.sysds.runtime.lineage.LineageCodegenItem
 
getCol() - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.Cell
 
getCol() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
getColBlockize(int) - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap.DensityMap
 
getColCounts() - Method in class org.apache.sysds.hops.estim.EstimatorMatrixHistogram.MatrixHistogram
 
getColGroupInfo(IColIndex) - Method in class org.apache.sysds.runtime.compress.estim.AComEst
Method for extracting Compressed Size Info of specified columns, together in a single ColGroup
getColGroupInfo(IColIndex, int, int) - Method in class org.apache.sysds.runtime.compress.estim.AComEst
A method to extract the Compressed Size Info for a given list of columns, This method further limits the estimated number of unique values, since in some cases the estimated number of uniques is estimated higher than the number estimated in sub groups of the given colIndexes.
getColGroupInfo(IColIndex, int, int) - Method in class org.apache.sysds.runtime.compress.estim.ComEstExact
 
getColGroupInfo(IColIndex, int, int) - Method in class org.apache.sysds.runtime.compress.estim.ComEstSample
 
getColGroups() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
Get the column groups of this CompressedMatrixBlock
getColGroups() - Method in class org.apache.sysds.runtime.compress.CompressionStatistics
 
getColGroupType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
getColGroupType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
getColGroupType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
getColGroupType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
getColGroupType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
getColGroupType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
 
getColGroupType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
 
getColGroupType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
getColGroupType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
getColGroupType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
getColGroupType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
getColGroupType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
getColGroupType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
getColID() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
getColIndex() - Method in class org.apache.sysds.runtime.iogen.ValueTrimFormat
 
getColIndices() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
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.LegacyEncoder
 
getColLower() - Method in class org.apache.sysds.runtime.instructions.cp.IndexingCPInstruction
 
getColLower() - Method in class org.apache.sysds.runtime.instructions.spark.IndexingSPInstruction
 
getColLowerBound() - Method in class org.apache.sysds.parser.IndexedIdentifier
 
getColLowerEqualsUpper() - Method in class org.apache.sysds.parser.IndexedIdentifier
 
getColMapping(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
Obtain the column mapping of encoded frames based on the passed meta data frame.
getColMapping(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
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.LegacyEncoder
Obtain the column mapping of encoded frames based on the passed meta data frame.
getColMaxs() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
getColMins() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
getColnames() - Method in class org.apache.sysds.runtime.transform.decode.Decoder
 
getColPattern() - Method in class org.apache.sysds.runtime.iogen.CustomProperties
 
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
 
getCols() - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
 
getColumn(int) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
getColumnData(int) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
getColumnEncoder(int, Class<T>) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
getColumnEncoders() - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
getColumnEncoders(Class<T>) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
getColumnIndex() - Method in class org.apache.sysds.runtime.matrix.data.MatrixIndexes
 
getColumnMetadata() - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
getColumnMetadata(int) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
getColumnName(int) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
Returns the column name for the requested column.
getColumnNameIDMap() - Method in class org.apache.sysds.runtime.frame.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.frame.data.FrameBlock
Returns the column names of the frame block.
getColumnNames(boolean) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
Returns the column names of the frame block.
getColumnNamesAsFrame() - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
getColumns() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
 
getColumns() - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
getColumnType(int) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
getColUpper() - Method in class org.apache.sysds.runtime.instructions.cp.IndexingCPInstruction
 
getColUpper() - Method in class org.apache.sysds.runtime.instructions.spark.IndexingSPInstruction
 
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
 
getCommon() - Method in class org.apache.sysds.runtime.compress.colgroup.AMorphingMMColGroup
Get common vector, note this should not materialize anything but simply point to things that are already allocated.
getCommon() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
getCommon() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
getCommon() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
getCommon() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
getCompAssRW() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
 
getCompiledFunction(String, long) - Static method in class org.apache.sysds.runtime.frame.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
 
getCompileTime() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
getComplementPPredOperation() - Method in class org.apache.sysds.hops.BinaryOp
 
getCompletePath() - Method in class org.apache.sysds.parser.ImportStatement
 
getCompositeEncodersForID(int) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
getCompressConfig() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
getCompressedMultiplications() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
getCompressedSize() - Method in class org.apache.sysds.hops.Hop
 
getCompressedSize() - Method in class org.apache.sysds.lops.OutputParameters
 
getCompressedSize() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
getCompressionScheme() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Get the compression scheme for this column group to enable compression of other data.
getCompressionScheme() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
getCompressionScheme() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
getCompressionScheme() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
getCompressionScheme() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
getCompressionScheme() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
getCompressionScheme() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
 
getCompressionScheme() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
 
getCompressionScheme() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
getCompressionScheme() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
getCompressionScheme() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
getCompressionScheme() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
getCompressionScheme() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
getCompressionScheme() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
getCompressionSize(AColGroup.CompressionType) - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
 
getCompType() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Obtain the compression type.
getCompType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
getCompType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
getCompType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
getCompType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
getCompType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
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.ColGroupSDC
 
getCompType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
getCompType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
getCompType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
getCompType() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
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.functionobjects.MinusMultiply
 
getConstant() - Method in class org.apache.sysds.runtime.functionobjects.PlusMultiply
 
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
 
getContext() - Method in class org.apache.sysds.runtime.codegen.SpoofCUDACellwise
 
getContext() - Method in interface org.apache.sysds.runtime.codegen.SpoofCUDAOperator
 
getContext() - Method in class org.apache.sysds.runtime.codegen.SpoofCUDARowwise
 
getContext() - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.Request
 
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
getCoordinatorHostId() - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.CoordinatorConnectionModel
 
getCoordinatorsTrafficBytes() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
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
 
getCost() - Method in class org.apache.sysds.hops.cost.HopRel
Get total cost as double
getCost(int, int, int, int, double) - Method in class org.apache.sysds.runtime.compress.cost.ComputationCostEstimator
Get the cost of a column group.
getCost(Collection<AColGroup>, int) - Method in class org.apache.sysds.runtime.compress.cost.ACostEstimate
Get the cost of a collection of column groups.
getCost(AColGroup, int) - Method in class org.apache.sysds.runtime.compress.cost.ACostEstimate
Get the cost of a compressed columnGroup.
getCost(AColGroup, int) - Method in class org.apache.sysds.runtime.compress.cost.ComputationCostEstimator
 
getCost(AColGroup, int) - Method in class org.apache.sysds.runtime.compress.cost.DistinctCostEstimator
 
getCost(AColGroup, int) - Method in class org.apache.sysds.runtime.compress.cost.HybridCostEstimator
 
getCost(AColGroup, int) - Method in class org.apache.sysds.runtime.compress.cost.MemoryCostEstimator
 
getCost(CompressedMatrixBlock) - Method in class org.apache.sysds.runtime.compress.cost.ACostEstimate
Get cost of a compressed matrix block
getCost(ComputationCostEstimator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Get the computation cost associated with this column group.
getCost(ComputationCostEstimator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
getCost(ComputationCostEstimator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
getCost(ComputationCostEstimator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
getCost(ComputationCostEstimator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
getCost(ComputationCostEstimator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
getCost(ComputationCostEstimator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
 
getCost(ComputationCostEstimator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
 
getCost(ComputationCostEstimator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
getCost(ComputationCostEstimator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
getCost(ComputationCostEstimator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
getCost(ComputationCostEstimator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
getCost(ComputationCostEstimator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
getCost(ComputationCostEstimator, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
getCost(CompressedSizeInfo) - Method in class org.apache.sysds.runtime.compress.cost.ACostEstimate
Get cost of an entire compression plan
getCost(CompressedSizeInfoColGroup) - Method in class org.apache.sysds.runtime.compress.cost.ACostEstimate
Get cost of a single column group estimate.
getCost(MatrixBlock) - Method in class org.apache.sysds.runtime.compress.cost.ACostEstimate
Get the cost of a matrix block.
getCost(MatrixBlock) - Method in class org.apache.sysds.runtime.compress.cost.ComputationCostEstimator
 
getCost(MatrixBlock) - Method in class org.apache.sysds.runtime.compress.cost.DistinctCostEstimator
 
getCost(MatrixBlock) - Method in class org.apache.sysds.runtime.compress.cost.HybridCostEstimator
 
getCost(MatrixBlock) - Method in class org.apache.sysds.runtime.compress.cost.MemoryCostEstimator
 
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
 
getCostObject() - Method in class org.apache.sysds.hops.cost.HopRel
Get cost object
getCounter() - Method in class org.apache.sysds.runtime.compress.cost.CostEstimatorBuilder
 
getCounts() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupValue
Returns the counts of values inside the dictionary.
getCounts() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Get the number of counts of each unique value contained in this map.
getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
getCounts(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[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Get the number of counts of each unique value contained in this map.
getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToUByte
 
getCounts(int[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
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
 
getCPlanCompile() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
getCPRecodeMaps() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
getCPRecodeMapsPartial() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
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
 
getCUDAopID(String) - Static method in class org.apache.sysds.runtime.codegen.CodegenUtils
 
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.readers.ReaderColumnSelection
 
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
 
getDAGCompile() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
getData() - Method in class org.apache.sysds.hops.estim.MMNode
 
getData() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
Access for superclass
getData() - Method in class org.apache.sysds.runtime.compress.colgroup.insertionsort.AInsertionSorter
 
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.homomorphicEncryption.PublicKey
 
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.Encrypted
 
getData() - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
getData() - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
getData(int) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
getData(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
Obtain an output as a Data object.
getData(String) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
getDataBuffer() - Method in class org.apache.sysds.runtime.io.hdf5.H5LocalHeap
 
getDataBuffer(int) - Method in class org.apache.sysds.runtime.io.hdf5.H5ContiguousDataset
 
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() - Method in interface org.apache.sysds.runtime.controlprogram.caching.CacheBlock
 
getDataCharacteristics() - Method in class org.apache.sysds.runtime.controlprogram.federated.MatrixLineagePair
 
getDataCharacteristics() - Method in class org.apache.sysds.runtime.data.TensorBlock
 
getDataCharacteristics() - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
getDataCharacteristics() - Method in class org.apache.sysds.runtime.instructions.cp.Encrypted
 
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
 
getDataCharacteristics() - Method in class org.apache.sysds.runtime.meta.MetaDataAll
 
getDataCharacteristics(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
getDataClass() - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
getDataExpression(String, ArrayList<ParameterExpression>, ParseInfo, CustomErrorListener) - Static method in class org.apache.sysds.parser.DataExpression
 
getDataExpression(ParserRuleContext, String, ArrayList<ParameterExpression>, String, 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
 
getDataIndex() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AIterator
Get the current data index associated with the index returned from value.
getDataLayoutClass() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
getDataLayoutVersion() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
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
 
getDataSegmentSize() - Method in class org.apache.sysds.runtime.io.hdf5.H5LocalHeap
 
getDataset() - Method in class org.apache.sysds.runtime.instructions.spark.data.DatasetObject
 
getDatasetName() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesHDF5
 
getDatasetName() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
getDataSize() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
getDataSize() - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
getDataSpaceVersion() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
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.controlprogram.federated.FederatedData
 
getDataType() - Method in class org.apache.sysds.runtime.controlprogram.federated.MatrixLineagePair
 
getDataType() - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
 
getDataType() - Method in class org.apache.sysds.runtime.instructions.cp.Data
 
getDataType() - Method in class org.apache.sysds.runtime.io.hdf5.H5ContiguousDataset
 
getDataType() - Method in class org.apache.sysds.runtime.iogen.SampleProperties
 
getDebugName() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
getDebugName() - Method in class org.apache.sysds.runtime.instructions.cp.CiphertextMatrix
 
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.PlaintextMatrix
 
getDebugName() - Method in class org.apache.sysds.runtime.instructions.cp.ScalarObject
 
getDecoderType(Decoder) - Static method in class org.apache.sysds.runtime.transform.decode.DecoderFactory
 
getDecompressionCount() - Static method in class org.apache.sysds.utils.DMLCompressionStatistics
 
getDecompressions() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
getDecreasing() - Method in class org.apache.sysds.runtime.functionobjects.SortIndex
 
getDedupBlocks() - Method in class org.apache.sysds.runtime.lineage.Lineage
 
getDedupPatch() - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
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
 
getDefaultTuple() - Method in class org.apache.sysds.runtime.compress.colgroup.ASDC
 
getDefaultTuple() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
getDefaultTuple() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
getDefaultTuple() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
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
 
getDelHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
getDelim() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
 
getDelim() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesLIBSVM
 
getDelim() - Method in class org.apache.sysds.runtime.iogen.CustomProperties
 
getDelim() - Method in class org.apache.sysds.runtime.meta.MetaDataAll
 
getDelims() - Method in class org.apache.sysds.runtime.iogen.RawRow
 
getDelimsSet() - Method in class org.apache.sysds.runtime.iogen.RawRow
 
getDeltaColGroupInfo(IColIndex) - Method in class org.apache.sysds.runtime.compress.estim.AComEst
Method for extracting info of specified columns as delta encodings (delta from previous rows values)
getDeltaColGroupInfo(IColIndex, int, int) - Method in class org.apache.sysds.runtime.compress.estim.AComEst
A method to extract the Compressed Size Info for a given list of columns, This method further limits the estimated number of unique values, since in some cases the estimated number of uniques is estimated higher than the number estimated in sub groups of the given colIndexes.
getDeltaColGroupInfo(IColIndex, int, int) - Method in class org.apache.sysds.runtime.compress.estim.ComEstExact
 
getDeltaColGroupInfo(IColIndex, int, int) - Method in class org.apache.sysds.runtime.compress.estim.ComEstSample
 
getDenseBlock() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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.compress.CompressedMatrixBlock
 
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(String, long, long, boolean) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
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
getDenseMatrixOutputForGPUInstruction(ExecutionContext, String, String, long, long, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
 
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.
getDensePointerAddress() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
 
getDensePointerForCuDNN(GPUContext, MatrixObject, String, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNN
Convenience method to get jcudaDenseMatrixPtr.
getDenseRatio() - Method in class org.apache.sysds.runtime.compress.CompressionStatistics
 
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
 
getDictionary() - Method in class org.apache.sysds.runtime.compress.colgroup.ADictBasedColGroup
 
getDictionary() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
getDictionary() - Method in class org.apache.sysds.runtime.compress.utils.DoubleCountHashMap
 
getDictionaryOps() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
getDictType() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Get the dictionary type this dictionary is.
getDictType() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
getDictType() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
getDictType() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
getDictType() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
getDictType() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
getDim(int) - Method in class org.apache.sysds.hops.Hop
 
getDim(int) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
getDim(int) - Method in class org.apache.sysds.runtime.controlprogram.federated.MatrixLineagePair
 
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
Get the number of rows in the 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
Get the number of columns in the 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
 
getDimensions() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
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.cp.Encrypted
 
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
 
getDirection() - Method in class org.apache.sysds.runtime.matrix.operators.UnarySketchOperator
 
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
getDomainSize() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
getDomainSize() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
getDomainSize() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
getDominantDateFormat(String[]) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
getDouble(int, int) - Method in interface org.apache.sysds.runtime.controlprogram.caching.CacheBlock
Returns the double value at the passed row and column.
getDouble(int, int) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
getDouble(int, int) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
getDouble(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
getDouble(Object) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
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
getDoubleActualValue() - Method in class org.apache.sysds.runtime.iogen.ValueTrimFormat
 
getDoubleDataType() - Method in class org.apache.sysds.runtime.io.hdf5.message.H5DataTypeMessage
 
getDoubleNaN(int, int) - Method in interface org.apache.sysds.runtime.controlprogram.caching.CacheBlock
Returns the double value at the passed row and column.
getDoubleNaN(int, int) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
getDoubleNaN(int, int) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
getDoubleNaN(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
getDoubleValue() - Method in class org.apache.sysds.hops.LiteralOp
 
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
 
getDoubleValue(String) - Method in class org.apache.sysds.conf.DMLConfig
 
getDoubleValue(LiteralOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
getDoubleValueSafe(LiteralOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
getDuration() - Method in class org.apache.sysds.hops.fedplanner.FederatedCompilationTimer.TimeEntry
 
getEc() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.SparkPSBody
 
getEc() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ParForBody
 
getECM(String, long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedLookupTable
Get the ExecutionContextMap corresponding to the given host and pid of the requesting coordinator from the lookup table.
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.
getEncodeApplyTime() - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
getEncodeBuildTime() - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
getEncoder(Class<T>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
getEncoders() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
getEncoderType(ColumnEncoder) - Static method in class org.apache.sysds.runtime.transform.encode.EncoderFactory
 
getEncoderTypes() - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
getEncoderTypes(int) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
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
 
getEndIndex(int, int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
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
 
getEntity(Long, Class<T>) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.DerbyRepository
 
getEntity(Long, Class<T>) - Method in interface org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.IRepository
 
getEntry(LineageItem) - Static method in class org.apache.sysds.runtime.lineage.LineageCache
 
getEnumAll() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
getEnumAllP() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
getEnumEval() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
getEnumEvalP() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
getEqualsFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.Equals
 
getEquiHeightBins(ExecutionContext, int, double[]) - Method in class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction
 
getErrorMessage() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedResponse
 
getErrorMessage() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcResponse
 
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, Types.ExecType) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator
Main estimation method.
getEstimatedDistinct() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfo
 
getEstimateReps() - Method in class org.apache.sysds.parser.ForStatementBlock
 
getEstMetaSize() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
getEstNumDistincts() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
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.frame.data.columns.Array
Get the exact serialized size on disk of this array.
getExactSerializedSize() - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
getExactSerializedSize() - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
getExactSerializedSize() - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
getExactSerializedSize() - Method in class org.apache.sysds.runtime.frame.data.columns.ColumnMetadata
 
getExactSerializedSize() - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
getExactSerializedSize() - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
getExactSerializedSize() - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
getExactSerializedSize() - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
getExactSerializedSize() - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
getExactSerializedSize() - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
getExactSerializedSize() - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
getExactSerializedSize() - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
 
getExactSerializedSize() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Returns the exact serialized size of column group.
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupOffset
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ADictBasedColGroup
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Calculate the space consumption if the dictionary is stored on disk.
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.ArrayIndex
 
getExactSizeOnDisk() - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex
Get the exact size on disk to enable preallocation of the disk output buffer sizes
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.RangeIndex
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.SingleIndex
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.TwoIndex
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Get the size of this Mapping object on disk.
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
Remember to include the ordinal of the type of offset list.
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetByte
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetChar
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetEmpty
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetSingle
 
getExactSizeOnDisk() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetTwo
 
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.
getExactSizeOnDisk(List<AColGroup>) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupIO
Get the size on disk for the given list of column groups
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.cost.HopRel
 
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, FED, 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
 
getExecutionTime() - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
getExecutionTimer() - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
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
 
getExponentBias() - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
getExponentLocation() - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
getExponentSize() - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
getExportTime() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
 
getExpr() - Method in class org.apache.sysds.parser.ParameterExpression
 
getExpr(int) - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
 
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
 
getFedDataPartitioningTime() - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
getFederatedCost() - Method in class org.apache.sysds.hops.Hop
 
getFederatedData() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
getFederatedOutput() - Method in class org.apache.sysds.hops.cost.HopRel
 
getFederatedOutput() - Method in class org.apache.sysds.hops.Hop
 
getFederatedOutput() - Method in class org.apache.sysds.lops.Lop
 
getFederatedOutputAlternative(Hop) - Method in class org.apache.sysds.hops.fedplanner.MemoTable
Get the federated output alternative for given root hop or throw exception if not found.
getFederatedOutputAlternativeOrNull(Hop) - Method in class org.apache.sysds.hops.fedplanner.MemoTable
Get the federated output alternative for given root hop or null if not found.
getFederatedRanges() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
getFederatedTimeout() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
getFEDInstructionType() - Method in class org.apache.sysds.runtime.instructions.fed.FEDInstruction
 
getFedLookupTableEntryCount() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
getFedLookupTableGetCount() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
getFedLookupTableGetTime() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
getFedMapping() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
Gets the mapping of indices ranges to federated objects.
getFedMapping() - Method in class org.apache.sysds.runtime.controlprogram.federated.MatrixLineagePair
 
getFedOutAlternatives(Hop) - Method in class org.apache.sysds.hops.fedplanner.MemoTable
Get list of strings representing the different hopRel federated outputs related to root hop.
getFedPutLineageCount() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
getFedPutLineageItems() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
getFedReuseReadBytesCount() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
getFedReuseReadHitCount() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
getFedSerializationReuseBytes() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
getFedSerializationReuseCount() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
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.hops.DataOp
 
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
 
getFileFormatPropertiesOfRRCIMapping() - Method in class org.apache.sysds.runtime.iogen.ReaderMapping
 
getFileFormatPropertiesOfRRCRMapping() - Method in class org.apache.sysds.runtime.iogen.ReaderMapping
 
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.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.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.ProgramBlock
 
getFilename() - Method in class org.apache.sysds.runtime.instructions.Instruction
 
getFileName() - Method in class org.apache.sysds.hops.DataOp
 
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.runtime.controlprogram.caching.CacheableData
 
getFilepath() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
 
getFilePath() - Method in class org.apache.sysds.parser.ImportStatement
 
getFilePath(String) - Static method in enum org.apache.sysds.common.Builtins
 
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(Configuration) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
 
getFileSystem(Path) - 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
 
getFillValue() - Method in class org.apache.sysds.runtime.io.hdf5.message.H5FillValueMessage
 
getFillValueVersion() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
getFillValueWriteTime() - Method in class org.apache.sysds.runtime.io.hdf5.message.H5FillValueMessage
 
getFineGrainedPrivacy() - Method in class org.apache.sysds.runtime.meta.MetaDataAll
 
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
 
getFirstColIndex() - Method in class org.apache.sysds.runtime.iogen.CustomProperties
 
getFirstExpr() - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
 
getFirstIndex() - Method in class org.apache.sysds.runtime.matrix.data.TripleIndexes
 
getFirstRowIndex() - Method in class org.apache.sysds.runtime.iogen.CustomProperties
 
getFlipped() - Method in enum org.apache.sysds.lops.MapMult.CacheType
 
getFnamespace() - Method in class org.apache.sysds.lops.FunctionCallCP
 
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
 
getFormatProperties() - Method in class org.apache.sysds.runtime.iogen.ReaderMapping
 
getFormatTypeString() - Method in class org.apache.sysds.runtime.meta.MetaDataAll
 
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.
getFrameArrayType() - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Get the internal FrameArrayType, to specify the encoding of the Types, note there are more Frame Array Types than there is ValueTypes.
getFrameArrayType() - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
getFrameArrayType() - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
getFrameArrayType() - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
getFrameArrayType() - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
getFrameArrayType() - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
getFrameArrayType() - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
getFrameArrayType() - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
getFrameArrayType() - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
getFrameArrayType() - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
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.
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(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
getFrameObject(CPOperand) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
getFrameSchema() - Method in class org.apache.sysds.api.mlcontext.FrameMetadata
Obtain the frame schema
getFrequencies() - Method in class org.apache.sysds.runtime.compress.estim.EstimationFactors
 
getFrequencyOfEachConsecutiveChar(String) - Static method in class org.apache.sysds.runtime.util.DMVUtils
 
getFrom() - Method in class org.apache.sysds.runtime.instructions.cp.DataGenCPInstruction
 
getFromAll(Class<T>, Function<? super T, ? extends E>) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
getFromAllDoubleArray(Class<T>, Function<? super T, ? extends Double>) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
getFromAllIntArray(Class<T>, Function<? super T, ? extends Integer>) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
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
 
getFSHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
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
 
getFSWrites() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
getFSWriteTime(long, long, double) - Static method in class org.apache.sysds.hops.cost.CostEstimatorStaticRuntime
 
getFType() - Method in class org.apache.sysds.hops.cost.HopRel
 
getFTypes(Hop) - Method in class org.apache.sysds.hops.fedplanner.MemoTable
Get all output FTypes of given root from HopRels stored in memo.
getFuncHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
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
 
getFunctionDictionary(String) - Method in class org.apache.sysds.parser.DMLProgram
 
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, boolean) - Method in class org.apache.sysds.runtime.controlprogram.Program
 
getFunctionProgramBlock(String, String) - 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
 
getFunctionProgramBlocks(String) - 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() - Method in class org.apache.sysds.parser.DMLProgram
 
getFunctionStatementBlocks(String) - 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
 
getGeneralPrivacyLevel(PrivacyConstraint) - Static method in class org.apache.sysds.runtime.privacy.PrivacyUtils
 
getGeneralPrivacyLevels(PrivacyConstraint[]) - Static method in class org.apache.sysds.runtime.privacy.PrivacyUtils
 
getGeneratorAPI() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
 
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
getGPUDensePointerAddress(MatrixObject) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
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() - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
 
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()).
getGPUSparsePointerAddress(MatrixObject) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
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
 
getGroupSymbolTableNodeVersion() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
getGrSymmetry() - Method in class org.apache.sysds.runtime.iogen.CustomProperties
 
getHasHeader() - Method in class org.apache.sysds.runtime.meta.MetaDataAll
 
getHashType() - Method in class org.apache.sysds.runtime.matrix.operators.CountDistinctOperator
 
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
 
getHeaderSize() - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
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.
getHeavyHittersHashMap() - Static method in class org.apache.sysds.utils.Statistics
 
getHeight() - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
getHighestCommonType(Types.ValueType, Types.ValueType) - Static method in enum org.apache.sysds.common.Types.ValueType
Get the highest common type that both ValueTypes can be contained in
getHistogram(int) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
Exposes the internal histogram after build.
getHop() - Method in class org.apache.sysds.runtime.compress.workload.Op
 
getHOPComputeCost(Hop) - Static method in class org.apache.sysds.hops.cost.ComputeCost
Get compute cost for given HOP based on the number of floating point operations per output cell and the total number of output cells.
getHopID() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeData
 
getHopID() - Method in class org.apache.sysds.hops.Hop
 
getHopRef() - Method in class org.apache.sysds.hops.cost.HopRel
 
getHopRefs() - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
 
getHopRel(Hop, FTypes.FType) - Method in class org.apache.sysds.hops.fedplanner.MemoTable
 
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.runtime.lineage.LineageItem
 
getId(DblArray) - Method in class org.apache.sysds.runtime.compress.utils.DblArrayCountHashMap
Get the ID behind the key, if it does not exist -1 is returned.
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
 
getIdentation(int) - Static method in class org.apache.sysds.utils.Explain
 
getIdentifier() - Method in class org.apache.sysds.parser.OutputStatement
 
getIdx(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Get the value at a colGroup specific row/column index position.
getIdx(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
getIdx(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
getIdx(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
getIdx(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
getIdx(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
getIdx(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
 
getIdx(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
 
getIdx(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
getIdx(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
getIdx(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
getIdx(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
getIdx(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
getIdx(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
getIfBody() - Method in class org.apache.sysds.parser.IfStatement
 
getIgnoreZeros() - Method in class org.apache.sysds.runtime.instructions.cp.CtableCPInstruction
 
getIgnoreZeros() - Method in class org.apache.sysds.runtime.instructions.spark.CtableSPInstruction
 
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() - Method in class org.apache.sysds.runtime.data.SparseRowScalar
 
getIndex() - Method in class org.apache.sysds.runtime.frame.data.columns.Array.ArrayIterator
 
getIndex() - Method in class org.apache.sysds.runtime.iogen.FastStringTokenizer
 
getIndex(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Get the given index back as a integer
getIndex(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
getIndex(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
getIndex(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
getIndex(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
getIndex(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
getIndex(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToUByte
 
getIndex(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
getIndex(int) - Method in class org.apache.sysds.runtime.data.SparseRowVector
 
getIndex(int) - Method in class org.apache.sysds.runtime.data.TensorIndexes
 
getIndexAsBytes(int) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
Python interface to extract strings from systemds.
getIndexDelim() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesLIBSVM
 
getIndexDelim() - Method in class org.apache.sysds.runtime.iogen.CustomProperties
 
getIndexes() - Method in class org.apache.sysds.runtime.compress.colgroup.insertionsort.AInsertionSorter
 
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
 
getIndexing() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
getIndexReturn() - Method in class org.apache.sysds.runtime.functionobjects.SortIndex
 
getInfo() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfo
 
getInitialValue(SpoofCellwise.AggOp) - Static method in class org.apache.sysds.runtime.codegen.SpoofMultiAggregate
 
getInitTime() - Static method in class org.apache.sysds.utils.stats.ParForStatistics
 
getInitValue() - Method in class org.apache.sysds.runtime.instructions.spark.CumulativeOffsetSPInstruction
 
getInjectedCheckpoints() - Method in class org.apache.sysds.hops.rewrite.ProgramRewriteStatus
 
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Returns the memory usage of the dictionary.
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Get the in memory size of this Mapping object.
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
Get the in memory size of the Offset object
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetByte
 
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetChar
 
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetEmpty
 
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetSingle
 
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetTwo
 
getInMemorySize() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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.frame.data.columns.Array
Get in memory size, not counting reference to this object.
getInMemorySize() - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
getInMemorySize() - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
getInMemorySize() - Method in class org.apache.sysds.runtime.frame.data.columns.ColumnMetadata
 
getInMemorySize() - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
getInMemorySize() - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
getInMemorySize() - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
getInMemorySize() - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
getInMemorySize() - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
getInMemorySize() - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
getInMemorySize() - Method in class org.apache.sysds.runtime.instructions.spark.data.PartitionedBlock
 
getInMemorySize() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
getInMemorySize(int) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
getInMemorySize(int) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
getInMemorySize(int) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
getInMemorySize(int) - Static method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
getInMemorySize(int) - Static method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
getInMemorySize(int) - Static method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
getInMemorySize(int) - Static method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
getInMemorySize(int) - Static method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToUByte
 
getInMemorySize(int) - Static method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
getInMemorySize(int, int, double) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
getInMemorySize(int, int, double, boolean) - Static method in interface org.apache.sysds.runtime.compress.colgroup.dictionary.DictionaryFactory
 
getInMemorySize(Types.ValueType, int) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
getInput() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
 
getInput() - Method in class org.apache.sysds.hops.Hop
 
getInput(int) - Method in class org.apache.sysds.hops.Hop
 
getInput(int) - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
 
getInput(String) - Method in class org.apache.sysds.hops.DataGenOp
 
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
 
getInput4() - Method in class org.apache.sysds.runtime.instructions.spark.QuaternarySPInstruction
 
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
 
getInputDependency() - Method in class org.apache.sysds.hops.cost.HopRel
 
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
Get the memory estimate of inputs as the sum of input estimates in bytes.
getInputMemEstimate(double) - Method in class org.apache.sysds.hops.Hop
Get the memory estimate of inputs as the sum of input estimates in bytes.
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.parser.FunctionStatement
 
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.SpoofCPInstruction
 
getInputs() - Method in class org.apache.sysds.runtime.instructions.cp.SqlCPInstruction
Returns the inputs of the instruction.
getInputs() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
 
getInputs() - Method in class org.apache.sysds.runtime.instructions.spark.SpoofSPInstruction
 
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
 
getInputTotalCost() - Method in class org.apache.sysds.hops.cost.FederatedCost
Get summed input costs.
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 SPARK) and returns the remaining parts, which include the opcode as well as the input and output operands.
getInstructions() - Method in class org.apache.sysds.lops.Data
Method to generate createvar instruction that updates symbol table with metadata, hdfsfile name, etc.
getInstructions() - Method in class org.apache.sysds.lops.Lop
Method should be overridden if needed
getInstructions() - Method in class org.apache.sysds.runtime.controlprogram.BasicProgramBlock
 
getInstructions(int, int, int, int, int, int, int, int) - Method in class org.apache.sysds.lops.Lop
 
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) - Method in class org.apache.sysds.lops.GroupedAggregate
Function to generate CP Grouped Aggregate Instructions.
getInstructions(String) - Method in class org.apache.sysds.lops.Lop
Method should be overridden if needed
getInstructions(String) - Method in class org.apache.sysds.lops.ParameterizedBuiltin
 
getInstructions(String[], String) - Method in class org.apache.sysds.lops.DnnTransform
 
getInstructions(String[], String) - Method in class org.apache.sysds.lops.Lop
 
getInstructions(String[], String) - Method in class org.apache.sysds.lops.Nary
Generate the complete instruction string for this Lop.
getInstructions(String[], String) - Method in class org.apache.sysds.lops.SpoofFused
 
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[], 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.SpoofFused
 
getInstructions(String, String) - Method in class org.apache.sysds.lops.BinaryUAggChain
 
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) - Method in class org.apache.sysds.lops.CSVReBlock
 
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(String, String) - Method in class org.apache.sysds.lops.DeCompression
 
getInstructions(String, String) - Method in class org.apache.sysds.lops.Local
 
getInstructions(String, 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.MMTSJ
 
getInstructions(String, String) - Method in class org.apache.sysds.lops.PartialAggregate
Instruction generation for CP and Spark
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) - Method in class org.apache.sysds.lops.ReBlock
 
getInstructions(String, String) - Method in class org.apache.sysds.lops.SortKeys
 
getInstructions(String, String) - Method in class org.apache.sysds.lops.SpoofFused
 
getInstructions(String, String) - Method in class org.apache.sysds.lops.Transform
 
getInstructions(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) - 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, String) - Method in class org.apache.sysds.lops.CentralMoment
Function to generate CP centralMoment instruction for unweighted operation.
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) - Method in class org.apache.sysds.lops.CumulativeOffsetBinary
 
getInstructions(String, String, String) - Method in class org.apache.sysds.lops.DnnTransform
 
getInstructions(String, String, String) - Method in class org.apache.sysds.lops.GroupedAggregateM
 
getInstructions(String, 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.MapMult
 
getInstructions(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, String) - Method in class org.apache.sysds.lops.MMZip
 
getInstructions(String, String, String) - Method in class org.apache.sysds.lops.PickByCount
 
getInstructions(String, String, String) - Method in class org.apache.sysds.lops.PMapMult
 
getInstructions(String, String, String) - Method in class org.apache.sysds.lops.SortKeys
 
getInstructions(String, String, String) - Method in class org.apache.sysds.lops.SpoofFused
 
getInstructions(String, String, String) - Method in class org.apache.sysds.lops.UAggOuterChain
 
getInstructions(String, String, String) - Method in class org.apache.sysds.lops.Unary
 
getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.Append
 
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, String) - Method in class org.apache.sysds.lops.CentralMoment
Function to generate CP centralMoment instruction for weighted operation.
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, String, String) - Method in class org.apache.sysds.lops.Ctable
 
getInstructions(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, 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.MapMultChain
 
getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.PMMJ
 
getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.SpoofFused
 
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, 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) - Method in class org.apache.sysds.lops.WeightedUnaryMM
 
getInstructions(String, String, String, String) - Method in class org.apache.sysds.lops.WeightedUnaryMMR
 
getInstructions(String, String, String, String, String) - Method in class org.apache.sysds.lops.AppendG
 
getInstructions(String, 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.Federated
 
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) - 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, String) - Method in class org.apache.sysds.lops.Transform
 
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, 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, 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.RightIndex
 
getInstructions(String, 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.Transform
 
getInstructions(String, String, String, String, String, 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.LeftIndex
 
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) - Method in class org.apache.sysds.lops.SpoofFused
 
getInstructions(String, String, String, String, String, String, String, String) - Method in class org.apache.sysds.lops.Lop
 
getInstructions(String, String, String, String, String, String, String, String) - Method in class org.apache.sysds.lops.SpoofFused
 
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
 
getInterceptForColumn(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
getIntercepts() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
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(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
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.
getIsExpand() - Method in class org.apache.sysds.runtime.instructions.cp.CtableCPInstruction
 
getIsExpand() - Method in class org.apache.sysds.runtime.instructions.spark.CtableSPInstruction
 
getIterablePredicate() - Method in class org.apache.sysds.parser.ForStatement
 
getIterations() - Method in class org.apache.sysds.runtime.controlprogram.parfor.Task
 
getIterator() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
Get an iterator of the offsets while also maintaining the data index pointer.
getIterator() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetByte
 
getIterator() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetChar
 
getIterator() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetEmpty
 
getIterator() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetSingle
 
getIterator() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetTwo
 
getIterator() - Method in class org.apache.sysds.runtime.data.SparseBlock
Get a non-zero iterator over the entire sparse block.
getIterator() - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
getIterator() - Method in class org.apache.sysds.runtime.frame.data.columns.Array
 
getIterator() - Method in class org.apache.sysds.runtime.matrix.data.CTableMap
 
getIterator() - Method in class org.apache.sysds.runtime.util.LongLongDoubleHashMap
 
getIterator(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ASDCZero
 
getIterator(int) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
Get an iterator that is pointing at a specific offset.
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) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
getIterator(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlock
Get a non-zero iterator over the subblock [rl, ru).
getIterator(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
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
 
getK() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderFeatureHash
 
getK(JSONObject) - Static method in class org.apache.sysds.runtime.transform.meta.TfMetaUtils
Get K value used for calculation during feature hashing from parsed specifications.
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
 
getLargestOffInstances() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
 
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) - 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, Types.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, Types.ExecType) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimatorHops
 
getLeafNodeEstimate(CostEstimator.TestMeasure, OptNode, Types.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
 
getLeft() - Method in class org.apache.sysds.runtime.compress.workload.OpSided
 
getLeftIndexingSparsity(long, long, long, long, long, long) - Static method in class org.apache.sysds.hops.OptimizerUtils
 
getLeftMultiplications() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
getLegacyEncoder(Class<T>) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
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
 
getLI() - Method in class org.apache.sysds.runtime.controlprogram.federated.MatrixLineagePair
 
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
 
getLineageCache() - Static method in class org.apache.sysds.runtime.lineage.LineageCache
 
getLineageChilds() - Method in class org.apache.sysds.runtime.instructions.spark.data.LineageObject
 
getLineageItem() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedResponse
 
getLineageItem(int) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
getLineageItem(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
getLineageItem(String) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.hops.fedplanner.PrivacyConstraintLoader.PrivacyConstraintRetriever
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics.FedStatsCollectFunction
 
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.FrameIndexingCPInstruction
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.cp.ListIndexingCPInstruction
 
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.StringInitCPInstruction
 
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.fed.InitFEDInstruction
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction.CreateFrameEncoder
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction.ExecuteFrameEncoder
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.ParameterizedBuiltinFEDInstruction.DecodeMatrix
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction.CreateMatrixFromFrame
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction.GetHistogram
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction.GetValuesInRange
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction.GetValuesInRanges
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction.MinMax
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.ReorgFEDInstruction.DiagMatrix
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.ReorgFEDInstruction.Rdiag
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.ReshapeFEDInstruction
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.VariableFEDInstruction
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.MatrixIndexingGPUInstruction
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.MatrixReshapeGPUInstruction
 
getLineageItem(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.gpu.SpoofCUDAInstruction
 
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.ReblockSPInstruction
 
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.
getLineageItem(CPOperand) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
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
 
getLineageLiteral(ScalarObject, boolean) - Static 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() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
 
getLineageTrace(String) - Method in class org.apache.sysds.api.jmlc.PreparedScript
Capture lineage of the DML/PyDML program and view result as a string.
getLinearizationOrder() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
getLineNum() - Method in class org.apache.sysds.runtime.instructions.Instruction
Getter for instruction line number
getLinHits() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
 
getLinkNameOffset() - Method in class org.apache.sysds.runtime.io.hdf5.H5SymbolTableEntry
 
getLinWrites() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
 
getListObject(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
getListObject(CPOperand) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
getLiteral() - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
 
getLiteral(CNode) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
getLiteralLineageItem() - 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
 
getLocalHeapAddress() - Method in class org.apache.sysds.runtime.io.hdf5.message.H5SymbolTableMessage
 
getLocalHeapVersion() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
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(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
 
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
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
 
getLongs() - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
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
 
getLopList(StatementBlock) - Static method in class org.apache.sysds.lops.OperatorOrderingUtils
 
getLops() - Method in class org.apache.sysds.hops.Hop
 
getLops() - Method in class org.apache.sysds.parser.StatementBlock
 
getLOUTOrNONEAlternative(Hop) - Method in class org.apache.sysds.hops.fedplanner.MemoTable
 
getMantissaLocation() - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
getMantissaNormalization() - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
getMantissaSize() - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
getMap() - Method in class org.apache.sysds.hops.estim.EstimatorDensityMap.DensityMap
 
getMap() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
 
getMap() - Static method in class org.apache.sysds.runtime.compress.SingletonLookupHashMap
 
getMap() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
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.OptTree
 
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.OptTree
 
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.OptTree
 
getMappedProgramBlock(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingAbstract
 
getMapToData() - Method in interface org.apache.sysds.runtime.compress.colgroup.AMapToDataGroup
 
getMapToData() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
getMapToData() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
getMapToData() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
getMapToData() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
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() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
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.
getMatrixInput(CPOperand) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
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
 
getMatrixLineagePair(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
getMatrixLineagePair(CPOperand) - 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() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
 
getMatrixObject(String) - Method in class org.apache.sysds.api.mlcontext.MLResults
Obtain an output as a MatrixObject
getMatrixObject(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
getMatrixObject(CPOperand) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
getMax() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Short hand method for getting maximum value contained in this column group.
getMax() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupCompressed
 
getMax() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
getMax() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
getMax() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
getMax() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
 
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
 
getMaxCol() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
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
 
getMaxNumRows(int) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplier
 
getMaxNumRows(int) - Method in class org.apache.sysds.runtime.transform.tokenize.Tokenizer
 
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.io.hdf5.H5RootObject
 
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.
getMaxSizes() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
getMaxThreadsPerBlock() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
Gets the maximum number of threads per block for "active" GPU.
getMaxTokens() - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplier
 
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
 
getMBDict() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
getMBDict() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
getMBDict(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Get this dictionary as a MatrixBlock dictionary.
getMBDict(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
getMBDict(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
getMBDict(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
getMBDict(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
getMBDict(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
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
 
getMemHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
getMemoryManager() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
 
getMemWrites() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
getMergePartialCTMapsTask(CTableMap, CTableMap, ArrayList<CTableMap>) - Method in class org.apache.sysds.runtime.functionobjects.CTable
 
getMergeTime() - Static method in class org.apache.sysds.utils.stats.ParForStatistics
 
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.
getMessageOfType(Class<T>) - Method in class org.apache.sysds.runtime.io.hdf5.H5ObjectHeader
 
getMessages() - Method in class org.apache.sysds.runtime.io.hdf5.H5ObjectHeader
 
getMessagesOfType(Class<T>) - Method in class org.apache.sysds.runtime.io.hdf5.H5ObjectHeader
 
getMetaData() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
getMetaData() - Method in class org.apache.sysds.runtime.instructions.cp.Data
 
getMetaData(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderFeatureHash
 
getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderPassThrough
 
getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderUDF
 
getMetaData(FrameBlock) - Method in interface 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.EncoderMVImpute
 
getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
 
getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.LegacyEncoder
Construct a frame block out of the transform meta data.
getMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
getMetaData(FrameBlock, int) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
getMetadataFilePaths(FileSystem, Path) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
 
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
 
getMin() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Short hand method for getting minimum value contained in this column group.
getMin() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupCompressed
 
getMin() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
getMin() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
getMin() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
getMinCostAlternative(Hop) - Method in class org.apache.sysds.hops.fedplanner.MemoTable
Get the HopRel with minimum cost for given root hop
getMinMaxLength() - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Get the minimum and maximum length of the contained values as string type.
getMinMaxLength() - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
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
 
getMO() - Method in class org.apache.sysds.runtime.controlprogram.federated.MatrixLineagePair
 
getModelFromBody(Request, Class<T>) - Static method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.MapperService
 
getModeNames() - Method in class org.apache.sysds.parser.dml.DmlLexer
 
getModifiedTime() - Method in class org.apache.sysds.runtime.io.hdf5.message.H5ObjectModificationTimeMessage
 
getMostCommonFraction() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
 
getMostFrequent() - Method in class org.apache.sysds.runtime.compress.utils.DoubleCountHashMap
 
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.frame.data.columns.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.codegen.SpoofCUDACellwise
 
getName() - Method in interface org.apache.sysds.runtime.codegen.SpoofCUDAOperator
 
getName() - Method in class org.apache.sysds.runtime.codegen.SpoofCUDARowwise
 
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
 
getNameHeapAddress() - Method in class org.apache.sysds.runtime.io.hdf5.H5SymbolTableEntry
 
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.iogen.CustomProperties
 
getNAStrings() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
 
getNAStrings() - Method in class org.apache.sysds.runtime.transform.TfUtils
 
getNativeStagingBuffer(Pointer, long, int) - Static method in class org.apache.sysds.runtime.codegen.SpoofOperator
 
getNewVal(double) - Method in class org.apache.sysds.runtime.io.hdf5.H5BufferBuilder
 
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[]) - Method in class org.apache.sysds.runtime.data.TensorBlock
Calculates the next index array.
getNextIndexes(int[], int[]) - Static 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() - 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(long, long, double) - Static method in class org.apache.sysds.hops.OptimizerUtils
 
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
 
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() - 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
 
getNonZeros(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
 
getNonZeros(MatrixObject) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
 
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
 
getNrColumnsString() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfo
 
getNString() - Method in class org.apache.sysds.runtime.iogen.ValueTrimFormat
 
getNthRow(int) - Method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNInputRowFetcher
Copy the nth row and return the dense pointer
getNulls() - Method in class org.apache.sysds.runtime.frame.data.columns.Array
 
getNulls() - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
getNulls() - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
getNumberColGroups() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfo
 
getNumberNonZeros(int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Get the number of nonZeros contained in this column group.
getNumberNonZeros(int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupValue
 
getNumberNonZeros(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
getNumberNonZeros(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
getNumberNonZeros(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
getNumberNonZeros(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
getNumberNonZeros(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
getNumberNonZeros(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
getNumberNonZeros(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
getNumberNonZeros(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
getNumberNonZeros(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Calculate the number of non zeros in the dictionary.
getNumberNonZeros(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
getNumberNonZeros(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
getNumberNonZeros(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
getNumberNonZeros(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
getNumberNonZeros(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
getNumberNonZerosWithReference(int[], double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Calculate the number of non zeros in the dictionary.
getNumberNonZerosWithReference(int[], double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
getNumberNonZerosWithReference(int[], double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
getNumberNonZerosWithReference(int[], double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
getNumberNonZerosWithReference(int[], double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
getNumberOfEntries() - Method in class org.apache.sysds.runtime.io.hdf5.H5GroupSymbolTableNode
 
getNumberOfValues(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Get the number of distinct tuples given that the column group has n columns
getNumberOfValues(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
getNumberOfValues(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
getNumberOfValues(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
getNumberOfValues(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
getNumberOfValues(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
getNumberTokenizeBlocks() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
getNumberTrue(boolean[]) - Static method in class org.apache.sysds.runtime.frame.data.lib.FrameLibRemoveEmpty
 
getNumBin() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
getNumBlocks() - 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.DataCharacteristics
 
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.AColGroup
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.tokenize.applier.TokenizerApplier
 
getNumCols() - Method in class org.apache.sysds.runtime.transform.tokenize.Tokenizer
 
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.bitmap.ABitmap
Get the number of columns encoded in this bitmap
getNumColumns() - Method in class org.apache.sysds.runtime.compress.bitmap.Bitmap
 
getNumColumns() - Method in class org.apache.sysds.runtime.compress.bitmap.MultiColBitmap
 
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() - Method in class org.apache.sysds.runtime.controlprogram.federated.MatrixLineagePair
 
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.frame.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.CM_N_COVCell
 
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
 
getNumColumns(DataCharacteristics) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
 
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.frame.data.columns.ColumnMetadata
 
getNumDistinctValues() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
getNumericLastIndex() - Method in class org.apache.sysds.runtime.iogen.RawRow
 
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
 
getNumExtraCols(IndexRange) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
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() - Method in class org.apache.sysds.runtime.controlprogram.parfor.TaskPartitioner
 
getNumIterations() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
getNumIterations(ForStatementBlock, long) - Static method in class org.apache.sysds.hops.OptimizerUtils
 
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
 
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
getNumNonZerosInOffset(int) - Method in class org.apache.sysds.runtime.compress.bitmap.ABitmap
Get the number of non zeros in a specific offset's tuple value.
getNumNonZerosInOffset(int) - Method in class org.apache.sysds.runtime.compress.bitmap.Bitmap
 
getNumNonZerosInOffset(int) - Method in class org.apache.sysds.runtime.compress.bitmap.MultiColBitmap
 
getNumOffs() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
Number of offsets, or number of non zero values.
getNumOffsets() - Method in class org.apache.sysds.runtime.compress.bitmap.ABitmap
Get the sum of offsets contained.
getNumOffsets(int) - Method in class org.apache.sysds.runtime.compress.bitmap.ABitmap
Get the number of offsets for a specific unique offset.
getNumOutCols() - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
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) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
 
getNumPreferredPartitions(DataCharacteristics, boolean) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
 
getNumPreferredPartitions(DataCharacteristics, JavaPairRDD<?, ?>) - 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() - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
 
getNumRemovedRows(boolean[]) - 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.ASDC
 
getNumRows() - Method in class org.apache.sysds.runtime.compress.colgroup.ASDCZero
 
getNumRows() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
getNumRows() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
 
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() - Method in class org.apache.sysds.runtime.controlprogram.federated.MatrixLineagePair
 
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.frame.data.FrameBlock
Get the number of rows of the frame block.
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.MatrixBlock
 
getNumRows() - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
getNumRows() - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
 
getNumRows(DataCharacteristics) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
 
getNumRows(DocumentRepresentation[]) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplier
 
getNumRows(DocumentRepresentation[]) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierCount
 
getNumRows(DocumentRepresentation[]) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierHash
 
getNumRows(DocumentRepresentation[]) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierPosition
 
getNumRowsEstimate() - Method in class org.apache.sysds.runtime.transform.tokenize.Tokenizer
 
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
 
getNumSubTokens() - Method in class org.apache.sysds.runtime.transform.tokenize.Token
 
getNumThreads() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
getNumThreads() - Method in class org.apache.sysds.runtime.instructions.cp.MMChainCPInstruction
 
getNumThreads() - Method in class org.apache.sysds.runtime.instructions.cp.MMTSJCPInstruction
 
getNumThreads() - Method in class org.apache.sysds.runtime.instructions.cp.QuantileSortCPInstruction
 
getNumThreads() - Method in class org.apache.sysds.runtime.matrix.operators.MultiThreadedOperator
 
getNumTotalPlans() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.Optimizer
 
getNumVals() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
Note cardinality is the same as number of distinct values.
getNumValues() - Method in class org.apache.sysds.runtime.compress.bitmap.ABitmap
Obtain number of distinct value groups in the column.
getNumValues() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Obtain number of distinct tuples in contained sets of values associated with this column group.
getNumValues() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupValue
 
getNumValues() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
getNumValues() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
getNumValues() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
getNumValues() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
getNumVectorIntermediates() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
 
getNumWorkers() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamServer
 
getNumZeros() - Method in class org.apache.sysds.runtime.compress.bitmap.ABitmap
Get the number of zero tuples contained in this bitmap.
getObjectHeaderAddress() - Method in class org.apache.sysds.runtime.io.hdf5.H5SymbolTableEntry
 
getObjectHeaderVersion() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
getObjectModificationTimeVersion() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
getObjectRowIterator(FrameBlock) - Static method in interface org.apache.sysds.runtime.frame.data.iterators.IteratorFactory
Get a row iterator over the frame where all fields are encoded as boxed objects according to their value types.
getObjectRowIterator(FrameBlock, int) - Static method in interface org.apache.sysds.runtime.frame.data.iterators.IteratorFactory
Get a row iterator over the frame where all selected fields are encoded as objects according to their value types.
getObjectRowIterator(FrameBlock, int[]) - Static method in interface org.apache.sysds.runtime.frame.data.iterators.IteratorFactory
Get a row iterator over the frame where all selected fields are encoded as boxed objects according to their value types.
getObjectRowIterator(FrameBlock, int, int) - Static method in interface org.apache.sysds.runtime.frame.data.iterators.IteratorFactory
Get a row iterator over the frame where all fields are encoded as boxed objects according to their value types.
getObjectRowIterator(FrameBlock, int, int, int) - Static method in interface org.apache.sysds.runtime.frame.data.iterators.IteratorFactory
Get a row iterator over the frame where all selected fields are encoded as boxed objects according to their value types.
getObjectRowIterator(FrameBlock, int, int, int[]) - Static method in interface org.apache.sysds.runtime.frame.data.iterators.IteratorFactory
Get a row iterator over the frame where all selected fields are encoded as boxed objects according to their value types.
getObjectRowIterator(FrameBlock, Types.ValueType[]) - Static method in interface org.apache.sysds.runtime.frame.data.iterators.IteratorFactory
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.
getOffset(long) - Method in class org.apache.sysds.runtime.transform.meta.TfOffsetMap
 
getOffsetColumnIndexFnObject(int) - Static method in class org.apache.sysds.runtime.functionobjects.OffsetColumnIndex
 
getOffsetIterator() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
Get an OffsetIterator of current offsets not maintaining the data index.
getOffsetIterator() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetByte
 
getOffsetIterator() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetChar
 
getOffsetIterator() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetEmpty
 
getOffsetIterator() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetSingle
 
getOffsetIterator() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetTwo
 
getOffsetIterator(int) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
Get an iterator that is pointing only at offsets from specific offset
getOffsetList() - Method in class org.apache.sysds.runtime.compress.bitmap.ABitmap
Get all the offset lists.
getOffsets() - Method in interface org.apache.sysds.runtime.compress.colgroup.AOffsetsGroup
 
getOffsets() - Method in class org.apache.sysds.runtime.compress.colgroup.ASDC
 
getOffsets() - Method in class org.apache.sysds.runtime.compress.colgroup.ASDCZero
 
getOffsets() - Method in class org.apache.sysds.runtime.compress.estim.encoding.SparseEncoding
 
getOffsetsIndex() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AIterator
Get the current offsets index, that points to the underlying offsets list.
getOffsetsList(int) - Method in class org.apache.sysds.runtime.compress.bitmap.ABitmap
Get a specific offset list.
getOffsetToFirst() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
Get the offset to the first index
getOffsetToFirst() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetByte
 
getOffsetToFirst() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetChar
 
getOffsetToFirst() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetEmpty
 
getOffsetToFirst() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetSingle
 
getOffsetToFirst() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetTwo
 
getOffsetToHeadOfFreeList() - Method in class org.apache.sysds.runtime.io.hdf5.H5LocalHeap
 
getOffsetToLast() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
Get the offset to the last value
getOffsetToLast() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetByte
 
getOffsetToLast() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetChar
 
getOffsetToLast() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetEmpty
 
getOffsetToLast() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetSingle
 
getOffsetToLast() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetTwo
 
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
getOpByRow() - Method in class org.apache.sysds.runtime.instructions.cp.ReshapeCPInstruction
 
getOpByRow() - Method in class org.apache.sysds.runtime.instructions.spark.MatrixReshapeSPInstruction
 
getOpCacheHits() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
getOpCacheTotal() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
getOpcode() - Method in class org.apache.sysds.runtime.instructions.Instruction
 
getOpcode() - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
getOpcode(Types.AggOp, Types.Direction) - Static method in class org.apache.sysds.lops.PartialAggregate
 
getOpcode(Types.OpOp2) - Static method in class org.apache.sysds.lops.BinaryM
 
getOpCode() - Method in class org.apache.sysds.lops.UnaryCP
 
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(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
 
getOpCols() - Method in class org.apache.sysds.runtime.instructions.cp.ReshapeCPInstruction
 
getOpCols() - Method in class org.apache.sysds.runtime.instructions.spark.MatrixReshapeSPInstruction
 
getOpDims() - Method in class org.apache.sysds.runtime.instructions.cp.ReshapeCPInstruction
 
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() - Method in class org.apache.sysds.lops.Data
method to get operation type, i.e.
getOperationType() - Method in class org.apache.sysds.lops.PickByCount
 
getOperationType() - Method in class org.apache.sysds.runtime.instructions.cp.QuantilePickCPInstruction
 
getOperationType() - Method in class org.apache.sysds.runtime.instructions.spark.QuantilePickSPInstruction
 
getOperationType(String) - Static method in class org.apache.sysds.lops.Ctable
 
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
 
getOperatorClass() - Method in class org.apache.sysds.runtime.instructions.spark.SpoofSPInstruction
 
getOperatorType() - Method in class org.apache.sysds.runtime.matrix.operators.CountDistinctOperator
 
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.
getOpRows() - Method in class org.apache.sysds.runtime.instructions.cp.ReshapeCPInstruction
 
getOpRows() - Method in class org.apache.sysds.runtime.instructions.spark.MatrixReshapeSPInstruction
 
getOps() - Method in class org.apache.sysds.runtime.compress.workload.AWTreeNode
 
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
 
getOptCount() - Static method in class org.apache.sysds.utils.stats.ParForStatistics
 
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
 
getOptTime() - Static method in class org.apache.sysds.utils.stats.ParForStatistics
 
getOpType() - Method in class org.apache.sysds.lops.SortKeys
 
getOrCreate(ColIndexes, ColIndexes, ColIndexes) - Method in class org.apache.sysds.runtime.compress.cocode.Memorizer
 
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
 
getOrDefault(double, int) - Method in class org.apache.sysds.runtime.compress.utils.DoubleCountHashMap
 
getOrder() - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
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
 
getOutDim1() - Method in class org.apache.sysds.runtime.instructions.cp.CtableCPInstruction
 
getOutDim1() - Method in class org.apache.sysds.runtime.instructions.spark.CtableSPInstruction
 
getOutDim2() - Method in class org.apache.sysds.runtime.instructions.cp.CtableCPInstruction
 
getOutDim2() - Method in class org.apache.sysds.runtime.instructions.spark.CtableSPInstruction
 
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() - Method in class org.apache.sysds.runtime.instructions.cp.SqlCPInstruction
 
getOutput() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
 
getOutput() - Method in class org.apache.sysds.runtime.instructions.spark.SpoofSPInstruction
 
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(int) - Method in class org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction
 
getOutput2() - Method in class org.apache.sysds.runtime.instructions.cp.ListAppendRemoveCPInstruction
 
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
 
getOutputEmptyBlocks() - Method in class org.apache.sysds.runtime.instructions.spark.ReblockSPInstruction
 
getOutputIds() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedUDF
 
getOutputIds() - Method in class org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction.ExecuteFrameEncoder
 
getOutputIds() - Method in class org.apache.sysds.runtime.instructions.fed.ParameterizedBuiltinFEDInstruction.DecodeMatrix
 
getOutputIds() - Method in class org.apache.sysds.runtime.instructions.fed.ReorgFEDInstruction.DiagMatrix
 
getOutputIds() - Method in class org.apache.sysds.runtime.instructions.fed.ReorgFEDInstruction.Rdiag
 
getOutputMemEstimate() - Method in class org.apache.sysds.hops.Hop
Output memory estimate in bytes.
getOutputMemEstimate(double) - Method in class org.apache.sysds.hops.Hop
Output memory estimate in bytes with negative memory estimates replaced by the injected default.
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
getOutputParamNames() - Method in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
 
getOutputParams() - Method in class org.apache.sysds.parser.FunctionStatement
 
getOutputParams() - Method in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
 
getOutputRow(int, List<Map<T, E>>) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplier
 
getOutputRow(int, DocumentRepresentation[]) - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplier
 
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
 
getOutputs() - Method in class org.apache.sysds.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction
 
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.
getOutSchema() - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplier
 
getOutSchema() - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierCount
 
getOutSchema() - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierHash
 
getOutSchema() - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierPosition
 
getOverlappingDecompressions() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
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
 
getParallelApplyBlocks() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
getParallelBinaryReadParallelism() - Static method in class org.apache.sysds.hops.OptimizerUtils
 
getParallelBinaryWriteParallelism() - Static method in class org.apache.sysds.hops.OptimizerUtils
 
getParallelBuildBlocks() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
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(int) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
 
getParam(String) - Method in class org.apache.sysds.hops.DataGenOp
 
getParam(String) - Method in class org.apache.sysds.runtime.instructions.cp.ParameterizedBuiltinCPInstruction
 
getParam(String) - Method in class org.apache.sysds.runtime.instructions.fed.ParameterizedBuiltinFEDInstruction
 
getParam(OptNode.ParamType) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
 
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
 
getParameterMap() - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction
 
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
 
getParamMap(FunctionOp) - Static method in class org.apache.sysds.hops.fedplanner.FederatedPlannerUtils
Return parameter map containing the mapping from parameter name to input hop for all parameters of the function hop.
getParams() - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction
 
getParamservPseudoFunctionCalls() - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
 
getParent() - Method in class org.apache.sysds.hops.Hop
 
getParent() - Method in class org.apache.sysds.runtime.compress.workload.OpMetadata
 
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
 
getParsedBuiltinFunctions() - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
 
getParsedBuiltinFunctionsNs() - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
 
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
 
getPartialBuildTask(CacheBlock<?>, int, int, HashMap<Integer, Object>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
getPartialBuildTask(CacheBlock<?>, int, int, HashMap<Integer, Object>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
getPartialBuildTask(CacheBlock<?>, int, int, HashMap<Integer, Object>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
getPartialCTableTask(MatrixBlock, MatrixBlock, MatrixBlock, int, int, ArrayList<CTableMap>) - Method in class org.apache.sysds.runtime.functionobjects.CTable
 
getPartialDecryption(CiphertextMatrix[]) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.FederatedPSControlThread
 
getPartialMergeBuildTask(HashMap<Integer, ?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
getPartialMergeBuildTask(HashMap<Integer, ?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
getPartialMergeBuildTask(HashMap<Integer, ?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
getPartialPublicKey() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.FederatedPSControlThread
 
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
 
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
 
getPartType() - Method in enum org.apache.sysds.hops.fedplanner.FTypes.FType
 
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
 
getPattern() - Method in class org.apache.sysds.runtime.matrix.operators.UnaryOperator
 
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
 
getPID() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
 
getPinnedDataSize() - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
 
getPlanCacheHits() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
getPlanCacheTotal() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
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
 
getPlanner() - Method in enum org.apache.sysds.hops.fedplanner.FTypes.FederatedPlanner
 
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
 
getPointerAddress(Pointer) - Static method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
 
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
getPow2(int) - Static method in interface org.apache.sysds.runtime.compress.utils.Util
 
getPower2FnObject() - Static method in class org.apache.sysds.runtime.functionobjects.Power2
 
getPowerFnObject() - Static method in class org.apache.sysds.runtime.functionobjects.Power
 
getPreAggregateSize() - Method in class org.apache.sysds.runtime.compress.colgroup.APreAgg
 
getPreAggregateSize() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
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() - Method in class org.apache.sysds.runtime.privacy.PrivacyConstraint
 
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
 
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
 
getRank() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
getRatio() - Method in class org.apache.sysds.runtime.compress.CompressionStatistics
 
getRaw() - Method in class org.apache.sysds.runtime.iogen.RawRow
 
getRawLastIndex() - Method in class org.apache.sysds.runtime.iogen.RawRow
 
getRcdMap() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
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
 
getRDDObject() - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
 
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.
getReader() - Method in class org.apache.sysds.runtime.iogen.GenerateReader.GenerateReaderFrame
 
getReader() - Method in class org.apache.sysds.runtime.iogen.GenerateReader.GenerateReaderMatrix
 
getReadOnlyParentMatrixVars() - Method in class org.apache.sysds.parser.ParForStatementBlock
 
getRecodeMap() - Method in class org.apache.sysds.runtime.frame.data.columns.Array
 
getRecodeMap(int) - Method in class org.apache.sysds.runtime.frame.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.
getRecompiledPredDAGs() - Static method in class org.apache.sysds.utils.stats.RecompileStatistics
 
getRecompiledSBDAGs() - Static method in class org.apache.sysds.utils.stats.RecompileStatistics
 
getRecompileTime() - Static method in class org.apache.sysds.utils.stats.RecompileStatistics
 
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
 
getRepetitions() - Method in class org.apache.sysds.hops.Hop
 
getReplacement(int) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
 
getReplacements() - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
 
getReps() - Method in class org.apache.sysds.runtime.compress.workload.WTreeNode
 
getRequiredPartialResult(Operator) - Method in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
 
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.
getRequiredResult(Operator) - Method in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
Return the result of the aggregated operation given the operator.
getReset() - Method in class org.apache.sysds.hops.recompile.RecompileStatus
 
getResetClone() - Method in class org.apache.sysds.runtime.iogen.RawRow
 
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
 
getReusableOpcodes() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
 
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
 
getRight() - Method in class org.apache.sysds.runtime.compress.workload.OpSided
 
getRightMultiplications() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
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.compress.workload.WTreeRoot
Get the Root hop instruction, that is producing a result used in the rest of the tree.
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
 
getRow() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
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
 
getRowLower() - Method in class org.apache.sysds.runtime.instructions.cp.IndexingCPInstruction
 
getRowLower() - Method in class org.apache.sysds.runtime.instructions.spark.IndexingSPInstruction
 
getRowLowerBound() - Method in class org.apache.sysds.parser.IndexedIdentifier
 
getRowLowerEqualsUpper() - Method in class org.apache.sysds.parser.IndexedIdentifier
 
getRowPattern() - Method in class org.apache.sysds.runtime.iogen.CustomProperties
 
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
 
getRows() - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
 
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() - Method in class org.apache.sysds.runtime.codegen.SpoofRowwise
 
getRowType(Hop, Hop...) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
getRowUpper() - Method in class org.apache.sysds.runtime.instructions.cp.IndexingCPInstruction
 
getRowUpper() - Method in class org.apache.sysds.runtime.instructions.spark.IndexingSPInstruction
 
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.
getRuntimePlanMapping() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTree
 
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
 
getSampleFrame() - Method in class org.apache.sysds.runtime.iogen.SampleProperties
 
getSampleMatrix() - Method in class org.apache.sysds.runtime.iogen.SampleProperties
 
getSampleRaw() - Method in class org.apache.sysds.runtime.iogen.SampleProperties
 
getSBHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
getSBID() - Method in class org.apache.sysds.parser.StatementBlock
 
getScalar() - Method in class org.apache.sysds.runtime.matrix.operators.QuaternaryOperator
Obtain epsilon value
getScalarInput(String, Types.ValueType, boolean) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
getScalarInput(CPOperand) - 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.dictionary.QDictionary
 
getScans() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
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() - 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.frame.data.FrameBlock
Returns the schema of the frame block.
getSchema() - Method in class org.apache.sysds.runtime.meta.MetaDataAll
 
getSchema() - Method in class org.apache.sysds.runtime.transform.decode.Decoder
 
getSchema() - Method in class org.apache.sysds.runtime.transform.tokenize.Tokenizer
 
getSchema(int, int) - Method in class org.apache.sysds.runtime.controlprogram.caching.FrameObject
Obtain schema of value types
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.frame.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.
getSealClient() - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
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
 
getSerializedBytes() - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
 
getSerializedFedResponseLineageItem(LineageItem) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
 
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
 
getSignLocation() - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
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.hops.fedplanner.MemoTable
 
getSize() - Method in class org.apache.sysds.parser.VariableSet
 
getSize() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
Get the number of contained elements, This method iterate the entire offset list, so it is not constant lookup.
getSize() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetByte
 
getSize() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetChar
 
getSize() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetEmpty
 
getSize() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetSingle
 
getSize() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetTwo
 
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() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
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.BroadcastObject
 
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.io.hdf5.H5BufferBuilder
 
getSize() - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
getSize() - Method in class org.apache.sysds.runtime.io.hdf5.message.H5DataLayoutMessage
 
getSize() - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
 
getSize(int) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
 
getSizeAllocatedGPUPointer(Pointer) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryManager
Get size of allocated GPU Pointer
getSizeofPinnedObjects() - Static method in class org.apache.sysds.utils.Statistics
 
getSizeOnDevice() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
 
getSlopeForColumn(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
getSlopes() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
getSoftReferenceToDecompressed() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
getSortedSample(int, int, long, int) - Static method in class org.apache.sysds.runtime.compress.estim.ComEstSample
 
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
 
getSpaceAllocationTime() - Method in class org.apache.sysds.runtime.io.hdf5.message.H5FillValueMessage
 
getSparkClusterConfig() - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
Obtains the lazily analyzed spark cluster configuration.
getSparkCollectCount() - Static method in class org.apache.sysds.utils.stats.SparkStatistics
 
getSparkContext() - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
Returns the used singleton spark context.
getSparkContext(MLContext) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
Obtain the 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.compress.CompressedMatrixBlock
 
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.compress.CompressedMatrixBlock
 
getSparseBlockIterator() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
getSparseBlockIterator(int, int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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
 
getSparseDelim() - Method in class org.apache.sysds.runtime.meta.MetaDataAll
 
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.
getSparseMatrixOutputForGPUInstruction(String, long, long, long, boolean) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
getSparseProductOutputNnz(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.hops.estim.EstimationUtils
 
getSparseRowsWZeros() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
getSparseRowsWZeros() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
getSparsity() - Method in class org.apache.sysds.hops.cost.VarStats
 
getSparsity() - Method in class org.apache.sysds.hops.Hop
 
getSparsity() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Get the sparsity of the dictionary.
getSparsity() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
getSparsity() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
getSparsity() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
getSparsity() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
getSparsity() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
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
 
getSparsity(long[], long) - Static method in class org.apache.sysds.hops.OptimizerUtils
 
getSparsity(long, long, long) - Static method in class org.apache.sysds.hops.OptimizerUtils
 
getSparsity(Hop) - Static method in class org.apache.sysds.hops.OptimizerUtils
 
getSparsity(DataCharacteristics) - Static method in class org.apache.sysds.hops.OptimizerUtils
 
getSpBroadcastSize() - Method in class org.apache.sysds.hops.Hop
 
getSpecialValueBit(int) - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
getSpecialValueBits() - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
getSPInstructionType() - Method in class org.apache.sysds.runtime.instructions.spark.SPInstruction
 
getSplits(JobConf, int) - Method in class org.apache.sysds.runtime.util.InputStreamInputFormat
 
getSplittedStringAsArray(String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
getSpoofAggOp() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
 
getSpoofOperator() - Method in class org.apache.sysds.runtime.instructions.cp.SpoofCPInstruction
 
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
 
getStartIndex(int) - Method in class org.apache.sysds.runtime.transform.tokenize.Token
 
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() - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
 
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.
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.
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(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Get a string representation of the dictionary, that considers the layout of the data.
getString(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
getString(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
getString(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
getString(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
getString(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
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
 
getString(int, int) - Method in interface org.apache.sysds.runtime.controlprogram.caching.CacheBlock
Returns the string of the value at the passed row and column.
getString(int, int) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
getString(int, int) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
getString(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
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
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
getStringOfActualValue() - Method in class org.apache.sysds.runtime.iogen.ValueTrimFormat
 
getStringRepresentation() - Static method in class org.apache.sysds.hops.fedplanner.FederatedCompilationTimer
 
getStringRowIterator(FrameBlock) - Static method in interface org.apache.sysds.runtime.frame.data.iterators.IteratorFactory
Get a row iterator over the frame where all fields are encoded as strings independent of their value types.
getStringRowIterator(FrameBlock, int) - Static method in interface org.apache.sysds.runtime.frame.data.iterators.IteratorFactory
Get a row iterator over the frame where all selected fields are encoded as strings independent of their value types.
getStringRowIterator(FrameBlock, int[]) - Static method in interface org.apache.sysds.runtime.frame.data.iterators.IteratorFactory
Get a row iterator over the frame where all selected fields are encoded as strings independent of their value types.
getStringRowIterator(FrameBlock, int, int) - Static method in interface org.apache.sysds.runtime.frame.data.iterators.IteratorFactory
Get a row iterator over the frame where all fields are encoded as strings independent of their value types.
getStringRowIterator(FrameBlock, int, int, int) - Static method in interface org.apache.sysds.runtime.frame.data.iterators.IteratorFactory
Get a row iterator over the frame where all selected fields are encoded as strings independent of their value types.
getStringRowIterator(FrameBlock, int, int, int[]) - Static method in interface org.apache.sysds.runtime.frame.data.iterators.IteratorFactory
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
 
getSum(int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Short hand method for getting the sum of this column group
getSum(int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupCompressed
 
getSum(int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
getSumCounts() - Method in class org.apache.sysds.runtime.compress.utils.DblArrayCountHashMap
 
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
 
getSuperblock() - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
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.
getSymbolTableEntries() - Method in class org.apache.sysds.runtime.io.hdf5.H5GroupSymbolTableNode
 
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
 
getTarget(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction
 
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
 
getTasks(FrameBlock, DocumentRepresentation[]) - Method in class org.apache.sysds.runtime.transform.tokenize.builder.TokenizerBuilder
 
getTemplate() - Method in class org.apache.sysds.hops.codegen.cplan.CodeTemplate
 
getTemplate(boolean, long, ArrayList<CNode>, SpoofCompiler.GeneratorAPI) - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeNary.NaryType
 
getTemplate(String) - Static method in class org.apache.sysds.hops.codegen.cplan.CodeTemplate
 
getTemplate(CNodeBinary.BinType, boolean, boolean, boolean, boolean, boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CodeTemplate
 
getTemplate(CNodeBinary.BinType, boolean, boolean, boolean, boolean, boolean) - Method in class org.apache.sysds.hops.codegen.cplan.cuda.Binary
 
getTemplate(CNodeBinary.BinType, boolean, boolean, boolean, boolean, boolean) - Method in class org.apache.sysds.hops.codegen.cplan.java.Binary
 
getTemplate(CNodeTernary.TernaryType, boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CodeTemplate
 
getTemplate(CNodeTernary.TernaryType, boolean) - Method in class org.apache.sysds.hops.codegen.cplan.cuda.Ternary
 
getTemplate(CNodeTernary.TernaryType, boolean) - Method in class org.apache.sysds.hops.codegen.cplan.java.Ternary
 
getTemplate(CNodeUnary.UnaryType, boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CodeTemplate
 
getTemplate(CNodeUnary.UnaryType, boolean) - Method in class org.apache.sysds.hops.codegen.cplan.cuda.Unary
 
getTemplate(CNodeUnary.UnaryType, boolean) - Method in class org.apache.sysds.hops.codegen.cplan.java.Unary
 
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
 
getTerminalHops() - Method in class org.apache.sysds.hops.fedplanner.FederatedPlannerCostbased
 
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.hops.recompile.RecompileStatus
 
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
 
getTimeEstimate(ProgramBlock, ExecutionContext, boolean) - Static method in class org.apache.sysds.hops.cost.CostEstimationWrapper
 
getTimeEstimate(ProgramBlock, LocalVariableMap, HashMap<String, VarStats>, boolean) - Method in class org.apache.sysds.hops.cost.CostEstimator
 
getTimeEstimate(Program, ExecutionContext) - 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
 
getTimestamp(String[]) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
getTLeft() - Method in class org.apache.sysds.runtime.compress.workload.OpSided
 
getTmpParforFunctions() - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
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
 
getTokenizeNumThreads() - Static method in class org.apache.sysds.hops.OptimizerUtils
 
getTokenNames() - Method in class org.apache.sysds.parser.dml.DmlLexer
Deprecated.
getTokenNames() - Method in class org.apache.sysds.parser.dml.DmlParser
Deprecated.
getTokens() - Method in class org.apache.sysds.runtime.transform.tokenize.DocumentRepresentation
 
getToLops() - Method in class org.apache.sysds.parser.ForStatementBlock
 
getTotal() - Method in class org.apache.sysds.hops.cost.FederatedCost
Get the total sum of costs stored in this object.
getTotalFedTransferCount() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
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
 
getTotalLength() - Method in class org.apache.sysds.runtime.io.hdf5.message.H5DataSpaceMessage
 
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
 
getTransformNumThreads() - Static method in class org.apache.sysds.hops.OptimizerUtils
 
getTransientInputs(Hop, Map<String, Hop>, Map<String, Hop>, LocalVariableMap) - Static method in class org.apache.sysds.hops.fedplanner.FederatedPlannerUtils
Get transient inputs from either paramMap or transientWrites.
getTRight() - Method in class org.apache.sysds.runtime.compress.workload.OpSided
 
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.
getTupleSparsity() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
 
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.colgroup.mapping.AMapToData
 
getType() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
getType() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
getType() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
getType() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
getType() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
getType() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToUByte
 
getType() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
getType() - Method in class org.apache.sysds.runtime.compress.workload.AWTreeNode
 
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
 
getUMMFree() - Static method in class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
 
getUMMSize() - Static method in class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
 
getUncompressed() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
getUncompressed(String) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
getUncompressed(String, int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
getUncompressed(MatrixValue) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
getUncompressed(MatrixValue, String) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
getUnique() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Get the number of unique values inside this map.
getUnique() - Method in class org.apache.sysds.runtime.compress.estim.encoding.ConstEncoding
 
getUnique() - Method in class org.apache.sysds.runtime.compress.estim.encoding.DenseEncoding
 
getUnique() - Method in class org.apache.sysds.runtime.compress.estim.encoding.EmptyEncoding
 
getUnique() - Method in interface org.apache.sysds.runtime.compress.estim.encoding.IEncode
Get the number of unique values in this encoding
getUnique() - Method in class org.apache.sysds.runtime.compress.estim.encoding.SparseEncoding
 
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.
getUniqueValues(MatrixBlock, Types.Direction) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixSketch
 
getUniqueWorkingDir(String) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
 
getUnixEpocSecond() - Method in class org.apache.sysds.runtime.io.hdf5.message.H5ObjectModificationTimeMessage
 
getUnorderedCountsAndReplaceWithUIDs() - Method in class org.apache.sysds.runtime.compress.utils.DblArrayCountHashMap
 
getUnorderedCountsAndReplaceWithUIDs() - Method in class org.apache.sysds.runtime.compress.utils.DoubleCountHashMap
 
getUnorderedCountsAndReplaceWithUIDsWithExtraCell() - Method in class org.apache.sysds.runtime.compress.utils.DblArrayCountHashMap
 
getUnorderedCountsAndReplaceWithUIDsWithout0() - Method in class org.apache.sysds.runtime.compress.utils.DoubleCountHashMap
 
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
 
getUpperBoundValue() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Get the maximum value that is possible to allocate inside this map.
getUpperBoundValue() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
getUpperBoundValue() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
getUpperBoundValue() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
getUpperBoundValue() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
getUpperBoundValue() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
getUpperBoundValue() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToUByte
 
getUpperBoundValue() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
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.
getUtilization() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
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
 
getValidationTime() - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
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 enum org.apache.sysds.common.Types.AggOp
 
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() - Method in enum org.apache.sysds.runtime.codegen.SpoofCellwise.CellType
 
getValue() - Method in enum org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
 
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.data.SparseRowScalar
 
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() - Method in class org.apache.sysds.runtime.lineage.BooleanArray32
 
getValue() - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
getValue() - Method in class org.apache.sysds.runtime.matrix.data.Pair
 
getValue() - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
 
getValue(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Get Specific value contained in the dictionary at index.
getValue(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
getValue(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
getValue(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
getValue(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
getValue(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
getValue(int, int) - Method in class org.apache.sysds.runtime.codegen.SpoofOperator.SideInput
 
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(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(int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Get Specific value contain in dictionary at index.
getValue(int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
getValue(int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
getValue(int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
getValue(int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
getValue(int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
getValue(MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinct.CountDistinctFunctionSketch
 
getValue(MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox.KMVSketch
 
getValue(MatrixBlock) - Method in interface org.apache.sysds.runtime.matrix.data.sketch.MatrixSketch
Get scalar distinct count from an input matrix block.
getValueByte(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
getValueDenseUnsafe(int, int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
getValueDenseUnsafe(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
getValueFromSketch(CorrMatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinct.CountDistinctFunctionSketch
 
getValueFromSketch(CorrMatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox.KMVSketch
 
getValueFromSketch(CorrMatrixBlock) - Method in interface org.apache.sysds.runtime.matrix.data.sketch.MatrixSketch
Obtain matrix distinct count value from estimation Used for estimating distinct in rows or columns.
getValues() - Method in class org.apache.sysds.runtime.compress.bitmap.Bitmap
Get all values without unnecessary allocations and copies.
getValues() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
Get dense values from colgroupConst.
getValues() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Get all the values contained in the dictionary as a linearized double array.
getValues() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
getValues() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
getValues() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
getValues() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
getValues() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
getValues(int) - Method in class org.apache.sysds.runtime.compress.bitmap.MultiColBitmap
Obtain tuple of column values associated with index.
getValuesByte() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
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.frame.data.columns.Array
Get the current value type of this array.
getValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
getValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
getValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
getValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
getValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
getValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
getValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
getValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
getValueType() - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
getValueType() - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
 
getValueType() - Method in class org.apache.sysds.runtime.instructions.cp.Data
 
getValueType() - Method in class org.apache.sysds.runtime.iogen.ValueTrimFormat
 
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(SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNode
 
getVarname(SpoofCompiler.GeneratorAPI) - 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(SpoofCompiler.GeneratorAPI) - 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
 
getVersion() - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
getVersion() - Method in class org.apache.sysds.runtime.io.hdf5.H5GroupSymbolTableNode
 
getVersion() - Method in class org.apache.sysds.runtime.io.hdf5.H5LocalHeap
 
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
 
getWorkerDataObjects() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
getWorkerEvents() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
getWorkerID() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcCall
 
getWorkerName() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.FederatedPSControlThread
 
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
 
getWorkerOnlineStatus(Long) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.WorkerService
 
getWorkerRequests() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
getWorkerStatistics(Long, String) - Static method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.StatisticsService
 
getWorkingDir(String) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
 
getWorkingFilePath(String) - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
 
getWrappedTaskFuture() - Method in class org.apache.sysds.runtime.util.DependencyWrapperTask
 
getWrappedTasks() - Method in class org.apache.sysds.runtime.util.DependencyWrapperTask
 
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
 
GLM - org.apache.sysds.common.Builtins
 
GLM_PREDICT - org.apache.sysds.common.Builtins
 
GLOBAL_MEAN - org.apache.sysds.runtime.transform.encode.EncoderMVImpute.MVMethod
 
GLOBAL_MODE - org.apache.sysds.runtime.transform.encode.EncoderMVImpute.MVMethod
 
GMM - org.apache.sysds.common.Builtins
 
GMM_PREDICT - org.apache.sysds.common.Builtins
 
GNMF - org.apache.sysds.common.Builtins
 
goToPositionWithWriteZero(long) - Method in class org.apache.sysds.runtime.io.hdf5.H5BufferBuilder
 
gpu - Variable in class org.apache.sysds.api.DMLOptions
 
GPU - org.apache.sysds.common.Types.ExecType
 
GPU - org.apache.sysds.runtime.instructions.Instruction.IType
 
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
 
gpuEvictionThread - Static variable in class org.apache.sysds.runtime.lineage.LineageGPUCacheEviction
 
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
 
GPUMemoryEviction - Class in org.apache.sysds.runtime.instructions.gpu.context
 
GPUMemoryEviction() - Constructor for class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryEviction
 
GPUMemoryEviction(int) - Constructor for class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryEviction
 
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
GPUObject(GPUContext, GPUObject, MatrixObject) - Constructor for class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
 
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
 
GREATER - org.apache.sysds.common.Types.OpOp2
 
GREATER - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
GREATER - org.apache.sysds.parser.Expression.RelationalOp
 
GREATEREQUAL - org.apache.sysds.common.Types.OpOp2
 
GREATEREQUAL - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
GREATEREQUAL - org.apache.sysds.parser.Expression.RelationalOp
 
GreaterThan - Class in org.apache.sysds.runtime.functionobjects
 
GreaterThanEquals - Class in org.apache.sysds.runtime.functionobjects
 
GREEDY - org.apache.sysds.runtime.compress.cocode.CoCoderFactory.PartitionerType
 
GRID_SEARCH - org.apache.sysds.common.Builtins
 
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
 
GroupedAgg - org.apache.sysds.lops.Lop.Type
 
GROUPEDAGG - org.apache.sysds.common.Builtins
 
GROUPEDAGG - org.apache.sysds.common.Types.ParamBuiltinOp
 
GroupedAggM - org.apache.sysds.lops.Lop.Type
 
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.compress.CompressedMatrixBlock
 
groupedAggOperations(MatrixValue, MatrixValue, MatrixValue, int, Operator, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
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
 
GroupedAggregate - Class in org.apache.sysds.lops
Lop to perform grouped aggregates
GroupedAggregate(HashMap<String, Lop>, Types.DataType, Types.ValueType, Types.ExecType) - Constructor for class org.apache.sysds.lops.GroupedAggregate
 
GroupedAggregate(HashMap<String, Lop>, Types.DataType, Types.ValueType, Types.ExecType, boolean) - Constructor for class org.apache.sysds.lops.GroupedAggregate
 
GroupedAggregate(HashMap<String, Lop>, Types.DataType, Types.ValueType, Types.ExecType, int) - Constructor for class org.apache.sysds.lops.GroupedAggregate
 
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, Types.ExecType) - Constructor for class org.apache.sysds.lops.GroupedAggregateM
 
GroupedAggregateM.CacheType - Enum in org.apache.sysds.lops
 
Grouping - org.apache.sysds.lops.Lop.Type
 
groupInternalNodeK - Variable in class org.apache.sysds.runtime.io.hdf5.H5Superblock
 
groupLeafNodeK - Variable in class org.apache.sysds.runtime.io.hdf5.H5Superblock
 

H

h(int, int) - Method in class org.apache.sysds.hops.estim.EstimatorSampleRa
 
H - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
 
H5 - Class in org.apache.sysds.runtime.io.hdf5
 
H5() - Constructor for class org.apache.sysds.runtime.io.hdf5.H5
 
H5BTree - Class in org.apache.sysds.runtime.io.hdf5
 
H5BTree(H5RootObject, byte, byte, int, long, long, List<Long>) - Constructor for class org.apache.sysds.runtime.io.hdf5.H5BTree
 
H5BTree(H5RootObject, long) - Constructor for class org.apache.sysds.runtime.io.hdf5.H5BTree
 
H5BufferBuilder - Class in org.apache.sysds.runtime.io.hdf5
 
H5BufferBuilder() - Constructor for class org.apache.sysds.runtime.io.hdf5.H5BufferBuilder
 
H5Constants - Class in org.apache.sysds.runtime.io.hdf5
 
H5Constants() - Constructor for class org.apache.sysds.runtime.io.hdf5.H5Constants
 
H5ContiguousDataset - Class in org.apache.sysds.runtime.io.hdf5
 
H5ContiguousDataset(H5RootObject, H5ObjectHeader) - Constructor for class org.apache.sysds.runtime.io.hdf5.H5ContiguousDataset
 
H5DataLayoutMessage - Class in org.apache.sysds.runtime.io.hdf5.message
 
H5DataLayoutMessage(H5RootObject, BitSet, long, long) - Constructor for class org.apache.sysds.runtime.io.hdf5.message.H5DataLayoutMessage
 
H5DataLayoutMessage(H5RootObject, BitSet, ByteBuffer) - Constructor for class org.apache.sysds.runtime.io.hdf5.message.H5DataLayoutMessage
 
H5DataSpaceMessage - Class in org.apache.sysds.runtime.io.hdf5.message
 
H5DataSpaceMessage(H5RootObject, BitSet) - Constructor for class org.apache.sysds.runtime.io.hdf5.message.H5DataSpaceMessage
 
H5DataSpaceMessage(H5RootObject, BitSet, ByteBuffer) - Constructor for class org.apache.sysds.runtime.io.hdf5.message.H5DataSpaceMessage
 
H5DataTypeMessage - Class in org.apache.sysds.runtime.io.hdf5.message
 
H5DataTypeMessage(H5RootObject, BitSet, ByteBuffer) - Constructor for class org.apache.sysds.runtime.io.hdf5.message.H5DataTypeMessage
 
H5DataTypeMessage(H5RootObject, BitSet, H5DoubleDataType) - Constructor for class org.apache.sysds.runtime.io.hdf5.message.H5DataTypeMessage
 
H5Dcreate(H5RootObject, long, long, String) - Static method in class org.apache.sysds.runtime.io.hdf5.H5
 
H5Dopen(H5RootObject, String) - Static method in class org.apache.sysds.runtime.io.hdf5.H5
 
H5DoubleDataType - Class in org.apache.sysds.runtime.io.hdf5
 
H5DoubleDataType() - Constructor for class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
H5DoubleDataType(ByteBuffer) - Constructor for class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
H5Dread(H5ContiguousDataset, int, double[]) - Static method in class org.apache.sysds.runtime.io.hdf5.H5
 
H5Dread(H5RootObject, H5ContiguousDataset, double[][]) - Static method in class org.apache.sysds.runtime.io.hdf5.H5
 
H5Dwrite(H5RootObject, double[]) - Static method in class org.apache.sysds.runtime.io.hdf5.H5
 
H5Dwrite(H5RootObject, double[][]) - Static method in class org.apache.sysds.runtime.io.hdf5.H5
 
H5FillValueMessage - Class in org.apache.sysds.runtime.io.hdf5.message
 
H5FillValueMessage(H5RootObject, BitSet, int, int, boolean) - Constructor for class org.apache.sysds.runtime.io.hdf5.message.H5FillValueMessage
 
H5FillValueMessage(H5RootObject, BitSet, ByteBuffer) - Constructor for class org.apache.sysds.runtime.io.hdf5.message.H5FillValueMessage
 
H5Fopen(BufferedInputStream) - Static method in class org.apache.sysds.runtime.io.hdf5.H5
 
H5GroupSymbolTableNode - Class in org.apache.sysds.runtime.io.hdf5
 
H5GroupSymbolTableNode(H5RootObject, long) - Constructor for class org.apache.sysds.runtime.io.hdf5.H5GroupSymbolTableNode
 
H5GroupSymbolTableNode(H5RootObject, short, H5SymbolTableEntry[]) - Constructor for class org.apache.sysds.runtime.io.hdf5.H5GroupSymbolTableNode
 
H5LocalHeap - Class in org.apache.sysds.runtime.io.hdf5
 
H5LocalHeap(H5RootObject, long) - Constructor for class org.apache.sysds.runtime.io.hdf5.H5LocalHeap
 
H5LocalHeap(H5RootObject, String, long, long, long) - Constructor for class org.apache.sysds.runtime.io.hdf5.H5LocalHeap
 
H5Message - Class in org.apache.sysds.runtime.io.hdf5.message
 
H5Message(H5RootObject, BitSet) - Constructor for class org.apache.sysds.runtime.io.hdf5.message.H5Message
 
H5NilMessage - Class in org.apache.sysds.runtime.io.hdf5.message
 
H5NilMessage(H5RootObject, BitSet) - Constructor for class org.apache.sysds.runtime.io.hdf5.message.H5NilMessage
 
H5NilMessage(H5RootObject, BitSet, ByteBuffer) - Constructor for class org.apache.sysds.runtime.io.hdf5.message.H5NilMessage
 
H5ObjectHeader - Class in org.apache.sysds.runtime.io.hdf5
 
H5ObjectHeader(H5RootObject, long) - Constructor for class org.apache.sysds.runtime.io.hdf5.H5ObjectHeader
 
H5ObjectHeader(H5RootObject, String) - Constructor for class org.apache.sysds.runtime.io.hdf5.H5ObjectHeader
 
H5ObjectModificationTimeMessage - Class in org.apache.sysds.runtime.io.hdf5.message
 
H5ObjectModificationTimeMessage(H5RootObject, BitSet, long) - Constructor for class org.apache.sysds.runtime.io.hdf5.message.H5ObjectModificationTimeMessage
 
H5ObjectModificationTimeMessage(H5RootObject, BitSet, ByteBuffer) - Constructor for class org.apache.sysds.runtime.io.hdf5.message.H5ObjectModificationTimeMessage
 
H5RootObject - Class in org.apache.sysds.runtime.io.hdf5
 
H5RootObject() - Constructor for class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
H5RuntimeException - Exception in org.apache.sysds.runtime.io.hdf5
 
H5RuntimeException(Exception) - Constructor for exception org.apache.sysds.runtime.io.hdf5.H5RuntimeException
 
H5RuntimeException(String) - Constructor for exception org.apache.sysds.runtime.io.hdf5.H5RuntimeException
 
H5RuntimeException(String, Exception) - Constructor for exception org.apache.sysds.runtime.io.hdf5.H5RuntimeException
 
H5Screate(BufferedOutputStream, long, long) - Static method in class org.apache.sysds.runtime.io.hdf5.H5
 
H5Superblock - Class in org.apache.sysds.runtime.io.hdf5
 
H5Superblock() - Constructor for class org.apache.sysds.runtime.io.hdf5.H5Superblock
 
H5Superblock(BufferedInputStream, long) - Constructor for class org.apache.sysds.runtime.io.hdf5.H5Superblock
 
H5SymbolTableEntry - Class in org.apache.sysds.runtime.io.hdf5
 
H5SymbolTableEntry(int, long, int, long, long) - Constructor for class org.apache.sysds.runtime.io.hdf5.H5SymbolTableEntry
 
H5SymbolTableEntry(H5RootObject) - Constructor for class org.apache.sysds.runtime.io.hdf5.H5SymbolTableEntry
 
H5SymbolTableEntry(H5RootObject, long) - Constructor for class org.apache.sysds.runtime.io.hdf5.H5SymbolTableEntry
 
H5SymbolTableMessage - Class in org.apache.sysds.runtime.io.hdf5.message
 
H5SymbolTableMessage(H5RootObject, BitSet, long, long) - Constructor for class org.apache.sysds.runtime.io.hdf5.message.H5SymbolTableMessage
 
H5SymbolTableMessage(H5RootObject, BitSet, ByteBuffer) - Constructor for class org.apache.sysds.runtime.io.hdf5.message.H5SymbolTableMessage
 
H5WriteHeaders(H5RootObject) - Static method in class org.apache.sysds.runtime.io.hdf5.H5
 
HAAS_AND_STOKES_ALPHA1 - Static variable in interface org.apache.sysds.runtime.compress.estim.sample.HassAndStokes
 
HAAS_AND_STOKES_ALPHA2 - Static variable in interface org.apache.sysds.runtime.compress.estim.sample.HassAndStokes
 
HAAS_AND_STOKES_UJ2A_C - Static variable in interface org.apache.sysds.runtime.compress.estim.sample.HassAndStokes
 
HAAS_AND_STOKES_UJ2A_CUT2 - Static variable in interface org.apache.sysds.runtime.compress.estim.sample.HassAndStokes
 
HAAS_AND_STOKES_UJ2A_SOLVE - Static variable in interface org.apache.sysds.runtime.compress.estim.sample.HassAndStokes
 
HADOOP - org.apache.sysds.api.mlcontext.MLContext.ExecutionType
 
handleIllegalReflectiveAccessSpark() - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
 
handlePrivacy(Data) - Static method in class org.apache.sysds.runtime.privacy.PrivacyMonitor
Throws DMLPrivacyException if privacy constraint is set to private or private aggregation.
hasBackReference() - Method in class org.apache.sysds.runtime.instructions.spark.data.LineageObject
 
hasBinaryBlocks() - Method in class org.apache.sysds.api.mlcontext.Frame
Whether or not this frame contains data as binary blocks
hasBinaryBlocks() - Method in class org.apache.sysds.api.mlcontext.Matrix
Whether or not this matrix contains data as binary blocks
hasBroadcastHandle() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
hasBuild() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
hasCommonRowTemplateMatrixInput(Hop, Hop, CPlanMemoTable) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
hasCompressedInput() - Method in class org.apache.sysds.hops.Hop
 
hasConstantValue() - Method in class org.apache.sysds.hops.DataGenOp
 
hasConstantValue(double) - Method in class org.apache.sysds.hops.DataGenOp
 
hasConstraints() - Method in interface org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacy
True if any fine-grained constraints has been set.
hasConstraints() - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyList
 
hasConstraints() - Method in class org.apache.sysds.runtime.privacy.finegrained.FineGrainedPrivacyMap
 
hasConstraints() - Method in class org.apache.sysds.runtime.privacy.PrivacyConstraint
Return true if any constraints have level Private or PrivateAggregate.
hasDependency(DependencyTask<?>) - Method in class org.apache.sysds.runtime.util.DependencyTask
 
hasEncoder(Class<T>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
hasFederatedOutput() - Method in class org.apache.sysds.hops.cost.HopRel
 
hasFederatedOutput() - Method in class org.apache.sysds.hops.Hop
 
hasFederatedOutputAlternative(Hop) - Method in class org.apache.sysds.hops.fedplanner.MemoTable
Checks if any of the federated execution alternatives for the given root hop has federated output.
hasFineGrainedConstraints() - Method in class org.apache.sysds.runtime.privacy.PrivacyConstraint
Checks if fine-grained privacy is set for this privacy constraint.
hasFourInputs() - Method in enum org.apache.sysds.lops.WeightedCrossEntropy.WCeMMType
 
hasFourInputs() - Method in enum org.apache.sysds.lops.WeightedDivMM.WDivMMType
 
hasFourInputs() - Method in enum org.apache.sysds.lops.WeightedSquaredLoss.WeightsType
 
hasFourInputs() - Method in class org.apache.sysds.runtime.matrix.operators.QuaternaryOperator
 
hasFrameObject() - Method in class org.apache.sysds.api.mlcontext.Frame
Whether or not this frame contains data as a FrameObject
hasFunctions() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
hasFunctionStatementBlocks() - Method in class org.apache.sysds.parser.DMLProgram
 
hash(double, Hash.HashType) - Static method in class org.apache.sysds.utils.Hash
Hash functions for double values.
hash(Object, Hash.HashType) - Static method in class org.apache.sysds.utils.Hash
Generic hashing of java objects, not ideal for specific values so use the specific methods for specific types.
Hash - Class in org.apache.sysds.utils
A class containing different hashing functions.
Hash() - Constructor for class org.apache.sysds.utils.Hash
 
HASH - org.apache.sysds.runtime.transform.TfUtils.TfMethod
 
Hash.HashType - Enum in org.apache.sysds.utils
Available Hashing techniques
hashCode() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
 
hashCode() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeBinary
 
hashCode() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
 
hashCode() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeData
 
hashCode() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
 
hashCode() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeNary
 
hashCode() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeOuterProduct
 
hashCode() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
 
hashCode() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTernary
 
hashCode() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
 
hashCode() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeUnary
 
hashCode() - Method in class org.apache.sysds.hops.codegen.opt.InterestingPoint
 
hashCode() - Method in class org.apache.sysds.hops.codegen.opt.PlanSelection.VisitMarkCost
 
hashCode() - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
 
hashCode() - Method in class org.apache.sysds.hops.codegen.template.TemplateBase
 
hashCode() - Method in class org.apache.sysds.hops.ipa.FunctionCallSizeInfo
 
hashCode() - Method in class org.apache.sysds.parser.DataIdentifier
 
hashCode() - Method in class org.apache.sysds.parser.Expression
 
hashCode() - Method in class org.apache.sysds.parser.ParForStatementBlock.ResultVar
 
hashCode() - Method in class org.apache.sysds.runtime.compress.cocode.ColIndexes
 
hashCode() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.AColIndex
 
hashCode() - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex
 
hashCode() - Method in class org.apache.sysds.runtime.compress.utils.DblArray
 
hashCode() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
 
hashCode() - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeTaggedMatrixIndexes
 
hashCode() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
 
hashCode() - Method in class org.apache.sysds.runtime.data.TensorIndexes
 
hashCode() - Method in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
 
hashCode() - Method in class org.apache.sysds.runtime.instructions.cp.KahanObject
 
hashCode() - Method in class org.apache.sysds.runtime.instructions.spark.data.BlockPartitioner
 
hashCode() - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
hashCode() - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
 
hashCode() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
hashCode() - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
hashCode() - Method in class org.apache.sysds.runtime.matrix.data.MatrixIndexes
 
hashCode() - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue.CellIndex
 
hashCode() - Method in class org.apache.sysds.runtime.matrix.data.TripleIndexes
 
hashCode() - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
 
hashCode() - Method in class org.apache.sysds.runtime.matrix.data.WeightedPair
 
hashCode() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
 
hashCode() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
 
hashCode() - Method in class org.apache.sysds.runtime.meta.MetaData
 
hashCode() - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
 
hashCode() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
hashCode() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
hashCode() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
hashCode() - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
 
hashCode() - Method in class org.apache.sysds.runtime.transform.tokenize.Token
 
hasHeader() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
 
hashMissCount - Static variable in class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap
 
hashMissCount - Static variable in class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap
 
hasHops() - Method in class org.apache.sysds.parser.StatementBlock
 
hasIDColumn() - Method in enum org.apache.sysds.api.mlcontext.FrameFormat
 
hasIDColumn() - Method in enum org.apache.sysds.api.mlcontext.MatrixFormat
Does the DataFrame have a row index?
hasInputStatistics(Hop) - Method in class org.apache.sysds.hops.MemoTable
 
hasLeftPMInput() - Method in class org.apache.sysds.hops.AggBinaryOp
 
hasLegacyEncoder() - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
hasLegacyEncoder(Class<T>) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
hasListInputs(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
hasLocalOutput() - Method in class org.apache.sysds.hops.cost.HopRel
 
hasLocalOutput() - Method in class org.apache.sysds.hops.Hop
 
hasMatrixInput(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
hasMatrixInputWithDifferentBlocksizes() - Method in class org.apache.sysds.hops.Hop
 
hasMatrixObject() - Method in class org.apache.sysds.api.mlcontext.Matrix
Whether or not this matrix contains data as a MatrixObject
hasMatrixObjectSideInput(ArrayList<MatrixObject>) - Static method in class org.apache.sysds.runtime.codegen.SpoofRowwise
 
hasMatrixSideInput(ArrayList<MatrixBlock>) - Static method in class org.apache.sysds.runtime.codegen.SpoofRowwise
 
hasMessageOfType(Class<T>) - Method in class org.apache.sysds.runtime.io.hdf5.H5ObjectHeader
 
hasMultipleConsumers() - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
 
hasNestedParallelism(boolean) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
 
hasNestedPartitionReads(boolean) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
 
hasNext() - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IIterate
Get if the index has a next index.
hasNext() - Method in class org.apache.sysds.runtime.frame.data.columns.Array.ArrayIterator
 
hasNext() - Method in class org.apache.sysds.runtime.frame.data.iterators.RowIterator
 
hasNext() - Method in class org.apache.sysds.runtime.instructions.spark.data.LazyIterableIterator
 
hasNext() - Method in class org.apache.sysds.runtime.matrix.data.BinaryBlockToTextCellConverter
 
hasNext() - Method in interface org.apache.sysds.runtime.matrix.data.Converter
 
hasNext() - Method in class org.apache.sysds.runtime.matrix.data.TextToBinaryCellConverter
 
hasNoOperation(CNodeTpl) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
hasOnlyDataNodeOrLookupInputs(CNode) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
hasOnlyExactMatches(long, TemplateBase.TemplateType, TemplateBase.TemplateType) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
 
hasOnlyRDD() - Method in class org.apache.sysds.hops.DataOp
 
hasOnlySimpleChilds() - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
 
hasOnlyUnaryBinaryParents(Hop, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
hasOnlyWriteParents(Hop, boolean, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
hasOuter() - Method in class org.apache.sysds.hops.codegen.opt.PlanPartition
 
hasPadding() - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplier
 
hasParseIssues() - Method in exception org.apache.sysds.parser.ParseException
Does this ParseException contain a list of parse issues?
hasPlanRef() - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
 
hasPlanRefTo(long) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
 
hasPrivateElements() - Method in class org.apache.sysds.runtime.privacy.PrivacyConstraint
Return true if any of the elements has privacy level private
hasRDDHandle() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
hasReferences(Data) - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
 
hasSafeLiterals(String) - Method in class org.apache.sysds.hops.ipa.FunctionCallSizeInfo
Indicates if the given function has at least one input that allows for safe literal propagation and replacement, i.e., all function calls have consistent literal inputs.
HassAndStokes - org.apache.sysds.runtime.compress.estim.sample.SampleEstimatorFactory.EstimationType
 
HassAndStokes - Interface in org.apache.sysds.runtime.compress.estim.sample
 
HassAndStokes.MethodOfMomentsFunction - Class in org.apache.sysds.runtime.compress.estim.sample
 
HassAndStokesNoSolveCache - org.apache.sysds.runtime.compress.estim.sample.SampleEstimatorFactory.EstimationType
 
hasScalar() - Method in enum org.apache.sysds.lops.WeightedDivMM.WDivMMType
 
hasSecondInput() - Method in enum org.apache.sysds.lops.Ctable.OperationTypes
 
hasSingleLineage() - Method in class org.apache.sysds.runtime.instructions.cp.MultiReturnBuiltinCPInstruction
 
hasSingleLineage() - Method in class org.apache.sysds.runtime.instructions.cp.MultiReturnParameterizedBuiltinCPInstruction
 
hasSingleLineage() - Method in interface org.apache.sysds.runtime.lineage.LineageTraceable
Obtain meta data on number of outputs and thus, number of lineage items.
hasSingleOperation(CNodeTpl) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
hasThirdInput() - Method in enum org.apache.sysds.lops.Ctable.OperationTypes
 
hasThreadID() - Method in class org.apache.sysds.hops.recompile.RecompileStatus
 
hasThreadID() - Method in class org.apache.sysds.runtime.controlprogram.ProgramBlock
 
hasTransposeParentUnderOuterProduct(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
hasUnspecifiedSeed() - Method in class org.apache.sysds.hops.DataGenOp
 
hasValidCPDimsAndSize() - Method in class org.apache.sysds.hops.Hop
 
hasValidInputDims(Hop, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
hasValidInputDims(DataCharacteristics[], boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
hasValidInputNnz(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
hasValidInputNnz(DataCharacteristics[], boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
hasValidLineage() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
haveCompressed() - Static method in class org.apache.sysds.utils.DMLCompressionStatistics
 
HDF5 - org.apache.sysds.common.Types.FileFormat
 
HDF5_DATASET_NAME - Static variable in class org.apache.sysds.parser.DataExpression
 
HDF5InputOutputInfo - Static variable in class org.apache.sysds.runtime.io.InputOutputInfo
 
HDFSTool - Class in org.apache.sysds.runtime.util
 
HDFSTool() - Constructor for class org.apache.sysds.runtime.util.HDFSTool
 
HEADER_SIZE - Static variable in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
HeavyHitterModel - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.models
 
HeavyHitterModel() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.HeavyHitterModel
 
HeavyHitterModel(Long, Long, String, double, Long) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.HeavyHitterModel
 
HeavyHitterModel(Long, String, double, Long) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.HeavyHitterModel
 
heavyHitters - Variable in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics.FedStatsCollection
 
heavyHitters - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.StatisticsModel
 
heavyHitters - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.StatisticsOptions
 
help - Variable in class org.apache.sysds.api.DMLOptions
 
HEParamServer - Class in org.apache.sysds.runtime.controlprogram.paramserv
This class implements Homomorphic Encryption (HE) for LocalParamServer.
HEURISTIC - org.apache.sysds.hops.codegen.SpoofCompiler.RegisterAlloc
 
HEURISTIC - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.POptMode
 
hiddenFileFilter - Static variable in class org.apache.sysds.runtime.io.IOUtilFunctions
 
HLL - org.apache.sysds.runtime.matrix.operators.CountDistinctOperatorTypes
 
hoistFunctionCallsFromExpressions() - Method in class org.apache.sysds.parser.DMLProgram
 
Hop - Class in org.apache.sysds.hops
 
Hop(String, Types.DataType, Types.ValueType) - Constructor for class org.apache.sysds.hops.Hop
 
HOP - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.NodeType
 
HopDagValidator - Class in org.apache.sysds.hops.rewrite
This class allows to check hop dags for validity, e.g., parent-child linking.
HopInputComparator() - Constructor for class org.apache.sysds.hops.codegen.template.TemplateCell.HopInputComparator
 
HopInputComparator(Hop) - Constructor for class org.apache.sysds.hops.codegen.template.TemplateCell.HopInputComparator
 
HopInputComparator(Hop, Hop) - Constructor for class org.apache.sysds.hops.codegen.template.TemplateRow.HopInputComparator
 
hopPropagation(Hop) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
Propagate privacy constraints from input hops to given hop.
hopPropagation(Hop, ArrayList<Hop>) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
Propagate privacy constraints from input hops to given hop.
HopRel - Class in org.apache.sysds.hops.cost
HopRel provides a representation of the relation between a hop, the cost of setting a given FederatedOutput value, and the input dependency with the given FederatedOutput value.
HopRel(Hop, FEDInstruction.FederatedOutput, FTypes.FType, MemoTable, ArrayList<Hop>) - Constructor for class org.apache.sysds.hops.cost.HopRel
Constructs a HopRel with input dependency and cost estimate based on entries in hopRelMemo.
HopRel(Hop, FEDInstruction.FederatedOutput, FTypes.FType, MemoTable, List<Hop>, List<FTypes.FType>) - Constructor for class org.apache.sysds.hops.cost.HopRel
 
HopRel(Hop, FEDInstruction.FederatedOutput, MemoTable) - Constructor for class org.apache.sysds.hops.cost.HopRel
Constructs a HopRel with input dependency and cost estimate based on entries in hopRelMemo.
HopRel(Hop, FEDInstruction.FederatedOutput, MemoTable, ArrayList<Hop>) - Constructor for class org.apache.sysds.hops.cost.HopRel
Constructs a HopRel with input dependency and cost estimate based on entries in hopRelMemo.
HopRewriteRule - Class in org.apache.sysds.hops.rewrite
Base class for all hop rewrites in order to enable generic application of all rules.
HopRewriteRule() - Constructor for class org.apache.sysds.hops.rewrite.HopRewriteRule
 
HopRewriteUtils - Class in org.apache.sysds.hops.rewrite
 
HopRewriteUtils() - Constructor for class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
HOPS - org.apache.sysds.api.mlcontext.MLContext.ExplainLevel
Explain program and HOPs
HOPS - org.apache.sysds.hops.codegen.SpoofCompiler.IntegrationType
 
HOPS - org.apache.sysds.utils.Explain.ExplainType
 
HopsException - Exception in org.apache.sysds.hops
Exception occurring in the HOP level.
HopsException() - Constructor for exception org.apache.sysds.hops.HopsException
 
HopsException(String) - Constructor for exception org.apache.sysds.hops.HopsException
 
HopsException(String, Throwable) - Constructor for exception org.apache.sysds.hops.HopsException
 
HopsException(Throwable) - Constructor for exception org.apache.sysds.hops.HopsException
 
HOSPITAL_RESIDENCY_MATCH - org.apache.sysds.common.Builtins
 
host - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.CoordinatorModel
 
hostToDevice(GPUContext, double[], Pointer, String) - Method in interface org.apache.sysds.runtime.matrix.data.CudaSupportFunctions
 
hostToDevice(GPUContext, double[], Pointer, String) - Method in class org.apache.sysds.runtime.matrix.data.DoublePrecisionCudaSupportFunctions
 
hostToDevice(GPUContext, double[], Pointer, String) - Method in class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
 
HYBRID - org.apache.sysds.common.Types.ExecMode
 
HYBRID_W_TREE - org.apache.sysds.runtime.compress.cost.CostEstimatorFactory.CostType
 
HybridCostEstimator - Class in org.apache.sysds.runtime.compress.cost
 
HYPERBAND - org.apache.sysds.common.Builtins
 

I

ICLAScheme - Interface in org.apache.sysds.runtime.compress.colgroup.scheme
Abstract class for a scheme instance.
IColIndex - Interface in org.apache.sysds.runtime.compress.colgroup.indexes
Class to contain column indexes for the compression column groups.
IColIndex.ColIndexType - Enum in org.apache.sysds.runtime.compress.colgroup.indexes
 
IColIndex.SliceResult - Class in org.apache.sysds.runtime.compress.colgroup.indexes
A Class for slice results containing indexes for the slicing of dictionaries, and the resulting column index
IController - Interface in org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers
 
id - Variable in class org.apache.sysds.runtime.compress.utils.DArrCounts
 
id - Variable in class org.apache.sysds.runtime.compress.utils.DCounts
 
id - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.BaseModel
 
ID - Static variable in class org.apache.sysds.parser.dml.DmlLexer
 
ID - Static variable in class org.apache.sysds.parser.dml.DmlParser
 
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() - 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
 
ID_JSON_MSG - Static variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.Constants
 
idEnd - Variable in class org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex.SliceResult
End index (not inclusive) to slice inside the dictionary
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
 
Identity - org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary.DictType
 
IDENTITY - org.apache.sysds.runtime.compress.colgroup.dictionary.DictionaryFactory.Type
 
IDENTITY_SLICE - org.apache.sysds.runtime.compress.colgroup.dictionary.DictionaryFactory.Type
 
IdentityDictionary - Class in org.apache.sysds.runtime.compress.colgroup.dictionary
 
IdentityDictionary(int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
Create a Identity matrix dictionary.
IdentityDictionarySlice - Class in org.apache.sysds.runtime.compress.colgroup.dictionary
 
IdentityDictionarySlice(int, int, int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
Create a Identity matrix dictionary slice.
IdentitySlice - org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary.DictType
 
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
 
idStart - Variable in class org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex.SliceResult
Start index to slice inside the dictionary
IEncode - Interface in org.apache.sysds.runtime.compress.estim.encoding
This interface covers an intermediate encoding for the samples to improve the efficiency of the joining of sample column groups.
IF - org.apache.sysds.runtime.compress.workload.AWTreeNode.WTNodeType
 
IF - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.NodeType
 
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
 
IFELSE - org.apache.sysds.common.Builtins
 
IFELSE - org.apache.sysds.common.Types.OpOp3
 
IFELSE - org.apache.sysds.hops.codegen.cplan.CNodeTernary.TernaryType
 
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
 
IGNORE_READ_WRITE_METADATA - org.apache.sysds.conf.CompilerConfig.ConfigType
 
IGNORE_TEMPORARY_FILENAMES - org.apache.sysds.conf.CompilerConfig.ConfigType
 
IGNORE_UNSPECIFIED_ARGS - org.apache.sysds.conf.CompilerConfig.ConfigType
 
IIterate - Interface in org.apache.sysds.runtime.compress.colgroup.indexes
Class to iterate through the columns of a IColIndex.
IJV - Class in org.apache.sysds.runtime.matrix.data
Helper class for external key/value exchange.
IJV - org.apache.sysds.api.mlcontext.FrameFormat
(I J V) format (sparse).
IJV - org.apache.sysds.api.mlcontext.MatrixFormat
(I J V) format (sparse).
IJV() - Constructor for class org.apache.sysds.runtime.matrix.data.IJV
 
ILinearize - Interface in org.apache.sysds.lops.compile.linearization
A interface for the linearization algorithms that order the DAG nodes into a sequence of instructions to execute.
ILinearize.DagLinearization - Enum in org.apache.sysds.lops.compile.linearization
 
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
 
im2col(MatrixBlock, MatrixBlock, int, DnnParameters, 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
 
IMG_BRIGHTNESS - org.apache.sysds.common.Builtins
 
IMG_CROP - org.apache.sysds.common.Builtins
 
IMG_CUTOUT - org.apache.sysds.common.Builtins
 
IMG_INVERT - org.apache.sysds.common.Builtins
 
IMG_MIRROR - org.apache.sysds.common.Builtins
 
IMG_POSTERIZE - org.apache.sysds.common.Builtins
 
IMG_ROTATE - org.apache.sysds.common.Builtins
 
IMG_SAMPLE_PAIRING - org.apache.sysds.common.Builtins
 
IMG_SHEAR - org.apache.sysds.common.Builtins
 
IMG_TRANSFORM - org.apache.sysds.common.Builtins
 
IMG_TRANSLATE - org.apache.sysds.common.Builtins
 
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
 
IMPURITY_MEASURES - org.apache.sysds.common.Builtins
 
IMPUTE - org.apache.sysds.runtime.transform.TfUtils.TfMethod
 
IMPUTE_BY_MEAN - org.apache.sysds.common.Builtins
 
IMPUTE_BY_MEAN_APPLY - org.apache.sysds.common.Builtins
 
IMPUTE_BY_MEDIAN - org.apache.sysds.common.Builtins
 
IMPUTE_BY_MEDIAN_APPLY - org.apache.sysds.common.Builtins
 
IMPUTE_BY_MODE - org.apache.sysds.common.Builtins
 
IMPUTE_BY_MODE_APPLY - org.apache.sysds.common.Builtins
 
IMPUTE_FD - org.apache.sysds.common.Builtins
 
IMPUTE_FD_APPLY - org.apache.sysds.common.Builtins
 
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.
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.
inc() - Method in class org.apache.sysds.runtime.compress.utils.DArrCounts
 
inc() - Method in class org.apache.sysds.runtime.compress.utils.DCounts
 
incAsyncBroadcastCount(long) - Static method in class org.apache.sysds.utils.stats.SparkStatistics
 
incAsyncPrefetchCount(long) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
incAsyncPrefetchCount(long) - Static method in class org.apache.sysds.utils.stats.SparkStatistics
 
incAsyncSparkOpCount(long) - Static method in class org.apache.sysds.utils.stats.SparkStatistics
 
incAsyncTriggerCheckpointCount(long) - Static method in class org.apache.sysds.utils.stats.SparkStatistics
 
incBinningApplyTime(long) - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
incBinningBuildTime(long) - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
incBroadcastCount(long) - Static method in class org.apache.sysds.utils.stats.SparkStatistics
 
incCMM() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
incCMM(int) - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
incDecompressions() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
incDecompressions(int) - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
incDictOps() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
incDictOps(int) - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
incDummyCodeApplyTime(long) - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
incEncoderCount(long) - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
incFeatureHashingApplyTime(long) - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
incFederated(FederatedRequest.RequestType, List<Object>) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
incFedLookupTableEntryCount() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
incFedLookupTableGetCount() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
incFedLookupTableGetTime(long) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
incFedReuseReadBytesCount(CacheableData<?>) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
incFedReuseReadBytesCount(CacheBlock<?>) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
incFedReuseReadHitCount() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
incFedTransfer(Object, String, Long) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
incImputeApplyTime(long) - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
incImputeBuildTime(long) - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
incIndexOp() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
incIndexOp(int) - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
incLMM() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
incLMM(int) - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
INCLUDE_FUNCTIONS - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
 
incMapSizeEstimationTime(long) - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
inColRange(long) - Method in class org.apache.sysds.runtime.util.IndexRange
 
incOmitApplyTime(long) - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
incOutMatrixPostProcessingTime(long) - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
incOutMatrixPreProcessingTime(long) - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
incOverlappingDecompressions() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
incOverlappingDecompressions(int) - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
incParallelizeCount(long) - Static method in class org.apache.sysds.utils.stats.SparkStatistics
 
incPassThroughApplyTime(long) - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
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) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
 
incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
 
incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
 
incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
 
incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
 
incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
 
incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
 
incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
 
incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
 
incr(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
 
incr(int, int) - 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.DenseBlock
Increments the given value for a given row and column by delta.
incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
 
incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
 
incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
 
incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
 
incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
 
incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
 
incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
 
incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
 
incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
 
incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
 
incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
 
incr(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockString
 
incRecodeApplyTime(long) - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
incRecodeBuildTime(long) - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
increment - Variable in class org.apache.sysds.parser.dml.DmlParser.IterablePredicateSeqExpressionContext
 
increment - Variable in class org.apache.sysds.parser.dml.ExpressionInfo
 
increment(double) - Method in class org.apache.sysds.runtime.compress.utils.DoubleCountHashMap
 
increment(double, int) - Method in class org.apache.sysds.runtime.compress.utils.DoubleCountHashMap
 
increment(DblArray) - Method in class org.apache.sysds.runtime.compress.utils.DblArrayCountHashMap
Increment the key, and return the Id of the value incremented.
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, BasicTensorBlock) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
 
incrementalAggregate(AggregateOperator, MatrixValue) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
incrementalAggregate(AggregateOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
 
incrementalAggregate(AggregateOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
incrementalAggregate(AggregateOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
incrementalAggregate(AggregateOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
 
incrementalAggregate(AggregateOperator, MatrixValue, MatrixValue, boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
incrementalAggregate(AggregateOperator, MatrixValue, MatrixValue, boolean) - 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, MatrixValue, boolean) - 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
 
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
 
incrementBPoolWrites() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
 
incrementClassCompile() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
incrementClassCompileTime(long) - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
incrementCompileTime(long) - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
incrementConv2dBwdDataTime(long) - Static method in class org.apache.sysds.utils.stats.NativeStatistics
 
incrementConv2dBwdFilterTime(long) - Static method in class org.apache.sysds.utils.stats.NativeStatistics
 
incrementConv2dTime(long) - Static method in class org.apache.sysds.utils.stats.NativeStatistics
 
incrementCPlanCompile(long) - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
incrementDAGCompile() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
incrementDelHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
incrementEnumAll(long) - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
incrementEnumAllP(long) - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
incrementEnumEval(long) - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
incrementEnumEvalP(long) - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
incrementExportTime(long) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
 
incrementFailuresCounter() - Static method in class org.apache.sysds.utils.stats.NativeStatistics
 
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(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() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
incrementFSHits(int) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
 
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() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
incrementFSWrites(int) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
 
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
 
incrementGpuAsyncEvicts() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
incrementGpuHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
incrementGpuSyncEvicts() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
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
 
incrementInitTime(long) - Static method in class org.apache.sysds.utils.stats.ParForStatistics
 
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
 
incrementLibMatrixMultTime(long) - Static method in class org.apache.sysds.utils.stats.NativeStatistics
 
incrementLinHits() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
 
incrementLinHits(int) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
 
incrementLinWrites() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
 
incrementLinWrites(int) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
 
incrementMemDeletes() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
incrementMemHits() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
 
incrementMemHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
incrementMemHits(int) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
 
incrementMemWrites() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
incrementMergeTime(long) - Static method in class org.apache.sysds.utils.stats.ParForStatistics
 
incrementMissedComputeTime(long) - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
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
 
incrementNumConv2dBwdDataCalls() - Static method in class org.apache.sysds.utils.stats.NativeStatistics
 
incrementNumConv2dBwdFilterCalls() - Static method in class org.apache.sysds.utils.stats.NativeStatistics
 
incrementNumConv2dCalls() - Static method in class org.apache.sysds.utils.stats.NativeStatistics
 
incrementNumLibMatrixMultCalls() - Static method in class org.apache.sysds.utils.stats.NativeStatistics
 
incrementNumReferences() - Method in class org.apache.sysds.runtime.instructions.spark.data.LineageObject
 
incrementNumSparseConv2dBwdDataCalls() - Static method in class org.apache.sysds.utils.stats.NativeStatistics
 
incrementNumSparseConv2dBwdFilterCalls() - Static method in class org.apache.sysds.utils.stats.NativeStatistics
 
incrementNumSparseConv2dCalls() - Static method in class org.apache.sysds.utils.stats.NativeStatistics
 
incrementOpCacheHits() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
incrementOpCacheTotal() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
incrementOptimCount() - Static method in class org.apache.sysds.utils.stats.ParForStatistics
 
incrementOptimTime(long) - Static method in class org.apache.sysds.utils.stats.ParForStatistics
 
incrementParForMRCounters(Reporter, long, long) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForUtils
 
incrementPlanCacheHits() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
incrementPlanCacheTotal() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
incrementPRewrites() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
incrementRDDHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
incrementRDDPersistHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
incrementRecompilePred() - Static method in class org.apache.sysds.utils.stats.RecompileStatistics
 
incrementRecompilePred(long) - Static method in class org.apache.sysds.utils.stats.RecompileStatistics
 
incrementRecompileSB() - Static method in class org.apache.sysds.utils.stats.RecompileStatistics
 
incrementRecompileSB(long) - Static method in class org.apache.sysds.utils.stats.RecompileStatistics
 
incrementRecompileTime(long) - Static method in class org.apache.sysds.utils.stats.RecompileStatistics
 
incrementReleaseTime(long) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
 
incrementSavedComputeTime(long) - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
incrementSavedComputeTime(long) - Static method in class org.apache.sysds.runtime.lineage.LineageEstimatorStatistics
 
incrementSBHits() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
incrementSparkCollectHits() - 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
 
incrementWorkload(ExecutionContext, long, Instruction) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedWorkloadAnalyzer
 
incrementWorkload(ExecutionContext, ConcurrentHashMap<Long, InstructionTypeCounter>, ComputationCPInstruction) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedWorkloadAnalyzer
 
increOp - Variable in class org.apache.sysds.runtime.matrix.operators.AggregateOperator
 
incRMM() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
incRMM(int) - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
incScans() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
incScans(int) - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
incst1() - Method in class org.apache.sysds.runtime.compress.cocode.Memorizer
 
incst4() - Method in class org.apache.sysds.runtime.compress.cocode.Memorizer
 
incUDFApplyTime(long) - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
incWorkerNumber() - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
incWorkerNumber(long) - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
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(IndexedMatrixValue) - 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
 
IndexedTensorBlock - Class in org.apache.sysds.runtime.data
 
IndexedTensorBlock() - Constructor for class org.apache.sysds.runtime.data.IndexedTensorBlock
 
IndexedTensorBlock(IndexedTensorBlock) - Constructor for class org.apache.sysds.runtime.data.IndexedTensorBlock
 
IndexedTensorBlock(TensorIndexes, TensorBlock) - 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() - 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() - 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
 
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(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
indexes(int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
 
Indexes - org.apache.sysds.lops.SortKeys.OperationTypes
 
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
 
IndexingFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
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
 
Inf - org.apache.sysds.parser.BuiltinConstant
 
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
 
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.
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() - 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() - Static method in class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
 
init(double[][], int, int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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.compress.CompressedMatrixBlock
 
init(double[], int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
NOTE: This method is designed only for dense representation.
init(ArrayList<Hop>, RecompileStatus) - Method in class org.apache.sysds.hops.MemoTable
 
init(Map<String, String>) - Static method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
 
init(Hop, RecompileStatus) - Method in class org.apache.sysds.hops.MemoTable
 
init(Lop, Lop, Types.DataType, Types.ValueType, Types.ExecType) - Method in class org.apache.sysds.lops.AppendR
 
init(Lop, Lop, Lop, Types.DataType, Types.ValueType) - Method in class org.apache.sysds.lops.Append
 
init(Lop, Lop, Lop, Types.DataType, Types.ValueType) - Method in class org.apache.sysds.lops.AppendGAlignedSP
 
init(Lop, Lop, Lop, Types.DataType, Types.ValueType, Types.ExecType) - Method in class org.apache.sysds.lops.AppendM
 
init(Lop, Lop, Lop, Lop, Types.DataType, Types.ValueType, Types.ExecType) - Method in class org.apache.sysds.lops.AppendG
 
init(DataIdentifier, String, Types.ExecType) - Method in class org.apache.sysds.lops.DataGen
 
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
Init - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
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.
initClient(byte[]) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.NativeHEHelper
generates a Client object
initColList(int[]) - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
 
initColList(int[]) - Method in class org.apache.sysds.runtime.transform.encode.LegacyEncoder
 
initColList(JSONArray) - Method in class org.apache.sysds.runtime.transform.encode.LegacyEncoder
 
initFederatedData(long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
 
initFederatedData(long, MetaData) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
 
initFederatedDataFromLocal(long, CacheBlock<?>) - 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
 
InitFEDInstruction(CPOperand, 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() - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.NativeHEHelper
 
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.ColumnEncoderBin
 
initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderFeatureHash
 
initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderPassThrough
 
initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
Construct the recodemaps from the given input frame for all columns registered for recode.
initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderUDF
 
initMetaData(FrameBlock) - Method in interface 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.EncoderMVImpute
 
initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
 
initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.LegacyEncoder
Sets up the required meta data for a subsequent call to apply.
initMetaData(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
initRecodeIDList(List<Integer>) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
 
initServer() - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.NativeHEHelper
generates the Server object and returns a pointer to it
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
 
INPLACE - org.apache.sysds.runtime.controlprogram.caching.MatrixObject.UpdateType
 
INPLACE_PINNED - org.apache.sysds.runtime.controlprogram.caching.MatrixObject.UpdateType
 
input(int) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
 
INPUT_DIMS - org.apache.sysds.hops.codegen.SpoofFusedOp.SpoofOutputDimsType
 
INPUT_DIMS_CONST2 - org.apache.sysds.hops.codegen.SpoofFusedOp.SpoofOutputDimsType
 
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
 
InsertionSorterFactory - Interface in org.apache.sysds.runtime.compress.colgroup.insertionsort
 
InsertionSorterFactory.SORT_TYPE - Enum in org.apache.sysds.runtime.compress.colgroup.insertionsort
 
INST - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.NodeType
 
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 - org.apache.sysds.runtime.lineage.LineageItem.LineageItemType
 
INSTRUCTION_DELIM - Static variable in class org.apache.sysds.runtime.instructions.Instruction
 
INSTRUCTION_DELIMITOR - Static variable in class org.apache.sysds.lops.Lop
 
Instruction.IType - Enum in org.apache.sysds.runtime.instructions
 
InstructionParser - Class in org.apache.sysds.runtime.instructions
 
InstructionParser() - Constructor for class org.apache.sysds.runtime.instructions.InstructionParser
 
instructionStringFEDPrepare(String, CPOperand, long, CPOperand[], long[], boolean) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
Prepare instruction string for sending in a FederatedRequest as a CP instruction.
InstructionTypeCounter - Class in org.apache.sysds.runtime.compress.cost
 
InstructionTypeCounter() - Constructor for class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
InstructionTypeCounter(int, int, int, int, int, int, int, int, boolean) - Constructor for class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
InstructionUtils - Class in org.apache.sysds.runtime.instructions
 
InstructionUtils() - Constructor for class org.apache.sysds.runtime.instructions.InstructionUtils
 
INT - org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory.MAP_TYPE
 
INT - org.apache.sysds.runtime.util.LongLongDoubleHashMap.EntryType
 
INT - Static variable in class org.apache.sysds.parser.dml.DmlLexer
 
INT - Static variable in class org.apache.sysds.parser.dml.DmlParser
 
INT() - Method in class org.apache.sysds.parser.dml.DmlParser.ConstIntIdExpressionContext
 
INT_SIZE - Static variable in class org.apache.sysds.hops.OptimizerUtils
 
INT_VALUE_TYPE - Static variable in class org.apache.sysds.parser.Statement
 
INT32 - org.apache.sysds.common.Types.ValueType
 
INT32 - org.apache.sysds.runtime.frame.data.columns.ArrayFactory.FrameArrayType
 
INT64 - org.apache.sysds.common.Types.ValueType
 
INT64 - org.apache.sysds.runtime.frame.data.columns.ArrayFactory.FrameArrayType
 
INT8_DICT - org.apache.sysds.runtime.compress.colgroup.dictionary.DictionaryFactory.Type
 
intArrayCost(long) - Static method in class org.apache.sysds.utils.MemoryEstimates
Get the worst case memory usage of an array of integers.
IntArrayList - Class in org.apache.sysds.runtime.compress.utils
 
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
 
INTDIV - org.apache.sysds.common.Types.OpOp2
 
INTDIV - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
INTDIV - org.apache.sysds.parser.Expression.BinaryOp
 
INTEGER - org.apache.sysds.runtime.io.FileFormatPropertiesMM.MMField
 
IntegerArray - Class in org.apache.sysds.runtime.frame.data.columns
 
IntegerArray(int[]) - Constructor for class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
IntegerDivide - Class in org.apache.sysds.runtime.functionobjects
 
integerFloatPattern - Static variable in interface org.apache.sysds.runtime.frame.data.lib.FrameUtil
 
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 - org.apache.sysds.parser.Expression.FunctCallOp
 
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
 
INTERQUANTILE - org.apache.sysds.common.Builtins
 
INTERQUANTILE - org.apache.sysds.common.Types.OpOp2
 
INTERQUANTILE - org.apache.sysds.common.Types.OpOp3
 
interQuartileMean() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
interQuartileMean() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
INTERSECT - org.apache.sysds.common.Builtins
 
intersection(CorrMatrixBlock, CorrMatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinct.CountDistinctFunctionSketch
 
intersection(CorrMatrixBlock, CorrMatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox.KMVSketch
 
intersection(CorrMatrixBlock, CorrMatrixBlock) - Method in interface org.apache.sysds.runtime.matrix.data.sketch.MatrixSketch
Intersect two sketches
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(ParserRuleContext, long, String) - Constructor for class org.apache.sysds.parser.IntIdentifier
 
IntIdentifier(IntIdentifier, ParseInfo) - 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 - org.apache.sysds.common.Types.CorrectionLocationType
 
INVALID - org.apache.sysds.common.Types.ExecType
 
INVALID - org.apache.sysds.common.Types.ParamBuiltinOp
 
INVALID - org.apache.sysds.lops.Ctable.OperationTypes
 
INVALID - org.apache.sysds.parser.Expression.BinaryOp
 
INVALID - org.apache.sysds.parser.Expression.BooleanOp
 
INVALID - org.apache.sysds.parser.Expression.RelationalOp
 
INVALID - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ProbabilityDistributionCode
 
INVALID - org.apache.sysds.runtime.matrix.data.LibMatrixBincell.BinaryAccessType
 
INVALID - org.apache.sysds.runtime.matrix.operators.CMOperator.AggregateOperationTypes
 
INVALID - org.apache.sysds.runtime.transform.encode.ColumnEncoderBin.BinMethod
 
INVALID - org.apache.sysds.runtime.transform.encode.EncoderMVImpute.MVMethod
 
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.frame.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.
INVCDF - org.apache.sysds.common.Builtins
 
INVCDF - org.apache.sysds.common.Types.ParamBuiltinOp
 
INVCDF - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ParameterizedBuiltinCode
 
INVERSE - org.apache.sysds.common.Builtins
 
INVERSE - org.apache.sysds.common.Types.OpOp1
 
INVERSE - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
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
 
IPAPassCompressionWorkloadAnalysis - Class in org.apache.sysds.hops.ipa
This rewrite obtains workload summaries for all hops candidates amenable for compression as a basis for workload-aware compression planning.
IPAPassCompressionWorkloadAnalysis() - Constructor for class org.apache.sysds.hops.ipa.IPAPassCompressionWorkloadAnalysis
 
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
 
IPAPassReplaceEvalFunctionCalls - 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.
IPAPassReplaceEvalFunctionCalls() - Constructor for class org.apache.sysds.hops.ipa.IPAPassReplaceEvalFunctionCalls
 
IPAPassRewriteFederatedPlan - Class in org.apache.sysds.hops.ipa
This rewrite generates a federated execution plan by estimating and setting costs and the FederatedOutput values of all relevant hops in the DML program.
IPAPassRewriteFederatedPlan() - Constructor for class org.apache.sysds.hops.ipa.IPAPassRewriteFederatedPlan
 
IQM - org.apache.sysds.common.Builtins
 
IQM - org.apache.sysds.common.Types.OpOp1
 
IQM - org.apache.sysds.common.Types.OpOp2
 
IQM - org.apache.sysds.lops.PickByCount.OperationTypes
 
IRepository - Interface in org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories
 
is(String) - Method in class org.apache.sysds.hops.fedplanner.FederatedCompilationTimer.TimeEntry
 
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...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
isAggUnaryOp(Hop, Types.AggOp, Types.Direction) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
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.
isAligned(FederationMap, boolean) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
Determines if the two federation maps are aligned row/column partitions at the same federated sites (which allows for purely federated operation)
isAligned(FederationMap, boolean, boolean, boolean) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
determines if the two federated data are aligned row/column partitions (depending on parameters equalRows/equalCols) at the same federated site (which often allows for purely federated operations)
isAligned(FederationMap, FTypes.AlignType...) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
helper function for checking multiple allowed alignment types
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.
isAllCols() - Method in class org.apache.sysds.hops.IndexingOp
 
isAllDense(MatrixBlock...) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixBincell
 
isAllocated() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
isAllocated() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
 
isAllocated() - Method in class org.apache.sysds.runtime.data.DataTensorBlock
 
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
 
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
 
isAllOnes(Integer...) - Method in class org.apache.sysds.runtime.matrix.data.DnnParameters
 
isAllOutputsCP() - Method in class org.apache.sysds.lops.Lop
Function that determines if all the outputs of a LOP are of CP execution types
isAllPathsTaken() - Method in class org.apache.sysds.runtime.lineage.LineageDedupBlock
 
isAllRows() - Method in class org.apache.sysds.hops.IndexingOp
 
isAllTrue() - Method in class org.apache.sysds.runtime.frame.data.columns.ABooleanArray
 
isAllTrue() - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
isAllTrue() - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
isAllZero() - Method in class org.apache.sysds.runtime.instructions.cp.KahanObject
 
isApplicable() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
Indicates if this encoder is applicable, i.e, if there is a column to encode.
isApplicable() - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
Indicates if this encoder is applicable, i.e, if there is at least one column to encode.
isApplicable() - Method in class org.apache.sysds.runtime.transform.encode.LegacyEncoder
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.ColumnEncoder
Indicates if this encoder is applicable for the given column ID, i.e., if it is subject to this transformation.
isApplicable(int) - Method in class org.apache.sysds.runtime.transform.encode.LegacyEncoder
Indicates if this encoder is applicable for the given column ID, i.e., if it is subject to this transformation.
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.IPAPassCompressionWorkloadAnalysis
 
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(FunctionCallGraph) - Method in class org.apache.sysds.hops.ipa.IPAPassReplaceEvalFunctionCalls
 
isApplicable(FunctionCallGraph) - Method in class org.apache.sysds.hops.ipa.IPAPassRewriteFederatedPlan
Indicates if an IPA pass is applicable for the current configuration.
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
 
isAsync() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheMaintenanceService
 
isAsynchronousOp() - Method in class org.apache.sysds.lops.Lop
 
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)
isBelowCachingThreshold(CacheBlock<?>) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
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
 
isBinaryMatrixRowVectorOperation(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
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
 
isBoolean(String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
isBroadcastEnabled() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
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
 
isCast() - Method in enum org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
 
isCastUnaryOperation() - Method in class org.apache.sysds.hops.UnaryOp
 
isCellOp() - Method in enum org.apache.sysds.common.Types.OpOpN
 
isCheckpointEnabled() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
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
 
isCol() - Method in enum org.apache.sysds.common.Types.Direction
 
isColAggregate() - Method in class org.apache.sysds.runtime.matrix.operators.AggregateUnaryOperator
 
isCollectForBroadcast(Lop) - Static method in class org.apache.sysds.lops.OperatorOrderingUtils
 
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.frame.data.FrameBlock
 
isColNamesDefault() - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
isColPartitioned() - Method in enum org.apache.sysds.hops.fedplanner.FTypes.FType
 
isColType() - Method in enum org.apache.sysds.hops.fedplanner.FTypes.AlignType
 
isColumnAgg() - Method in enum org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
 
isColumnMetadataDefault() - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
isColumnMetadataDefault(int) - Method in class org.apache.sysds.runtime.frame.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(CNode) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
isColVector(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
isCommutative() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
isCommutative() - Method in class org.apache.sysds.runtime.matrix.operators.BinaryOperator
 
isCompareOperator(BinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixOuterAgg
This will return if uaggOp is of type RowIndexMin
isCompCompMM() - Method in class org.apache.sysds.runtime.compress.workload.OpSided
 
isCompiled() - Method in enum org.apache.sysds.hops.fedplanner.FTypes.FederatedPlanner
 
isCompiled(String) - Static method in enum org.apache.sysds.hops.fedplanner.FTypes.FederatedPlanner
 
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)
isCompressed() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
isCompressedOutput() - Method in class org.apache.sysds.hops.Hop
 
isCompressedOutput() - Method in class org.apache.sysds.runtime.compress.workload.Op
 
isCompressedOutput() - Method in class org.apache.sysds.runtime.compress.workload.OpNormal
 
isCompressedOutput() - Method in class org.apache.sysds.runtime.compress.workload.OpSided
 
isCompressedTransformEncode(CacheBlock<?>, boolean) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
isCompressionEnabled() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
isConsecutiveIndex(Hop, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
isConst() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
 
isConstDim2(long) - Method in enum org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
 
isContiguous() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.ArrayIndex
 
isContiguous() - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex
Get if these columns are contiguous, meaning all indexes are integers at increments of 1.
isContiguous() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.RangeIndex
 
isContiguous() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.SingleIndex
 
isContiguous() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.TwoIndex
 
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() - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
 
isContiguous() - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
 
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
 
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(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
 
isContiguous(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
 
isCostBased() - Method in enum org.apache.sysds.hops.codegen.SpoofCompiler.PlanSelector
 
isCostNsize() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
 
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
 
isCTableReshapeRewriteApplicable(Types.ExecType, Ctable.OperationTypes) - Method in class org.apache.sysds.hops.TernaryOp
 
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
 
isDagHeightBased() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
 
isData(Hop, Types.OpOpData) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
isData(Hop, Types.OpOpData...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
isDataExecLocation() - Method in class org.apache.sysds.lops.Lop
 
isDataFrameWithIDColumn(FrameMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
Return whether or not the DataFrame has an ID column.
isDataFrameWithIDColumn(MatrixMetadata) - 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
 
isDateColumn(String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
isDecompressing() - Method in class org.apache.sysds.runtime.compress.workload.Op
 
isDecompressing() - Method in class org.apache.sysds.runtime.compress.workload.WTreeRoot
 
isDedup() - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
isDefault() - Method in class org.apache.sysds.runtime.frame.data.columns.ColumnMetadata
 
isDefault(String, Types.ValueType) - Static method in interface org.apache.sysds.runtime.frame.data.lib.FrameUtil
 
isDegreeOfParallelismFixed() - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
isDelimitedFormat() - Method in enum org.apache.sysds.common.Types.FileFormat
 
isDelimitedFormat(String) - Static method in enum org.apache.sysds.common.Types.FileFormat
 
isDense() - Method in class org.apache.sysds.runtime.compress.cost.ComputationCostEstimator
 
isDense() - Method in class org.apache.sysds.runtime.compress.estim.encoding.ConstEncoding
 
isDense() - Method in class org.apache.sysds.runtime.compress.estim.encoding.DenseEncoding
 
isDense() - Method in class org.apache.sysds.runtime.compress.estim.encoding.EmptyEncoding
 
isDense() - Method in interface org.apache.sysds.runtime.compress.estim.encoding.IEncode
Signify if the counts are including zero or without zero.
isDense() - Method in class org.apache.sysds.runtime.compress.estim.encoding.SparseEncoding
 
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
isDensifying() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
isDensifying() - Method in class org.apache.sysds.runtime.compress.workload.Op
 
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
 
isElementwise() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
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() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Get if the group is only containing zero
isEmpty() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupCompressed
 
isEmpty() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
isEmpty() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
isEmpty() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
isEmpty() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
 
isEmpty() - Method in class org.apache.sysds.runtime.compress.utils.DblArray
 
isEmpty() - Method in class org.apache.sysds.runtime.compress.workload.AWTreeNode
 
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() - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Get if this array is empty, aka filled with empty values.
isEmpty() - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
isEmpty() - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
isEmpty() - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
isEmpty() - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
isEmpty() - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
isEmpty() - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
isEmpty() - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
isEmpty() - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
isEmpty() - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
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
 
isEmpty() - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox.SmallestPriorityQueue
 
isEmpty(boolean) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
 
isEmpty(boolean) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
 
isEmpty(boolean) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
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(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
isEmptyBlock() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
isEmptyBlock(boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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
 
isEnabled() - Method in enum org.apache.sysds.lops.DeCompression.CompressConfig
 
isEncoder(int, Class<?>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
isEqual(ValueTrimFormat) - Method in class org.apache.sysds.runtime.iogen.ValueTrimFormat
 
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(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
 
isEstimator() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
 
isExecSpark() - Method in class org.apache.sysds.lops.Lop
 
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.hops.Hop
Checks if ExecType is federated.
isFederated() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
Check if object is federated.
isFederated() - Method in class org.apache.sysds.runtime.controlprogram.federated.MatrixLineagePair
 
isFederated(FTypes.FType) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
isFederated(FTypes.FType) - Method in class org.apache.sysds.runtime.controlprogram.federated.MatrixLineagePair
 
isFederated(ExecutionContext, FTypes.FType, CPOperand[], Class<?>) - Static method in class org.apache.sysds.runtime.instructions.fed.SpoofFEDInstruction
 
isFederated(ExecutionContext, CPOperand[], Class<?>) - Static method in class org.apache.sysds.runtime.instructions.fed.SpoofFEDInstruction
 
isFederated(CPOperand) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
isFederated(CPOperand, FTypes.FType) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
isFederatedDataOp() - Method in class org.apache.sysds.hops.DataOp
 
isFederatedDataOp() - Method in class org.apache.sysds.hops.Hop
Checks if the hop is a DataOp with federated data.
isFederatedExcept(FTypes.FType) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
isFederatedExcept(FTypes.FType) - Method in class org.apache.sysds.runtime.controlprogram.federated.MatrixLineagePair
 
isFederatedReadCacheEnabled() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
isFederatedRuntimePlanner() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
isFederatedSSL() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
isFileEmpty(FileSystem, Path) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
isFill() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
 
isFillValueDefined() - Method in class org.apache.sysds.runtime.io.hdf5.message.H5FillValueMessage
 
isFlipOuter(int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
 
isFloatType(String, int) - Static method in interface org.apache.sysds.runtime.frame.data.lib.FrameUtil
 
isForced() - Method in enum org.apache.sysds.runtime.instructions.fed.FEDInstruction.FederatedOutput
 
isForcedFederated() - Method in enum org.apache.sysds.runtime.instructions.fed.FEDInstruction.FederatedOutput
 
isForcedLocal() - Method in enum org.apache.sysds.runtime.instructions.fed.FEDInstruction.FederatedOutput
 
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
 
isFullAggregate() - Method in class org.apache.sysds.runtime.matrix.operators.AggregateUnaryOperator
 
isFullColumnIndexing(IndexingOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
isFullColumnIndexing(LeftIndexingOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
isFullReuse() - Method in enum org.apache.sysds.runtime.lineage.LineageCacheConfig.ReuseCacheType
 
isFullRowIndexing(IndexingOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
isFullRowIndexing(LeftIndexingOp) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
isFullType() - Method in enum org.apache.sysds.hops.fedplanner.FTypes.AlignType
 
isFullyDense() - Method in class org.apache.sysds.runtime.matrix.data.RandomMatrixGenerator
 
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.
isGPUCacheEmpty() - Static method in class org.apache.sysds.runtime.lineage.LineageGPUCacheEviction
 
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
 
isGPUObject() - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
 
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
 
isHighPadding() - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
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
 
isIJV() - 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(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.
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.
ISINF - org.apache.sysds.common.Builtins
 
ISINF - org.apache.sysds.common.Types.OpOp1
 
ISINF - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
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
 
isInLineageCache() - Method in class org.apache.sysds.runtime.instructions.spark.data.LineageObject
 
isInMem() - Method in class org.apache.sysds.runtime.instructions.cp.QuantilePickCPInstruction
 
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 class org.apache.sysds.runtime.matrix.operators.UnaryOperator
 
isInPlace() - Method in class org.apache.sysds.hops.recompile.RecompileStatus
 
isInPlace() - Method in enum org.apache.sysds.runtime.controlprogram.caching.MatrixObject.UpdateType
 
isInSparkInstruction - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
Is a spark instruction
isInSparseFormat() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
isInSparseFormat() - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
 
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
 
isInSparseFormat(GPUContext, MatrixObject) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
 
isInstruction() - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
isIntegerNumber(String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
isInternalNamespace(String) - Static method in class org.apache.sysds.parser.DMLProgram
 
isInternalPadding() - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
isIntField() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesMM
 
isIntType(String, int) - Static method in interface org.apache.sysds.runtime.frame.data.lib.FrameUtil
 
isJava() - Method in enum org.apache.sysds.hops.codegen.SpoofCompiler.GeneratorAPI
 
isKnownNGroups() - Method in class org.apache.sysds.hops.ParameterizedBuiltinOp
 
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
 
isLeftMM() - Method in class org.apache.sysds.runtime.compress.workload.OpSided
 
isLIBSVMReadWithUnknownSize() - Method in class org.apache.sysds.parser.DataExpression
 
isLinCached() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
 
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() - 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
 
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
 
isLiteralOfValue(Hop, boolean) - 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, Double...) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
isLiteralOfValue(Hop, String) - 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.compress.workload.AWTreeNode.WTNodeType
 
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
 
isLopRoot(Lop) - Static method in class org.apache.sysds.lops.OperatorOrderingUtils
 
isLowPadding() - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
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.
isMapped() - Method in class org.apache.sysds.runtime.iogen.ReaderMapping
 
isMarked() - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
 
isMarked() - Method in class org.apache.sysds.runtime.iogen.RawRow
 
isMatMultMemoryBound(int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixNative
 
isMatPoint(InterestingPoint[], long, long) - Static method in class org.apache.sysds.hops.codegen.opt.InterestingPoint
 
isMatPoint(InterestingPoint[], long, CPlanMemoTable.MemoTableEntry, boolean[]) - Static method in class org.apache.sysds.hops.codegen.opt.InterestingPoint
 
isMatrix() - Method in enum org.apache.sysds.common.Types.DataType
 
isMatrix() - Method in class org.apache.sysds.hops.Hop
 
isMatrix() - Method in class org.apache.sysds.runtime.data.TensorBlock
 
isMatrix() - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
 
isMatrix(String) - Method in class org.apache.sysds.parser.VariableSet
 
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
 
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
 
isMatrixOrFrame() - Method in enum org.apache.sysds.common.Types.DataType
 
isMatrixValue() - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
 
isMatrixVector() - Method in enum org.apache.sysds.runtime.matrix.data.LibMatrixBincell.BinaryAccessType
 
isMaxLocalParallelism(int) - Static method in class org.apache.sysds.hops.OptimizerUtils
 
isMaxPrallelizeEnabled() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
isMaxSizesPresent() - Method in class org.apache.sysds.runtime.io.hdf5.message.H5DataSpaceMessage
 
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() - Method in enum org.apache.sysds.runtime.lineage.LineageCacheConfig.ReuseCacheType
 
isMultiLevelReuse() - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
 
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.TernaryOp
 
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.
ISNA - org.apache.sysds.common.Builtins
 
ISNA - org.apache.sysds.common.Types.OpOp1
 
ISNA - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
isNamedList() - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
ISNAN - org.apache.sysds.common.Builtins
 
ISNAN - org.apache.sysds.common.Types.OpOp1
 
ISNAN - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
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
 
isNoEmptyBlocks() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
 
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
 
isNotEmpty(int) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
 
isNotEmpty(int) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
isNotEmpty(int) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
isNotEmpty(int) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
isNotEmpty(int) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
isNotEmpty(int) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
isNotEmpty(int) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
isNotEmpty(int) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
isNotEmpty(int) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
isNotEmpty(int) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
isNotMatrixVectorBinaryOperation(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
isNotOver(int) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AIterator
Find out if the current offset is not exceeding the index given.
isNotSet() - Method in class org.apache.sysds.runtime.iogen.ValueTrimFormat
 
isNotSupportedBySpoofCUDA() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
isNotSupportedBySpoofCUDA() - Method in enum org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
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
 
isNumeric(String) - Static method in class org.apache.sysds.runtime.codegen.CodegenUtils
Extension of org.apache.commons.lang.StringUtils to account for negatives and decimals.
isNumeric(Types.ValueType) - Method in class org.apache.sysds.runtime.data.DenseBlock
Indicates if the dense block is a specific numeric value type.
isNumeric(Types.ValueType) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
 
isNumeric(Types.ValueType) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
 
isNumeric(Types.ValueType) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
 
isNumeric(Types.ValueType) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
 
isNumeric(Types.ValueType) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
 
isNumeric(Types.ValueType) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
 
isNumeric(Types.ValueType) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
 
isNumeric(Types.ValueType) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
 
isNumeric(Types.ValueType) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
 
isNumeric(Types.ValueType) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
 
isNumeric(Types.ValueType) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
 
isNumeric(Types.ValueType) - 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
 
isOuterProductTSMM(int, int, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
 
isOutputEmptyBlocks() - Method in class org.apache.sysds.hops.Hop
 
isOutputFederated(Instruction, Data) - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
 
isOutputThreadSafe() - Method in class org.apache.sysds.runtime.matrix.data.DnnParameters
 
isOverlapping() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
isOverlapping() - Method in class org.apache.sysds.runtime.compress.workload.Op
 
isParallelIOEnabled() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
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
 
isParallelTokenize() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
isParallelTransform() - 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
 
isPassThrough() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
isPatternField() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesMM
 
isPending() - Method in class org.apache.sysds.runtime.instructions.spark.data.RDDObject
 
isPendingRDDOps() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
isPersistableSparkOp(Lop) - Static method in class org.apache.sysds.lops.OperatorOrderingUtils
 
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
 
isPlaceholder() - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
isPlanRef(int) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
 
isPPredOperation() - Method in class org.apache.sysds.hops.BinaryOp
 
isPrefetchEnabled() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
isPseudoFunctionCall() - Method in class org.apache.sysds.hops.FunctionOp
 
isPseudoNumeric() - Method in enum org.apache.sysds.common.Types.ValueType
 
isRDDCached(int) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
 
isRDDPersist() - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
 
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.
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.
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
 
isReady() - Method in class org.apache.sysds.runtime.util.DependencyTask
 
isRecode() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
isRecodeToDummy() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
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) - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
Indicates if the given function is either directly or indirectly recursive.
isRecursiveFunction(String, String) - Method in class org.apache.sysds.hops.ipa.FunctionCallGraph
Indicates if the given function is either directly or indirectly recursive.
isRemoveEmpty(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
isRemoveEmpty(Hop, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
isRemoveVariable() - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
 
isRemoveVariable(String) - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
Checks if this instruction is a remove instruction for varName
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
 
isRequiredDecompression() - Method in class org.apache.sysds.hops.Hop
 
isReset() - Method in enum org.apache.sysds.hops.recompile.Recompiler.ResetType
 
isReset() - Method in class org.apache.sysds.hops.recompile.RecompileStatus
 
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.MMTSJ.MMTSJType
 
isRight() - Method in enum org.apache.sysds.lops.WeightedDivMM.WDivMMType
 
isRightMM() - Method in class org.apache.sysds.runtime.compress.workload.OpSided
 
isRLEAllowed() - Method in class org.apache.sysds.runtime.compress.CompressionSettings
 
isrmVarPending() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
 
isRow() - Method in enum org.apache.sysds.common.Types.Direction
 
isRowAggregate() - Method in class org.apache.sysds.runtime.matrix.operators.AggregateUnaryOperator
 
isRowCol() - Method in enum org.apache.sysds.common.Types.Direction
 
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
 
isRowPartitioned() - Method in enum org.apache.sysds.hops.fedplanner.FTypes.FType
 
isRowRegular() - Method in class org.apache.sysds.runtime.iogen.ReaderMapping
 
isRows() - Method in enum org.apache.sysds.common.Types.CorrectionLocationType
 
isRowSafeLeft(double[]) - Method in class org.apache.sysds.runtime.matrix.operators.BinaryOperator
 
isRowSafeRight(double[]) - Method in class org.apache.sysds.runtime.matrix.operators.BinaryOperator
 
isRowType() - Method in enum org.apache.sysds.hops.fedplanner.FTypes.AlignType
 
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
 
isSameTypeString(Types.ValueType, Types.ValueType) - Static method in enum org.apache.sysds.common.Types.ValueType
 
isSBP() - Method in enum org.apache.sysds.parser.Statement.PSUpdateType
 
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
 
isScalarValue() - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
 
isScript() - Method in enum org.apache.sysds.common.Builtins
 
isSerializedBytes() - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
 
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 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() - Method in class org.apache.sysds.runtime.frame.data.columns.Array
analyze if this array can be shallow serialized.
isShallowSerialize() - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
isShallowSerialize() - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
isShallowSerialize() - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
isShallowSerialize() - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
isShallowSerialize() - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
isShallowSerialize() - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
isShallowSerialize() - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
isShallowSerialize() - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
isShallowSerialize() - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
isShallowSerialize() - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
isShallowSerialize() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
isShallowSerialize(boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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(boolean) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
isShallowSerialize(boolean) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
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) - 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, 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.
isSinglePrecision() - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixNative
 
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, double[]) - Static method in class org.apache.sysds.runtime.util.SortUtils
 
isSorted(int, int, int[]) - 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() - 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
 
isSparse() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesLIBSVM
 
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
 
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
 
isSparseOutputMatrixMult(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
 
isSparsePermutationMatrix() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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
 
isSpecial(double) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
isSplitDag() - Method in class org.apache.sysds.parser.StatementBlock
 
isStagedParallelTransform() - Static method in class org.apache.sysds.conf.ConfigurationManager
 
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
 
isSupported(SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNode
 
isSupported(SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeBinary
 
isSupported(SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
 
isSupported(SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeData
 
isSupported(SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeMultiAgg
 
isSupported(SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeNary
 
isSupported(SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeOuterProduct
 
isSupported(SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
 
isSupported(SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTernary
 
isSupported(SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeUnary
 
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
 
isSymmetric() - Method in class org.apache.sysds.runtime.iogen.ReaderMapping
 
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
 
isTerminalHop(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
Check if given hop is of a terminal type.
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.compress.CompressedMatrixBlock
 
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
 
isTransposed() - Method in enum org.apache.sysds.hops.fedplanner.FTypes.AlignType
 
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(double) - Static method in interface org.apache.sysds.runtime.frame.data.lib.FrameUtil
 
isType(double, Types.ValueType) - Static method in interface org.apache.sysds.runtime.frame.data.lib.FrameUtil
 
isType(String) - Static method in interface org.apache.sysds.runtime.frame.data.lib.FrameUtil
 
isType(String, Types.ValueType) - Static method in interface org.apache.sysds.runtime.frame.data.lib.FrameUtil
Get type type subject to minimum another type.
isType(TemplateBase.TemplateType, TemplateBase.TemplateType...) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
isType(FTypes.FType) - Method in enum org.apache.sysds.hops.fedplanner.FTypes.FType
 
isUltraSparse() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
isUltraSparse() - 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
 
isUltraSparse(boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
isUltraSparse(boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
isUltraSparse(int, int) - Method in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
Check for ultra sparsity
isUltraSparseMatrixMult(MatrixBlock, MatrixBlock, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
 
isUMMEnabled() - Static method in class org.apache.sysds.hops.OptimizerUtils
Check if unified memory manager is in effect
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...) - 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
 
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
 
isUnaryRowAgg(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(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.
isValidCPDimensions(DataCharacteristics) - Static method in class org.apache.sysds.hops.OptimizerUtils
 
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
 
isValidDimensionsBinaryExtended(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.ParamBuiltinOp, Types.ParamBuiltinOp...) - 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
 
isValidOpcode(String) - Static method in class org.apache.sysds.runtime.instructions.fed.UnaryMatrixFEDInstruction
 
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() - Method in class org.apache.sysds.runtime.data.TensorBlock
 
isVector() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
isVector(Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
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.lops.Lop
 
isVisited() - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
isWeighted() - Method in enum org.apache.sysds.lops.MapMultChain.ChainType
 
isWideFormat() - Method in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplier
 
isWorkload() - Method in enum org.apache.sysds.lops.Compression.CompressConfig
 
isWrite() - Method in enum org.apache.sysds.common.Types.OpOpData
 
isWrite() - Method in class org.apache.sysds.hops.DataOp
 
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() - Constructor for class org.apache.sysds.parser.dml.DmlParser.IterablePredicateContext
 
IterablePredicateContext(ParserRuleContext, int) - 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.compress.colgroup.indexes.ArrayIndex
 
iterator() - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex
A Iterator of the indexes see the iterator interface for details.
iterator() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.RangeIndex
 
iterator() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.SingleIndex
 
iterator() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.TwoIndex
 
iterator() - Method in class org.apache.sysds.runtime.instructions.spark.data.LazyIterableIterator
 
IteratorFactory - Interface in org.apache.sysds.runtime.frame.data.iterators
Factory pattern for construction of rowIterators of the FrameBlock.
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
 

J

jaccardSim(String, String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
JANINO - org.apache.sysds.hops.codegen.SpoofCompiler.CompilerType
 
JAVA - org.apache.sysds.hops.codegen.SpoofCompiler.GeneratorAPI
 
JAVA_COMPILER - Static variable in class org.apache.sysds.hops.codegen.SpoofCompiler
 
JAVAC - org.apache.sysds.hops.codegen.SpoofCompiler.CompilerType
 
javaRDDStringCSVToFrameObject(JavaRDD<String>) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
Convert a JavaRDD<String> in CSV format to a FrameObject
javaRDDStringCSVToFrameObject(JavaRDD<String>, FrameMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
Convert a JavaRDD<String> in CSV format to a FrameObject
javaRDDStringCSVToMatrixObject(JavaRDD<String>) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
Convert a JavaRDD<String> in CSV format to a MatrixObject
javaRDDStringCSVToMatrixObject(JavaRDD<String>, MatrixMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
Convert a JavaRDD<String> in CSV format to a MatrixObject
javaRDDStringIJVToFrameObject(JavaRDD<String>, FrameMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
Convert a JavaRDD<String> in IJV format to a FrameObject .
javaRDDStringIJVToMatrixObject(JavaRDD<String>, MatrixMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
Convert a JavaRDD<String> in IJV format to a MatrixObject .
JCudaKernels - Class in org.apache.sysds.runtime.instructions.gpu.context
 
jitCompileTime - Variable in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics.FedStatsCollection
 
JMLC_MEM_STATISTICS - Static variable in class org.apache.sysds.api.DMLScript
 
JMLCUtils - Class in org.apache.sysds.api.jmlc
Utility class containing static methods for working with JMLC.
JMLCUtils() - Constructor for class org.apache.sysds.api.jmlc.JMLCUtils
 
JNI_MAT_ENTRY_SIZE - Static variable in interface org.apache.sysds.runtime.codegen.SpoofCUDAOperator
 
jsc() - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
Obtain JavaSparkContext from MLContextProxy.
JSON_ATTRS - Static variable in class org.apache.sysds.runtime.transform.TfUtils
 
JSON_CONSTS - Static variable in class org.apache.sysds.runtime.transform.TfUtils
 
JSON_MTHD - Static variable in class org.apache.sysds.runtime.transform.TfUtils
 
JSON_NBINS - Static variable in class org.apache.sysds.runtime.transform.TfUtils
 
JSONHelper - Class in org.apache.sysds.utils
 
JSONHelper() - Constructor for class org.apache.sysds.utils.JSONHelper
 
JSONL - org.apache.sysds.common.Types.FileFormat
 

K

K - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
 
KahanFunction - Class in org.apache.sysds.runtime.functionobjects
Runtime function type to perform the summation of values using the Kahan summation algorithm.
KahanFunction() - Constructor for class org.apache.sysds.runtime.functionobjects.KahanFunction
 
KahanObject - Class in org.apache.sysds.runtime.instructions.cp
 
KahanObject(double, double) - Constructor for class org.apache.sysds.runtime.instructions.cp.KahanObject
 
KahanPlus - Class in org.apache.sysds.runtime.functionobjects
 
KahanPlusSq - Class in org.apache.sysds.runtime.functionobjects
Runtime function to perform the summation of squared values using the Kahan summation algorithm.
KEEP_DATA_ON_WORKER - org.apache.sysds.parser.Statement.FederatedPSScheme
 
KeepDataOnWorkerFederatedScheme - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
Keep Data on Worker Federated scheme When the parameter server runs in federated mode it cannot pull in the data which is already on the workers.
KeepDataOnWorkerFederatedScheme() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.KeepDataOnWorkerFederatedScheme
 
key - Variable in class org.apache.sysds.runtime.compress.utils.DArrCounts
 
key - Variable in class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap.DArrayIListEntry
 
key - Variable in class org.apache.sysds.runtime.compress.utils.DCounts
 
key - Variable in class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap.DIListEntry
 
KEY_DELIM - Static variable in class org.apache.sysds.runtime.controlprogram.Program
 
KEY_VALUE_DELIM - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
 
keyClass - Variable in class org.apache.sysds.runtime.io.InputOutputInfo
 
keyEquals(DblArray) - Method in class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap.DArrayIListEntry
 
keys - Variable in class org.apache.sysds.runtime.transform.tokenize.DocumentRepresentation
 
keySet() - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
 
KM - org.apache.sysds.common.Builtins
 
KMEANS - org.apache.sysds.common.Builtins
 
KMEANSPREDICT - org.apache.sysds.common.Builtins
 
KMV - org.apache.sysds.runtime.matrix.operators.CountDistinctOperatorTypes
 
KMVSketch - Class in org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox
KMV synopsis(for k minimum values) Distinct-Value Estimation Kevin S.
KMVSketch(Operator) - Constructor for class org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox.KMVSketch
 
KNN - org.apache.sysds.common.Builtins
 
KNNBF - org.apache.sysds.common.Builtins
 
KNNGRAPH - org.apache.sysds.common.Builtins
 
knownBlocksize() - Method in class org.apache.sysds.runtime.io.FileFormatProperties
 
knownParamservFunctions(Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
knownParamservFunctions(Hop, DMLProgram) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 

L

L2_CACHESIZE - Static variable in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
 
L2SVM - org.apache.sysds.common.Builtins
 
L2SVMPREDICT - org.apache.sysds.common.Builtins
 
L3_CACHESIZE - Static variable in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
 
LanguageErrorCodes() - Constructor for class org.apache.sysds.parser.LanguageException.LanguageErrorCodes
 
LanguageException - Exception in org.apache.sysds.parser
Exception occurring at the Language level.
LanguageException() - Constructor for exception org.apache.sysds.parser.LanguageException
 
LanguageException(String) - Constructor for exception org.apache.sysds.parser.LanguageException
 
LanguageException(String, String) - Constructor for exception org.apache.sysds.parser.LanguageException
 
LanguageException(String, Throwable) - Constructor for exception org.apache.sysds.parser.LanguageException
 
LanguageException(Throwable) - Constructor for exception org.apache.sysds.parser.LanguageException
 
LanguageException.LanguageErrorCodes - Class in org.apache.sysds.parser
 
LASSO - org.apache.sysds.common.Builtins
 
LASTCOLUMN - org.apache.sysds.common.Types.CorrectionLocationType
 
LASTFOURCOLUMNS - org.apache.sysds.common.Types.CorrectionLocationType
 
LASTFOURROWS - org.apache.sysds.common.Types.CorrectionLocationType
 
LASTROW - org.apache.sysds.common.Types.CorrectionLocationType
 
LASTTWOCOLUMNS - org.apache.sysds.common.Types.CorrectionLocationType
 
LASTTWOROWS - org.apache.sysds.common.Types.CorrectionLocationType
 
launchKernel(String, ExecutionConfig, Object...) - Method in class org.apache.sysds.runtime.instructions.gpu.context.JCudaKernels
Setups the kernel parameters and launches the kernel using cuLaunchKernel API.
LayeredGraph(List<MatrixBlock>, int) - Constructor for class org.apache.sysds.hops.estim.EstimatorLayeredGraph.LayeredGraph
 
LazyIterableIterator<T> - Class in org.apache.sysds.runtime.instructions.spark.data
This class is a generic base class for lazy, single pass iterator classes in order to simplify the implementation of lazy iterators for mapPartitions use cases.
LazyIterableIterator(Iterator<T>) - Constructor for class org.apache.sysds.runtime.instructions.spark.data.LazyIterableIterator
 
LazyWriteBuffer - Class in org.apache.sysds.runtime.controlprogram.caching
 
LazyWriteBuffer() - Constructor for class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
 
LazyWriteBuffer.RPolicy - Enum in org.apache.sysds.runtime.controlprogram.caching
 
LDRB - org.apache.sysds.runtime.data.DenseBlock.Type
 
left - Variable in class org.apache.sysds.parser.dml.DmlParser.AddSubExpressionContext
 
left - Variable in class org.apache.sysds.parser.dml.DmlParser.AtomicExpressionContext
 
left - Variable in class org.apache.sysds.parser.dml.DmlParser.BooleanAndExpressionContext
 
left - Variable in class org.apache.sysds.parser.dml.DmlParser.BooleanNotExpressionContext
 
left - Variable in class org.apache.sysds.parser.dml.DmlParser.BooleanOrExpressionContext
 
left - Variable in class org.apache.sysds.parser.dml.DmlParser.MatrixMulExpressionContext
 
left - Variable in class org.apache.sysds.parser.dml.DmlParser.ModIntDivExpressionContext
 
left - Variable in class org.apache.sysds.parser.dml.DmlParser.MultDivExpressionContext
 
left - Variable in class org.apache.sysds.parser.dml.DmlParser.PowerExpressionContext
 
left - Variable in class org.apache.sysds.parser.dml.DmlParser.RelationalExpressionContext
 
left - Variable in class org.apache.sysds.parser.dml.DmlParser.UnaryExpressionContext
 
LEFT - org.apache.sysds.lops.LeftIndex.LixCacheType
 
LEFT - org.apache.sysds.lops.MapMult.CacheType
 
LEFT - org.apache.sysds.lops.MMTSJ.MMTSJType
 
LEFT - org.apache.sysds.lops.PMMJ.CacheType
 
LEFT_OUTER_PRODUCT - org.apache.sysds.runtime.codegen.SpoofOuterProduct.OutProdType
 
LEFT_PART - org.apache.sysds.lops.MapMult.CacheType
 
LEFT_PART - org.apache.sysds.lops.PMMJ.CacheType
 
LeftIndex - Class in org.apache.sysds.lops
 
LeftIndex - org.apache.sysds.lops.Lop.Type
 
LeftIndex(Lop, Lop, Lop, Lop, Lop, Lop, Types.DataType, Types.ValueType, Types.ExecType) - Constructor for class org.apache.sysds.lops.LeftIndex
 
LeftIndex(Lop, Lop, Lop, Lop, Lop, Lop, Types.DataType, Types.ValueType, Types.ExecType, LeftIndex.LixCacheType) - Constructor for class org.apache.sysds.lops.LeftIndex
 
LeftIndex.LixCacheType - Enum in org.apache.sysds.lops
 
LeftIndexingOp - Class in org.apache.sysds.hops
 
LeftIndexingOp(String, Types.DataType, Types.ValueType, Hop, Hop, Hop, Hop, Hop, Hop, boolean, boolean) - Constructor for class org.apache.sysds.hops.LeftIndexingOp
 
LeftIndexingOp.LeftIndexingMethod - Enum in org.apache.sysds.hops
 
leftIndexingOperations(FrameBlock, int, int, int, int, FrameBlock) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
leftIndexingOperations(FrameBlock, IndexRange, FrameBlock) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
leftIndexingOperations(ScalarObject, int, int, MatrixBlock, MatrixObject.UpdateType) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
leftIndexingOperations(ScalarObject, int, int, MatrixBlock, MatrixObject.UpdateType) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Explicitly allow left indexing for scalars.
leftIndexingOperations(MatrixBlock, int, int, int, int, MatrixBlock, MatrixObject.UpdateType) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
leftIndexingOperations(MatrixBlock, int, int, int, int, MatrixBlock, MatrixObject.UpdateType) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
leftIndexingOperations(MatrixBlock, IndexRange, MatrixBlock, MatrixObject.UpdateType) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
leftMultByAColGroup(AColGroup, MatrixBlock, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Left side matrix multiplication with a column group that is transposed.
leftMultByAColGroup(AColGroup, MatrixBlock, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AMorphingMMColGroup
 
leftMultByAColGroup(AColGroup, MatrixBlock, int) - Method in class org.apache.sysds.runtime.compress.colgroup.APreAgg
 
leftMultByAColGroup(AColGroup, MatrixBlock, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
leftMultByAColGroup(AColGroup, MatrixBlock, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
leftMultByAColGroup(AColGroup, MatrixBlock, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
leftMultByAColGroup(AColGroup, MatrixBlock, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
leftMultByMatrix(CompressedMatrixBlock, MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibLeftMultBy
Left multiplication with two CompressedMatrixBlock following the equation: ret = left %*% right
leftMultByMatrixNoPreAgg(MatrixBlock, MatrixBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Left multiply with this column group.
leftMultByMatrixNoPreAgg(MatrixBlock, MatrixBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AMorphingMMColGroup
 
leftMultByMatrixNoPreAgg(MatrixBlock, MatrixBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ASDCZero
 
leftMultByMatrixNoPreAgg(MatrixBlock, MatrixBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
leftMultByMatrixNoPreAgg(MatrixBlock, MatrixBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
leftMultByMatrixNoPreAgg(MatrixBlock, MatrixBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
leftMultByMatrixNoPreAgg(MatrixBlock, MatrixBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
leftMultByMatrixNoPreAgg(MatrixBlock, MatrixBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
 
leftMultByMatrixNoPreAgg(MatrixBlock, MatrixBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
 
leftMultByMatrixNoPreAgg(MatrixBlock, MatrixBlock, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
leftMultByMatrixTransposed(CompressedMatrixBlock, CompressedMatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibLeftMultBy
Left multiplication with two CompressedMatrixBlock following the equation: ret = t(left) %*% right
leftMultByMatrixTransposed(CompressedMatrixBlock, MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibLeftMultBy
Left multiplication with a CompressedMatrixBlock on the right following the equation: ret = t(left) %*% right
leftMultByTransposeSelf(CompressedMatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibTSMM
Self left Matrix multiplication (tsmm) t(x) %*% x
LeftScalarOperator - Class in org.apache.sysds.runtime.matrix.operators
Scalar operator for scalar-matrix operations with scalar on the left-hand-side.
LeftScalarOperator(ValueFunction, double) - Constructor for class org.apache.sysds.runtime.matrix.operators.LeftScalarOperator
 
LeftScalarOperator(ValueFunction, double, int) - Constructor for class org.apache.sysds.runtime.matrix.operators.LeftScalarOperator
 
legacyBuild(FrameBlock) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
LegacyEncoder - 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.
LENET_PREDICT - org.apache.sysds.common.Builtins
 
LENET_TRAIN - org.apache.sysds.common.Builtins
 
LENGTH - org.apache.sysds.common.Builtins
 
LENGTH - org.apache.sysds.common.Types.OpOp1
 
LENGTH - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
LENGTH - org.apache.sysds.runtime.instructions.cp.AggregateUnaryCPInstruction.AUType
 
LESS - org.apache.sysds.common.Types.OpOp2
 
LESS - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
LESS - org.apache.sysds.parser.Expression.RelationalOp
 
LESSEQUAL - org.apache.sysds.common.Types.OpOp2
 
LESSEQUAL - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
LESSEQUAL - org.apache.sysds.parser.Expression.RelationalOp
 
LessThan - Class in org.apache.sysds.runtime.functionobjects
 
LessThanEquals - Class in org.apache.sysds.runtime.functionobjects
 
LEVEL1 - org.apache.sysds.runtime.util.DMVUtils.LEVEL_ENUM
 
LEVEL2 - org.apache.sysds.runtime.util.DMVUtils.LEVEL_ENUM
 
LEVEL3 - org.apache.sysds.runtime.util.DMVUtils.LEVEL_ENUM
 
LEVEL4 - org.apache.sysds.runtime.util.DMVUtils.LEVEL_ENUM
 
LEVEL5 - org.apache.sysds.runtime.util.DMVUtils.LEVEL_ENUM
 
LEVEL6 - org.apache.sysds.runtime.util.DMVUtils.LEVEL_ENUM
 
LEVELIN - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
 
LEVELOUT - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
 
LevelsExecutor(Map<String, Integer>, DMVUtils.LEVEL_ENUM) - Static method in class org.apache.sysds.runtime.util.DMVUtils
 
LibCommonsMath - Class in org.apache.sysds.runtime.matrix.data
Library for matrix operations that need invocation of Apache Commons Math library.
LibMatrixAgg - Class in org.apache.sysds.runtime.matrix.data
MB: Library for matrix aggregations including ak+, uak+ for all combinations of dense and sparse representations, and corrections.
LibMatrixBincell - Class in org.apache.sysds.runtime.matrix.data
Library for binary cellwise operations (incl arithmetic, relational, etc).
LibMatrixBincell.BinaryAccessType - Enum in org.apache.sysds.runtime.matrix.data
 
LibMatrixCountDistinct - Interface in org.apache.sysds.runtime.matrix.data
This class contains various methods for counting the number of distinct values inside a MatrixBlock
LibMatrixCUDA - Class in org.apache.sysds.runtime.matrix.data
All CUDA kernels and library calls are redirected through this class
LibMatrixCUDA() - Constructor for class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
 
LibMatrixCuDNN - Class in org.apache.sysds.runtime.matrix.data
This class contains method that invoke CuDNN operations.
LibMatrixCuDNN() - Constructor for class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNN
 
LibMatrixCuDNNConvolutionAlgorithm - Class in org.apache.sysds.runtime.matrix.data
This class is a wrapper that contain necessary data structures to invoke a cudnn convolution* functions (such as cudnnConvolutionForward, etc) It implements autocloseable to simplify the LibMatrixCuDNN code and also avoids potential memory leaks.
LibMatrixCuDNNInputRowFetcher - Class in org.apache.sysds.runtime.matrix.data
Performs a slice operation: out = in[(n+1):(n+1), 1:numColumns]
LibMatrixCuDNNInputRowFetcher(GPUContext, String, MatrixObject) - Constructor for class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNInputRowFetcher
Initialize the input fetcher
LibMatrixCuDNNPoolingDescriptors - Class in org.apache.sysds.runtime.matrix.data
This class is a wrapper that contain necessary data structures to invoke a cudnn convolution* functions (such as cudnnConvolutionForward, etc) It implements autocloseable to simplify the LibMatrixCuDNN code and also avoids potential memory leaks.
LibMatrixCuDNNPoolingDescriptors() - Constructor for class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNPoolingDescriptors
 
LibMatrixCuDNNRnnAlgorithm - Class in org.apache.sysds.runtime.matrix.data
 
LibMatrixCuDNNRnnAlgorithm(ExecutionContext, GPUContext, String, String, int, int, int, int, boolean, Pointer) - Constructor for class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNRnnAlgorithm
 
LibMatrixCuMatMult - Class in org.apache.sysds.runtime.matrix.data
 
LibMatrixCuMatMult() - Constructor for class org.apache.sysds.runtime.matrix.data.LibMatrixCuMatMult
 
LibMatrixDatagen - Class in org.apache.sysds.runtime.matrix.data
 
LibMatrixDNN - Class in org.apache.sysds.runtime.matrix.data
 
LibMatrixDNN() - Constructor for class org.apache.sysds.runtime.matrix.data.LibMatrixDNN
 
LibMatrixDNN.PoolingType - Enum in org.apache.sysds.runtime.matrix.data
 
LibMatrixDNNConv2d - Class in org.apache.sysds.runtime.matrix.data
This class contains the set of operators used for performing conv2d
LibMatrixDNNConv2d() - Constructor for class org.apache.sysds.runtime.matrix.data.LibMatrixDNNConv2d
 
LibMatrixDNNHelper - Class in org.apache.sysds.runtime.matrix.data
 
LibMatrixDNNHelper() - Constructor for class org.apache.sysds.runtime.matrix.data.LibMatrixDNNHelper
 
LibMatrixDNNIm2Col - Class in org.apache.sysds.runtime.matrix.data
This class contains the different implementation of im2col operation
LibMatrixDNNIm2Col() - Constructor for class org.apache.sysds.runtime.matrix.data.LibMatrixDNNIm2Col
 
LibMatrixDNNPooling - Class in org.apache.sysds.runtime.matrix.data
This class contains the set of operators used for performing pooling
LibMatrixDNNPooling() - Constructor for class org.apache.sysds.runtime.matrix.data.LibMatrixDNNPooling
 
LibMatrixDNNRelu - Class in org.apache.sysds.runtime.matrix.data
This class contains the different implementation of rotate180 operation
LibMatrixDNNRelu() - Constructor for class org.apache.sysds.runtime.matrix.data.LibMatrixDNNRelu
 
LibMatrixDNNRelu.ReluBackward - Class in org.apache.sysds.runtime.matrix.data
Performs the operation: (X gt 0) * dout
LibMatrixDNNRotate180 - Class in org.apache.sysds.runtime.matrix.data
This class contains the different implementation of rotate180 operation
LibMatrixDNNRotate180() - Constructor for class org.apache.sysds.runtime.matrix.data.LibMatrixDNNRotate180
 
LibMatrixDNNRotate180.Rotate180Worker - Interface in org.apache.sysds.runtime.matrix.data
 
LibMatrixEquals - Class in org.apache.sysds.runtime.matrix.data
Equals library for MatrixBLocks:
LibMatrixMult - Class in org.apache.sysds.runtime.matrix.data
MB: Library for matrix multiplications including MM, MV, VV for all combinations of dense, sparse, ultrasparse representations and special operations such as transpose-self matrix multiplication.
LibMatrixNative - Class in org.apache.sysds.runtime.matrix.data
 
LibMatrixNative() - Constructor for class org.apache.sysds.runtime.matrix.data.LibMatrixNative
 
LibMatrixOuterAgg - Class in org.apache.sysds.runtime.matrix.data
ACS: Purpose of this library is to make some of the unary outer aggregate operator more efficient.
LibMatrixReorg - Class in org.apache.sysds.runtime.matrix.data
MB: Library for selected matrix reorg operations including special cases and all combinations of dense and sparse representations.
LibMatrixSketch - Class in org.apache.sysds.runtime.matrix.data
 
LibMatrixSketch() - Constructor for class org.apache.sysds.runtime.matrix.data.LibMatrixSketch
 
LibMatrixTercell - Class in org.apache.sysds.runtime.matrix.data
Library for ternary cellwise operations.
LibSpoofPrimitives - Class in org.apache.sysds.runtime.codegen
This library contains all vector primitives that are used in generated source code for fused operators.
LibSpoofPrimitives() - Constructor for class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
 
LIBSVM - org.apache.sysds.common.Types.FileFormat
 
LIBSVM_DELIM - Static variable in class org.apache.sysds.runtime.io.IOUtilFunctions
 
LIBSVM_INDEX_DELIM - Static variable in class org.apache.sysds.parser.DataExpression
 
LIBSVM_INDEX_DELIM - Static variable in class org.apache.sysds.runtime.io.IOUtilFunctions
 
LIBSVMInputOutputInfo - Static variable in class org.apache.sysds.runtime.io.InputOutputInfo
 
LIBSVMReblock - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
LIBSVMReblockSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
libsvmToBinaryBlock(JavaSparkContext, String, String, String, DataCharacteristics) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
Converts a libsvm text input file into two binary block matrices for features and labels, and saves these to the specified output files.
libsvmToBinaryBlock(JavaSparkContext, JavaPairRDD<LongWritable, Text>, DataCharacteristics, String, String) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
 
LibTensorAgg - Class in org.apache.sysds.runtime.data
 
LibTensorAgg() - Constructor for class org.apache.sysds.runtime.data.LibTensorAgg
 
LibTensorBincell - Class in org.apache.sysds.runtime.data
 
LibTensorBincell() - Constructor for class org.apache.sysds.runtime.data.LibTensorBincell
 
LibTensorReorg - Class in org.apache.sysds.runtime.data
 
linCachePolicy - Variable in class org.apache.sysds.api.DMLOptions
 
lIndex - Variable in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset.OffsetSliceInfo
 
LINE_COMMENT - Static variable in class org.apache.sysds.parser.dml.DmlLexer
 
LINE_COMMENT - Static variable in class org.apache.sysds.parser.dml.DmlParser
 
lineage - Variable in class org.apache.sysds.api.DMLOptions
 
Lineage - Class in org.apache.sysds.runtime.lineage
 
Lineage() - Constructor for class org.apache.sysds.runtime.lineage.Lineage
 
Lineage(Lineage) - Constructor for class org.apache.sysds.runtime.lineage.Lineage
 
LINEAGE - org.apache.sysds.common.Builtins
 
LINEAGE - org.apache.sysds.common.Types.OpOp1
 
LINEAGE - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
LINEAGE - org.apache.sysds.runtime.instructions.cp.AggregateUnaryCPInstruction.AUType
 
LINEAGE - Static variable in class org.apache.sysds.api.DMLScript
 
lineage_debugger - Variable in class org.apache.sysds.api.DMLOptions
 
LINEAGE_DEBUGGER - Static variable in class org.apache.sysds.api.DMLScript
 
lineage_dedup - Variable in class org.apache.sysds.api.DMLOptions
 
LINEAGE_DEDUP - Static variable in class org.apache.sysds.api.DMLScript
 
lineage_estimate - Variable in class org.apache.sysds.api.DMLOptions
 
LINEAGE_ESTIMATE - Static variable in class org.apache.sysds.api.DMLScript
 
LINEAGE_POLICY - Static variable in class org.apache.sysds.api.DMLScript
 
LINEAGE_REUSE - Static variable in class org.apache.sysds.api.DMLScript
 
LINEAGE_TRACE - Static variable in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
 
LineageCache - Class in org.apache.sysds.runtime.lineage
 
LineageCache() - Constructor for class org.apache.sysds.runtime.lineage.LineageCache
 
LineageCacheConfig - Class in org.apache.sysds.runtime.lineage
 
LineageCacheConfig() - Constructor for class org.apache.sysds.runtime.lineage.LineageCacheConfig
 
LineageCacheConfig.LineageCachePolicy - Enum in org.apache.sysds.runtime.lineage
 
LineageCacheConfig.ReuseCacheType - Enum in org.apache.sysds.runtime.lineage
 
lineageCachedChainHead - Variable in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
Next GPUObject that points to the same lineage cached GPU pointer
LineageCacheEntry - Class in org.apache.sysds.runtime.lineage
 
LineageCacheEntry(LineageItem, Types.DataType, MatrixBlock, ScalarObject, long) - Constructor for class org.apache.sysds.runtime.lineage.LineageCacheEntry
 
LineageCacheEviction - Class in org.apache.sysds.runtime.lineage
 
LineageCacheEviction() - Constructor for class org.apache.sysds.runtime.lineage.LineageCacheEviction
 
LINEAGECACHESPILL - Static variable in class org.apache.sysds.conf.DMLConfig
 
LineageCacheStatistics - Class in org.apache.sysds.runtime.lineage
This singleton provides basic lineage caching statistics in CP.
LineageCacheStatistics() - Constructor for class org.apache.sysds.runtime.lineage.LineageCacheStatistics
 
LineageCodegenItem - Class in org.apache.sysds.runtime.lineage
 
LineageCodegenItem() - Constructor for class org.apache.sysds.runtime.lineage.LineageCodegenItem
 
LineageDebugger - Class in org.apache.sysds.runtime.lineage
 
LineageDebugger() - Constructor for class org.apache.sysds.runtime.lineage.LineageDebugger
 
LineageDedupBlock - Class in org.apache.sysds.runtime.lineage
 
LineageDedupBlock() - Constructor for class org.apache.sysds.runtime.lineage.LineageDedupBlock
 
LineageDedupUtils - Class in org.apache.sysds.runtime.lineage
 
LineageDedupUtils() - Constructor for class org.apache.sysds.runtime.lineage.LineageDedupUtils
 
LineageEstimator - Class in org.apache.sysds.runtime.lineage
 
LineageEstimator() - Constructor for class org.apache.sysds.runtime.lineage.LineageEstimator
 
LineageEstimatorStatistics - Class in org.apache.sysds.runtime.lineage
 
LineageEstimatorStatistics() - Constructor for class org.apache.sysds.runtime.lineage.LineageEstimatorStatistics
 
LineageGPUCacheEviction - Class in org.apache.sysds.runtime.lineage
 
LineageGPUCacheEviction() - Constructor for class org.apache.sysds.runtime.lineage.LineageGPUCacheEviction
 
LineageItem - Class in org.apache.sysds.runtime.lineage
 
LineageItem() - Constructor for class org.apache.sysds.runtime.lineage.LineageItem
 
LineageItem(long, String) - Constructor for class org.apache.sysds.runtime.lineage.LineageItem
 
LineageItem(long, String, String) - Constructor for class org.apache.sysds.runtime.lineage.LineageItem
 
LineageItem(long, String, String, LineageItem[], int) - Constructor for class org.apache.sysds.runtime.lineage.LineageItem
 
LineageItem(long, LineageItem) - Constructor for class org.apache.sysds.runtime.lineage.LineageItem
 
LineageItem(String) - Constructor for class org.apache.sysds.runtime.lineage.LineageItem
 
LineageItem(String, String) - Constructor for class org.apache.sysds.runtime.lineage.LineageItem
 
LineageItem(String, String, LineageItem[]) - Constructor for class org.apache.sysds.runtime.lineage.LineageItem
 
LineageItem(String, LineageItem[]) - Constructor for class org.apache.sysds.runtime.lineage.LineageItem
 
LineageItem(String, LineageItem, int, LineageItem[]) - Constructor for class org.apache.sysds.runtime.lineage.LineageItem
 
LineageItem(String, LineageItem, LineageItem[]) - Constructor for class org.apache.sysds.runtime.lineage.LineageItem
 
LineageItem(LineageItem) - Constructor for class org.apache.sysds.runtime.lineage.LineageItem
 
LineageItem.LineageItemType - Enum in org.apache.sysds.runtime.lineage
 
LineageItemUtils - Class in org.apache.sysds.runtime.lineage
 
LineageItemUtils() - Constructor for class org.apache.sysds.runtime.lineage.LineageItemUtils
 
LineageMap - Class in org.apache.sysds.runtime.lineage
 
LineageMap() - Constructor for class org.apache.sysds.runtime.lineage.LineageMap
 
LineageMap(LineageMap) - Constructor for class org.apache.sysds.runtime.lineage.LineageMap
 
LineageObject - Class in org.apache.sysds.runtime.instructions.spark.data
 
LineageParser - Class in org.apache.sysds.runtime.lineage
 
LineageParser() - Constructor for class org.apache.sysds.runtime.lineage.LineageParser
 
LineageRecomputeUtils - Class in org.apache.sysds.runtime.lineage
 
LineageRecomputeUtils() - Constructor for class org.apache.sysds.runtime.lineage.LineageRecomputeUtils
 
LineageRewriteReuse - Class in org.apache.sysds.runtime.lineage
 
LineageRewriteReuse() - Constructor for class org.apache.sysds.runtime.lineage.LineageRewriteReuse
 
LineageTokenizer - Class in org.apache.sysds.runtime.lineage
 
LineageTokenizer() - Constructor for class org.apache.sysds.runtime.lineage.LineageTokenizer
 
LineageTraceable - Interface in org.apache.sysds.runtime.lineage
 
lineageTraceTokenizer - Static variable in class org.apache.sysds.runtime.lineage.LineageParser
 
LinearFunctional - org.apache.sysds.runtime.compress.colgroup.AColGroup.CompressionType
 
linearHash(int) - Static method in class org.apache.sysds.utils.Hash
Compute the Linear hash of an int input value.
linearHash(int, int) - Static method in class org.apache.sysds.utils.Hash
Compute the Linear hash of an int input value, but only use the first bits of the linear hash.
LinearHash - org.apache.sysds.utils.Hash.HashType
 
linearize(List<Lop>) - Static method in interface org.apache.sysds.lops.compile.linearization.ILinearize
 
LinearRegression - Interface in org.apache.sysds.runtime.compress.colgroup.functional
 
linReuseType - Variable in class org.apache.sysds.api.DMLOptions
 
LIST - org.apache.sysds.common.Builtins
 
LIST - org.apache.sysds.common.Types.DataType
 
LIST - org.apache.sysds.common.Types.OpOpN
 
LIST - org.apache.sysds.common.Types.ParamBuiltinOp
 
LIST - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
LIST - org.apache.sysds.runtime.instructions.cp.AppendCPInstruction.AppendType
 
LIST_ELEMENT_DELIM - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
 
ListAppendPropagator - Class in org.apache.sysds.runtime.privacy.propagation
 
ListAppendPropagator(ListObject, PrivacyConstraint, ListObject, PrivacyConstraint) - Constructor for class org.apache.sysds.runtime.privacy.propagation.ListAppendPropagator
 
ListAppendRemoveCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
ListIndexingCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
LISTNV - org.apache.sysds.common.Builtins
 
ListObject - Class in org.apache.sysds.runtime.instructions.cp
 
ListObject() - Constructor for class org.apache.sysds.runtime.instructions.cp.ListObject
 
ListObject(List<Data>) - Constructor for class org.apache.sysds.runtime.instructions.cp.ListObject
 
ListObject(List<Data>, List<String>) - Constructor for class org.apache.sysds.runtime.instructions.cp.ListObject
 
ListObject(List<Data>, List<String>, List<LineageItem>) - Constructor for class org.apache.sysds.runtime.instructions.cp.ListObject
 
ListObject(Data[]) - Constructor for class org.apache.sysds.runtime.instructions.cp.ListObject
 
ListObject(Data[], String[]) - Constructor for class org.apache.sysds.runtime.instructions.cp.ListObject
 
ListObject(ListObject) - Constructor for class org.apache.sysds.runtime.instructions.cp.ListObject
 
ListReader - Class in org.apache.sysds.runtime.io
 
ListReader() - Constructor for class org.apache.sysds.runtime.io.ListReader
 
ListRemovePropagator - Class in org.apache.sysds.runtime.privacy.propagation
 
ListRemovePropagator(ListObject, PrivacyConstraint, ScalarObject, PrivacyConstraint) - Constructor for class org.apache.sysds.runtime.privacy.propagation.ListRemovePropagator
 
ListWriter - Class in org.apache.sysds.runtime.io
 
ListWriter() - Constructor for class org.apache.sysds.runtime.io.ListWriter
 
Literal - org.apache.sysds.runtime.lineage.LineageItem.LineageItemType
 
LITERAL_PREFIX - Static variable in class org.apache.sysds.lops.Lop
 
LITERAL_PREFIX - Static variable in class org.apache.sysds.runtime.instructions.Instruction
 
LiteralOp - Class in org.apache.sysds.hops
 
LiteralOp(boolean) - Constructor for class org.apache.sysds.hops.LiteralOp
 
LiteralOp(double) - Constructor for class org.apache.sysds.hops.LiteralOp
 
LiteralOp(long) - Constructor for class org.apache.sysds.hops.LiteralOp
 
LiteralOp(String) - Constructor for class org.apache.sysds.hops.LiteralOp
 
LiteralOp(LiteralOp) - Constructor for class org.apache.sysds.hops.LiteralOp
 
LiteralReplacement - Class in org.apache.sysds.hops.recompile
 
LiteralReplacement() - Constructor for class org.apache.sysds.hops.recompile.LiteralReplacement
 
liveIn() - Method in class org.apache.sysds.parser.LiveVariableAnalysis
 
liveOut() - Method in class org.apache.sysds.parser.LiveVariableAnalysis
 
LIVEVAR_AWARE_EXPORT - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
liveVariableAnalysis(DMLProgram) - Method in class org.apache.sysds.parser.DMLTranslator
 
liveVariableAnalysis(DMLProgram, boolean) - Method in class org.apache.sysds.parser.DMLTranslator
 
LiveVariableAnalysis - Class in org.apache.sysds.parser
 
LiveVariableAnalysis() - Constructor for class org.apache.sysds.parser.LiveVariableAnalysis
 
liveVariableAnalysisFunction(DMLProgram, FunctionStatementBlock) - Method in class org.apache.sysds.parser.DMLTranslator
 
LM - org.apache.sysds.common.Builtins
 
LMCG - org.apache.sysds.common.Builtins
 
LMDS - org.apache.sysds.common.Builtins
 
LMPREDICT - org.apache.sysds.common.Builtins
 
loadAndParseBuiltinFunction(String, String, boolean) - Static method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
 
loadBLAS(String, String, String) - Static method in class org.apache.sysds.utils.NativeHelper
Attempts to load native BLAS
loadConfiguration(String) - Static method in class org.apache.sysds.api.DMLScript
 
loadConstraints(DMLProgram) - Method in class org.apache.sysds.hops.fedplanner.PrivacyConstraintLoader
 
loadFederatedPrivacyConstraints(Hop) - Method in class org.apache.sysds.hops.fedplanner.PrivacyConstraintLoader
Get privacy constraints from federated workers for DataOps.
loadFederatedPrivacyConstraints(Hop) - Method in class org.apache.sysds.hops.fedplanner.PrivacyConstraintLoaderMock
Set privacy constraint of given hop to mocked privacy level.
loadLibraryHelperFromResource(String) - Static method in class org.apache.sysds.utils.NativeHelper
Attempts to load the JNI shared library from the sysds jar
loadNativeCodeGenerator(SpoofCompiler.GeneratorAPI) - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
 
loadSystemDS(String) - Method in class org.apache.sysds.utils.SystemDSLoaderUtils
 
Local - Class in org.apache.sysds.lops
 
Local - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
Local(Lop, Types.DataType, Types.ValueType) - Constructor for class org.apache.sysds.lops.Local
 
LOCAL - org.apache.sysds.common.Builtins
 
LOCAL - org.apache.sysds.common.Types.OpOp1
 
LOCAL - org.apache.sysds.parser.Statement.PSModeType
 
LOCAL - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PDataPartitioner
 
LOCAL - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PExecMode
 
LOCAL_AUTOMATIC - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PResultMerge
 
LOCAL_FILE - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PResultMerge
 
LOCAL_MEM - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PResultMerge
 
LOCAL_SPARK_NUM_THREADS - Static variable in class org.apache.sysds.conf.DMLConfig
 
LOCAL_TMP_DIR - Static variable in class org.apache.sysds.conf.DMLConfig
 
LocalCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
A simple instruction that take whatever input it is and return it as a local matrix.
LocalDataPartitioner - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
 
LocalDataPartitioner(Statement.PSScheme) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.LocalDataPartitioner
 
LocalFileUtils - Class in org.apache.sysds.runtime.util
 
LocalFileUtils() - Constructor for class org.apache.sysds.runtime.util.LocalFileUtils
 
localFS - Variable in class org.apache.sysds.runtime.io.ReadProperties
 
LocalParamServer - Class in org.apache.sysds.runtime.controlprogram.paramserv
 
LocalParamServer() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.LocalParamServer
 
LocalParWorker - Class in org.apache.sysds.runtime.controlprogram.parfor
Instances of this class can be used to execute tasks in parallel.
LocalParWorker(long, LocalTaskQueue<Task>, ParForBody, CompilerConfig, int, boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.LocalParWorker
 
LocalPSWorker - Class in org.apache.sysds.runtime.controlprogram.paramserv
 
LocalPSWorker(int, String, Statement.PSFrequency, int, long, ExecutionContext, ParamServer, int, boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.LocalPSWorker
 
LocalTaskQueue<T> - Class in org.apache.sysds.runtime.controlprogram.parfor
This class provides a way of dynamic task distribution to multiple workers in local multi-threaded environments.
LocalTaskQueue() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.LocalTaskQueue
 
LocalVariableMap - Class in org.apache.sysds.runtime.controlprogram
Replaces HashMap⟨String, Data⟩ as the table of variable names and references.
LocalVariableMap() - Constructor for class org.apache.sysds.runtime.controlprogram.LocalVariableMap
 
LocalVariableMap(LocalVariableMap) - Constructor for class org.apache.sysds.runtime.controlprogram.LocalVariableMap
 
log(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
Performs an "log" operation on a matrix on the GPU
LOG - org.apache.sysds.common.Builtins
 
LOG - org.apache.sysds.common.Types.OpOp1
 
LOG - org.apache.sysds.common.Types.OpOp2
 
LOG - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
LOG - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
LOG - org.apache.sysds.lops.WeightedSigmoid.WSigmoidType
 
LOG - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
LOG - Static variable in interface org.apache.sysds.lops.compile.linearization.ILinearize
 
LOG - Static variable in interface org.apache.sysds.runtime.compress.colgroup.ColGroupIO
 
LOG - Static variable in interface org.apache.sysds.runtime.compress.colgroup.ColGroupSizes
 
LOG - Static variable in interface org.apache.sysds.runtime.compress.colgroup.dictionary.DictionaryFactory
 
LOG - Static variable in interface org.apache.sysds.runtime.compress.colgroup.insertionsort.InsertionSorterFactory
 
LOG - Static variable in interface org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory
 
LOG - Static variable in class org.apache.sysds.runtime.compress.colgroup.offset.AIterator
 
LOG - Static variable in class org.apache.sysds.runtime.compress.colgroup.offset.AOffsetIterator
 
LOG - Static variable in interface org.apache.sysds.runtime.compress.colgroup.scheme.ICLAScheme
Logging access for the CLA Scheme encoders
LOG - Static variable in interface org.apache.sysds.runtime.compress.estim.ComEstFactory
 
LOG - Static variable in interface org.apache.sysds.runtime.compress.estim.encoding.EncodingFactory
 
LOG - Static variable in interface org.apache.sysds.runtime.compress.estim.encoding.IEncode
 
LOG - Static variable in interface org.apache.sysds.runtime.compress.estim.sample.SampleEstimatorFactory
 
LOG - Static variable in interface org.apache.sysds.runtime.compress.lib.CLALibMMChain
 
LOG - Static variable in interface org.apache.sysds.runtime.compress.utils.Util
 
LOG - Static variable in interface org.apache.sysds.runtime.frame.data.lib.FrameUtil
 
LOG - Static variable in interface org.apache.sysds.runtime.frame.data.lib.MatrixBlockFromFrame
 
LOG - Static variable in interface org.apache.sysds.runtime.matrix.data.LibMatrixCountDistinct
 
LOG_MINUS - org.apache.sysds.lops.WeightedSigmoid.WSigmoidType
 
LOG_NZ - org.apache.sysds.common.Types.OpOp1
 
LOG_NZ - org.apache.sysds.common.Types.OpOp2
 
LOG_NZ - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
LOG_NZ - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
LOG_NZ - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
LOGICALAND - org.apache.sysds.parser.Expression.BooleanOp
 
LOGICALOR - org.apache.sysds.parser.Expression.BooleanOp
 
logServerTraffic(long, long) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
LOGSUMEXP - org.apache.sysds.common.Builtins
 
logWorkerTraffic(long, long) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
LONG - org.apache.sysds.runtime.util.LongLongDoubleHashMap.EntryType
 
LongArray - Class in org.apache.sysds.runtime.frame.data.columns
 
LongArray(long[]) - Constructor for class org.apache.sysds.runtime.frame.data.columns.LongArray
 
longArrayCost(long) - Static method in class org.apache.sysds.utils.MemoryEstimates
Get the worst case memory usage for an array of longs
LongFrameToLongWritableFrameFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils.LongFrameToLongWritableFrameFunction
 
longHashCode(long) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
longHashCode(long, long) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
Returns the hash code for a long-long pair.
longHashCode(long, long, long) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
Returns the hash code for a long-long-long triple.
LongLongDoubleHashMap - Class in org.apache.sysds.runtime.util
This native long long - double hashmap is specifically designed for ctable operations which only require addvalue - extract semantics.
LongLongDoubleHashMap() - Constructor for class org.apache.sysds.runtime.util.LongLongDoubleHashMap
 
LongLongDoubleHashMap(LongLongDoubleHashMap.EntryType) - Constructor for class org.apache.sysds.runtime.util.LongLongDoubleHashMap
 
LongLongDoubleHashMap.ADoubleEntry - Class in org.apache.sysds.runtime.util
 
LongLongDoubleHashMap.EntryType - Enum in org.apache.sysds.runtime.util
 
longToBa(long, byte[], int) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
 
longToBits(long) - Static method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
LongWritableFrameToLongFrameFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils.LongWritableFrameToLongFrameFunction
 
LongWritableTextToLongTextFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils.LongWritableTextToLongTextFunction
 
LongWritableToSerFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils.LongWritableToSerFunction
 
LOOKUP_C - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
LOOKUP_R - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
LOOKUP_RC - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
LOOKUP_RC1 - org.apache.sysds.hops.codegen.cplan.CNodeTernary.TernaryType
 
LOOKUP_RVECT1 - org.apache.sysds.hops.codegen.cplan.CNodeTernary.TernaryType
 
LOOKUP0 - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
loopPatchMap - Static variable in class org.apache.sysds.runtime.lineage.LineageRecomputeUtils
 
Lop - Class in org.apache.sysds.lops
Base class for all Lops.
Lop(Lop.Type, Types.DataType, Types.ValueType) - Constructor for class org.apache.sysds.lops.Lop
Constructor to be invoked by base class.
Lop.SimpleInstType - Enum in org.apache.sysds.lops
Lop types
Lop.Type - Enum in org.apache.sysds.lops
 
Lop.VisitStatus - Enum in org.apache.sysds.lops
 
LopComparator<N extends Lop> - Class in org.apache.sysds.lops.compile
Comparator class used in sorting the LopDAG in topological order.
LopComparator() - Constructor for class org.apache.sysds.lops.compile.LopComparator
 
LopProperties - Class in org.apache.sysds.lops
 
LopProperties() - Constructor for class org.apache.sysds.lops.LopProperties
 
LopRewriter - Class in org.apache.sysds.lops.rewrite
 
LopRewriter() - Constructor for class org.apache.sysds.lops.rewrite.LopRewriter
 
LopRewriteRule - Class in org.apache.sysds.lops.rewrite
 
LopRewriteRule() - Constructor for class org.apache.sysds.lops.rewrite.LopRewriteRule
 
LopsException - Exception in org.apache.sysds.lops
 
LopsException(String) - Constructor for exception org.apache.sysds.lops.LopsException
 
LopsException(String, Throwable) - Constructor for exception org.apache.sysds.lops.LopsException
 
lossy - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
True if lossy compression is enabled
LOUT - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FederatedOutput
 
LOWER - Static variable in class org.apache.sysds.runtime.util.DMVUtils
 
LOWER_TRI - org.apache.sysds.common.Builtins
 
LOWER_TRI - org.apache.sysds.common.Types.ParamBuiltinOp
 
LOWER_TRI - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ParameterizedBuiltinCode
 
LPLACEHOLDER - Static variable in class org.apache.sysds.runtime.lineage.LineageItemUtils
 
LPLACEHOLDER - Static variable in class org.apache.sysds.runtime.lineage.LineageRecomputeUtils
 
LRU - org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer.RPolicy
 
LRU - org.apache.sysds.runtime.lineage.LineageCacheConfig.LineageCachePolicy
 
lstm(ExecutionContext, GPUContext, String, Pointer, Pointer, Pointer, Pointer, boolean, String, String, int, int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNN
Computes the forward pass for an LSTM layer with M neurons.
LSTM - org.apache.sysds.common.Builtins
 
LSTM_BACKWARD - org.apache.sysds.common.Builtins
 
lstmBackward(ExecutionContext, GPUContext, String, Pointer, Pointer, Pointer, Pointer, String, String, String, String, String, String, String, boolean, int, int, int, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNN
 
LU - org.apache.sysds.common.Builtins
 

M

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
 
MAGG - org.apache.sysds.hops.codegen.template.TemplateBase.TemplateType
 
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.
maintainLineageDebuggerInfo(Instruction) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
maintainSpecialValueBits(Lineage, Instruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageDebugger
 
makeDoubleDictionary() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
makeSpace(long) - Static method in class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
 
malloc(String, long, boolean) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryManager
Allocate pointer of the given size in bytes.
map(String, long) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
map(FrameBlock.FrameMapFunction, long) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
MAP - org.apache.sysds.common.Builtins
 
MAP - org.apache.sysds.common.Types.OpOp3
 
MAP - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
mapDist(FrameBlock.FrameMapFunction) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
mapFunctionOutputs(FunctionOp, FunctionStatement, Map<String, Hop>) - Static method in class org.apache.sysds.hops.fedplanner.FederatedPlannerUtils
Saves the HOPs (TWrite) of the function return values for the variable name used when calling the function.
mapInplace(Function<String, String>) - Method in class org.apache.sysds.runtime.frame.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
 
MAPMM - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
MAPMM - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
MAPMM_CHAIN - org.apache.sysds.hops.AggBinaryOp.MMultMethod
 
MAPMM_L - org.apache.sysds.hops.AggBinaryOp.MMultMethod
 
MAPMM_R - org.apache.sysds.hops.AggBinaryOp.MMultMethod
 
MAPMMCHAIN - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
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 - org.apache.sysds.lops.Lop.Type
 
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_MEM_MULTIPLIER - Static variable in class org.apache.sysds.hops.AggBinaryOp
 
MapMult.CacheType - Enum in org.apache.sysds.lops
 
MapMultChain - Class in org.apache.sysds.lops
 
MapMultChain - org.apache.sysds.lops.Lop.Type
 
MapMultChain(Lop, Lop, Types.DataType, Types.ValueType, Types.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, Types.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.
MAppend - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
MapperService - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.services
 
MapperService() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.MapperService
 
mapResultToModel(ResultSet, Class<T>) - Static method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.MapperService
 
MapToBit - Class in org.apache.sysds.runtime.compress.colgroup.mapping
 
MapToBit(int, int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
MapToByte - Class in org.apache.sysds.runtime.compress.colgroup.mapping
 
MapToByte(int, int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
MapToChar - Class in org.apache.sysds.runtime.compress.colgroup.mapping
 
MapToChar(int, char[]) - Constructor for class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
MapToChar(int, int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
MapToCharPByte - Class in org.apache.sysds.runtime.compress.colgroup.mapping
 
MapToCharPByte(int, char[], byte[]) - Constructor for class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
MapToCharPByte(int, int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
MapToFactory - Interface in org.apache.sysds.runtime.compress.colgroup.mapping
 
MapToFactory.MAP_TYPE - Enum in org.apache.sysds.runtime.compress.colgroup.mapping
 
MapToInt - Class in org.apache.sysds.runtime.compress.colgroup.mapping
 
MapToInt(int, int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
MapToUByte - Class in org.apache.sysds.runtime.compress.colgroup.mapping
 
MapToUByte(int, int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.mapping.MapToUByte
 
MapToZero - Class in org.apache.sysds.runtime.compress.colgroup.mapping
 
MapToZero(int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
MarkForLineageReuse - Class in org.apache.sysds.hops.rewrite
 
MarkForLineageReuse() - Constructor for class org.apache.sysds.hops.rewrite.MarkForLineageReuse
 
MATERIALIZE - org.apache.sysds.runtime.compress.colgroup.insertionsort.InsertionSorterFactory.SORT_TYPE
 
MaterializeSort - Class in org.apache.sysds.runtime.compress.colgroup.insertionsort
 
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(EstimatorBitsetMM.BitsetMatrix) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix
 
matMult(MatrixBlock, MatrixBlock, MatrixBlock, AggregateBinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
 
matMult(MatrixBlock, MatrixBlock, AggregateBinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
 
matMult(MatrixIndexes, MatrixBlock, MatrixIndexes, MatrixBlock, MatrixIndexes, MatrixBlock, AggregateBinaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
 
MATMULT - org.apache.sysds.parser.Expression.BinaryOp
 
MatMultCP - Class in org.apache.sysds.lops
 
MatMultCP - org.apache.sysds.lops.Lop.Type
 
MatMultCP(Lop, Lop, Types.DataType, Types.ValueType, Types.ExecType) - Constructor for class org.apache.sysds.lops.MatMultCP
 
MatMultCP(Lop, Lop, Types.DataType, Types.ValueType, Types.ExecType, boolean, boolean) - Constructor for class org.apache.sysds.lops.MatMultCP
 
MatMultCP(Lop, Lop, Types.DataType, Types.ValueType, Types.ExecType, int) - Constructor for class org.apache.sysds.lops.MatMultCP
 
MatMultCP(Lop, Lop, Types.DataType, Types.ValueType, Types.ExecType, int, 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(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(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(Dataset<Row>, MatrixMetadata) - Constructor for class org.apache.sysds.api.mlcontext.Matrix
Convert a Spark DataFrame to a SystemDS binary-block representation.
Matrix(MatrixObject, SparkExecutionContext) - Constructor for class org.apache.sysds.api.mlcontext.Matrix
 
MATRIX - org.apache.sysds.common.Types.DataType
 
MATRIX - org.apache.sysds.parser.Expression.DataOp
 
MATRIX_BLOCK_DICT - org.apache.sysds.runtime.compress.colgroup.dictionary.DictionaryFactory.Type
 
MATRIX_COL_VECTOR - org.apache.sysds.runtime.matrix.data.LibMatrixBincell.BinaryAccessType
 
MATRIX_DATA_TYPE - Static variable in class org.apache.sysds.parser.Statement
 
MATRIX_MATRIX - org.apache.sysds.runtime.matrix.data.LibMatrixBincell.BinaryAccessType
 
MATRIX_ROW_VECTOR - org.apache.sysds.runtime.matrix.data.LibMatrixBincell.BinaryAccessType
 
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 - org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary.DictType
 
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, boolean) - 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(int, int, 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) - 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
Constructs a sparse MatrixBlock with a given instance of a SparseBlock
MatrixBlock(int, int, DenseBlock) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
MatrixBlock(MatrixBlock) - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
MatrixBlock(MatrixBlock, boolean) - 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.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
 
MatrixBlockDictionary - Class in org.apache.sysds.runtime.compress.colgroup.dictionary
 
matrixBlockFromDenseArray(double[], int) - Static method in interface org.apache.sysds.runtime.compress.utils.Util
 
matrixBlockFromDenseArray(double[], int, boolean) - Static method in interface org.apache.sysds.runtime.compress.utils.Util
 
MatrixBlockFromFrame - Interface in org.apache.sysds.runtime.frame.data.lib
 
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(double) - 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
 
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, 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(long, long, 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
 
MATRIXENTRY_TO_MATRIXCELL - org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtilsExt.RDDConverterTypes
 
MatrixFormat - Enum in org.apache.sysds.api.mlcontext
MatrixFormat represents the different matrix formats supported by the MLContext API.
MatrixGenerateReader - Class in org.apache.sysds.runtime.iogen
 
MatrixGenerateReader(CustomProperties) - Constructor for class org.apache.sysds.runtime.iogen.MatrixGenerateReader
 
MatrixGenerateReader.MatrixReaderRowIrregular - Class in org.apache.sysds.runtime.iogen
 
MatrixGenerateReader.MatrixReaderRowRegularColIrregular - Class in org.apache.sysds.runtime.iogen
 
MatrixGenerateReader.MatrixReaderRowRegularColRegular - Class in org.apache.sysds.runtime.iogen
 
MatrixHistogram(int[], int[], int[], int[], int, int) - Constructor for class org.apache.sysds.hops.estim.EstimatorMatrixHistogram.MatrixHistogram
 
MatrixHistogram(MatrixBlock, boolean) - 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
 
MatrixIndexing - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
MatrixIndexing - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
MatrixIndexing - org.apache.sysds.runtime.instructions.gpu.GPUInstruction.GPUINSTRUCTION_TYPE
 
MatrixIndexing - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
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.
MatrixLineagePair - Class in org.apache.sysds.runtime.controlprogram.federated
Class to represent the relation between a MatrixObject and the respective LineageItem.
MatrixLineagePair() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.MatrixLineagePair
 
MatrixLineagePair(MatrixObject, LineageItem) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.MatrixLineagePair
 
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(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(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(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(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(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(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, 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(MatrixFormat) - Constructor for class org.apache.sysds.api.mlcontext.MatrixMetadata
Constructor to create a MatrixMetadata object based on matrix format.
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, 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, 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(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, 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, 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(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) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
Performs a matrix multiplication All variants use a IKJ access pattern, and internally use dense output.
matrixMult(MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
Performs a matrix multiplication All variants use a IKJ access pattern, and internally use dense output.
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, boolean, int) - 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, int) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibMatrixMult
 
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.
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
 
matrixMultiply(MatrixBlock, MatrixBlock, MatrixBlock, int, boolean, boolean) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibMatrixMult
 
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, 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
TSMM with optional transposed left side or not (Transposed self matrix multiplication)
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(Types.ValueType, String, MetaData, MatrixBlock) - Constructor for class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
Constructor that takes the value type, HDFS filename and associated metadata and a MatrixBlock used for creation after serialization
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
 
MatrixObjectFuture - Class in org.apache.sysds.runtime.controlprogram.context
 
MatrixObjectFuture(Types.ValueType, String, Future<MatrixBlock>) - Constructor for class org.apache.sysds.runtime.controlprogram.context.MatrixObjectFuture
 
MatrixObjectFuture(MatrixObject, Future<MatrixBlock>) - Constructor for class org.apache.sysds.runtime.controlprogram.context.MatrixObjectFuture
 
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.
MATRIXPROFILE - org.apache.sysds.common.Builtins
 
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
 
MatrixReaderMapping(String, MatrixBlock) - Constructor for class org.apache.sysds.runtime.iogen.ReaderMapping.MatrixReaderMapping
 
MatrixReaderRowIrregular(CustomProperties) - Constructor for class org.apache.sysds.runtime.iogen.MatrixGenerateReader.MatrixReaderRowIrregular
 
MatrixReaderRowRegularColIrregular(CustomProperties) - Constructor for class org.apache.sysds.runtime.iogen.MatrixGenerateReader.MatrixReaderRowRegularColIrregular
 
MatrixReaderRowRegularColRegular(CustomProperties) - Constructor for class org.apache.sysds.runtime.iogen.MatrixGenerateReader.MatrixReaderRowRegularColRegular
 
MatrixReshape - org.apache.sysds.runtime.instructions.gpu.GPUInstruction.GPUINSTRUCTION_TYPE
 
MatrixReshape - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
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
 
MatrixSketch - Interface in org.apache.sysds.runtime.matrix.data.sketch
 
MatrixSketchFactory - Class in org.apache.sysds.runtime.matrix.data.sketch
 
MatrixSketchFactory() - Constructor for class org.apache.sysds.runtime.matrix.data.sketch.MatrixSketchFactory
 
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 - Static variable in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
max - Variable in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
 
max() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDAggregateUtils
 
MAX - org.apache.sysds.common.Builtins
 
MAX - org.apache.sysds.common.Types.AggOp
 
MAX - org.apache.sysds.common.Types.OpOp2
 
MAX - org.apache.sysds.common.Types.OpOpN
 
MAX - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
MAX - org.apache.sysds.runtime.codegen.SpoofCellwise.AggOp
 
MAX - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
MAX - org.apache.sysds.runtime.matrix.data.LibMatrixDNN.PoolingType
 
MAX - org.apache.sysds.runtime.matrix.operators.CMOperator.AggregateOperationTypes
 
MAX_ALLOC - Static variable in class org.apache.sysds.runtime.data.DenseBlockLDRB
 
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_PARALLELIZE - org.apache.sysds.lops.compile.linearization.ILinearize.DagLinearization
 
MAX_PARALLELIZE_ORDER - Static variable in class org.apache.sysds.hops.OptimizerUtils
Heuristic-based instruction ordering to maximize inter-operator parallelism.
MAX_POOL - org.apache.sysds.common.Builtins
 
MAX_POOL - org.apache.sysds.common.Types.OpOpDnn
 
MAX_POOL_BACKWARD - org.apache.sysds.common.Builtins
 
MAX_POOL_BACKWARD - org.apache.sysds.common.Types.OpOpDnn
 
MAX_PREFIX - Static variable in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
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 interface 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
 
maxColGroupCoCode - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
The maximum number of columns CoCoded allowed
maxGram - Variable in class org.apache.sysds.runtime.transform.tokenize.builder.TokenizerBuilderNgram
 
MAXINDEX - org.apache.sysds.common.Types.AggOp
 
MAXINDEX - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
maxSampleSize - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
The maximum size of the sample extracted.
mb - Variable in class org.apache.sysds.runtime.compress.io.CompressedWriteBlock
 
MCC - org.apache.sysds.common.Builtins
 
MCSR - org.apache.sysds.runtime.data.SparseBlock.Type
 
mdat - Variable in class org.apache.sysds.runtime.codegen.SpoofOperator.SideInput
 
mean - Variable in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
 
mean() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
mean() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Wrapper method for reduceall-mean of a matrix.
Mean - Class in org.apache.sysds.runtime.functionobjects
 
MEAN - org.apache.sysds.common.Builtins
 
MEAN - org.apache.sysds.common.Types.AggOp
 
MEAN - org.apache.sysds.runtime.matrix.operators.CMOperator.AggregateOperationTypes
 
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
 
MEDIAN - org.apache.sysds.common.Builtins
 
MEDIAN - org.apache.sysds.common.Types.OpOp1
 
MEDIAN - org.apache.sysds.common.Types.OpOp2
 
MEDIAN - org.apache.sysds.lops.PickByCount.OperationTypes
 
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
 
Memorizer - Class in org.apache.sysds.runtime.compress.cocode
 
Memorizer(AComEst) - Constructor for class org.apache.sysds.runtime.compress.cocode.Memorizer
 
MEMORY - org.apache.sysds.runtime.compress.cost.CostEstimatorFactory.CostType
 
MEMORY_MANAGER - Static variable in class org.apache.sysds.conf.DMLConfig
 
MEMORY_MANAGER - Static variable in class org.apache.sysds.hops.OptimizerUtils
Indicate the current memory manager in effect
MEMORY_USAGE - org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator.TestMeasure
 
MemoryCostEstimator - Class in org.apache.sysds.runtime.compress.cost
 
MemoryCostEstimator() - Constructor for class org.apache.sysds.runtime.compress.cost.MemoryCostEstimator
 
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
 
memoryUsage - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.UtilizationModel
 
MemoTable - Class in org.apache.sysds.hops.fedplanner
Memoization of federated execution alternatives.
MemoTable - Class in org.apache.sysds.hops
Memoization Table (hop id, worst-case matrix characteristics).
MemoTable() - Constructor for class org.apache.sysds.hops.fedplanner.MemoTable
 
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(FunctionDictionary<T>) - Method in class org.apache.sysds.parser.FunctionDictionary
 
merge(TensorBlock, boolean) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
merge(FrameBlock) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
merge(FrameBlock, boolean) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
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.compress.CompressedMatrixBlock
 
merge(MatrixBlock, boolean, boolean, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
merge(T, boolean) - Method in interface org.apache.sysds.runtime.controlprogram.caching.CacheBlock
Merge the given block into the current block.
MERGE - org.apache.sysds.runtime.compress.colgroup.insertionsort.InsertionSorterFactory.SORT_TYPE
 
mergeable() - Method in class org.apache.sysds.parser.StatementBlock
 
mergeAt(ColumnEncoder) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
Merges another encoder, of a compatible type, in after a certain position.
mergeAt(ColumnEncoder) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
mergeAt(ColumnEncoder) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
mergeAt(ColumnEncoder) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
mergeAt(ColumnEncoder) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderFeatureHash
 
mergeAt(ColumnEncoder) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderPassThrough
 
mergeAt(ColumnEncoder) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
mergeAt(ColumnEncoder) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderUDF
 
mergeAt(EncoderOmit, 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.MultiColumnEncoder
 
mergeAt(LegacyEncoder, int, int) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
 
mergeAt(LegacyEncoder, int, int) - Method in class org.apache.sysds.runtime.transform.encode.LegacyEncoder
Merges another encoder, of a compatible type, in after a certain position.
mergeBinary(PrivacyConstraint, PrivacyConstraint) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
Merges the input privacy constraints using the core propagation with NonAggregate operator type.
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
 
mergeNnzCounts(int[], int[]) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
 
mergeReplace(MultiColumnEncoder) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
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 interface org.apache.sysds.runtime.frame.data.lib.FrameUtil
 
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.
MergeSort - Class in org.apache.sysds.runtime.compress.colgroup.insertionsort
 
MergeSort(int, int, IntArrayList[]) - Constructor for class org.apache.sysds.runtime.compress.colgroup.insertionsort.MergeSort
 
MergeSort(int, int, IntArrayList[], int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.insertionsort.MergeSort
 
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() - Method in class org.apache.sysds.parser.WhileStatement
 
mergeStatementBlocks(List<StatementBlock>) - Static method in class org.apache.sysds.parser.StatementBlock
 
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 - Variable in class org.apache.sysds.runtime.io.InputOutputInfo
 
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 - 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
 
MetaDataAll - Class in org.apache.sysds.runtime.meta
 
MetaDataAll() - Constructor for class org.apache.sysds.runtime.meta.MetaDataAll
 
MetaDataAll(BufferedReader) - Constructor for class org.apache.sysds.runtime.meta.MetaDataAll
 
MetaDataAll(String) - Constructor for class org.apache.sysds.runtime.meta.MetaDataAll
 
MetaDataAll(String, boolean, boolean) - Constructor for class org.apache.sysds.runtime.meta.MetaDataAll
 
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
 
MetaDataUtils - Class in org.apache.sysds.runtime.meta
 
MetaDataUtils() - Constructor for class org.apache.sysds.runtime.meta.MetaDataUtils
 
MethodOfMomentsFunction(int, double) - Constructor for class org.apache.sysds.runtime.compress.estim.sample.HassAndStokes.MethodOfMomentsFunction
 
MICE - org.apache.sysds.common.Builtins
 
MICE_APPLY - org.apache.sysds.common.Builtins
 
mightHaveEmptyBlocks() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
 
mightHaveEmptyBlocks() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
 
min - Variable in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
 
min() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
min() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Wrapper method for reduceall-min of a matrix.
MIN - org.apache.sysds.common.Builtins
 
MIN - org.apache.sysds.common.Types.AggOp
 
MIN - org.apache.sysds.common.Types.OpOp2
 
MIN - org.apache.sysds.common.Types.OpOpN
 
MIN - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
MIN - org.apache.sysds.runtime.codegen.SpoofCellwise.AggOp
 
MIN - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
MIN - org.apache.sysds.runtime.matrix.operators.CMOperator.AggregateOperationTypes
 
MIN_INTERMEDIATE - org.apache.sysds.lops.compile.linearization.ILinearize.DagLinearization
 
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.ColumnEncoderBin
 
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
 
minGram - Variable in class org.apache.sysds.runtime.transform.tokenize.builder.TokenizerBuilderNgram
 
minimumCompressionRatio - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
The minimum compression ratio to achieve.
minimumRecommendedSparkVersion() - Method in class org.apache.sysds.api.mlcontext.ProjectInfo
Obtain the minimum recommended Spark version from the manifest.
minimumSampleSize - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
The minimum size of the sample extracted.
minimumSize - Static variable in interface 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.
MININDEX - org.apache.sysds.common.Types.AggOp
 
MININDEX - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
minNonZero() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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
 
MINUS - org.apache.sysds.common.Types.OpOp2
 
MINUS - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
MINUS - org.apache.sysds.lops.WeightedSigmoid.WSigmoidType
 
MINUS - org.apache.sysds.parser.Expression.BinaryOp
 
MINUS - Static variable in class org.apache.sysds.runtime.util.DMVUtils
 
MINUS_MULT - org.apache.sysds.common.Types.OpOp3
 
MINUS_MULT - org.apache.sysds.hops.codegen.cplan.CNodeTernary.TernaryType
 
MINUS_NZ - org.apache.sysds.common.Types.OpOp2
 
MINUS_NZ - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
MINUS_RIGHT - org.apache.sysds.common.Types.OpOp1
 
MINUS1_MULT - org.apache.sysds.common.Types.OpOp1
 
MINUS1_MULT - org.apache.sysds.common.Types.OpOp2
 
MINUS1_MULT - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
Minus1Multiply - Class in org.apache.sysds.runtime.functionobjects
 
MinusMult - org.apache.sysds.lops.Lop.Type
 
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.
MIXED - org.apache.sysds.hops.fedplanner.FTypes.FPartitioning
 
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(JavaSparkContext) - Constructor for class org.apache.sysds.api.mlcontext.MLContext
Create an MLContext based on a JavaSparkContext 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(SparkSession) - Constructor for class org.apache.sysds.api.mlcontext.MLContext
Create an MLContext based on a SparkSession for interaction with SystemDS on Spark.
MLCONTEXT - org.apache.sysds.conf.CompilerConfig.ConfigType
 
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) - 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.
MLContextException(String, Throwable) - Constructor for exception org.apache.sysds.api.mlcontext.MLContextException
 
MLContextException(Throwable) - Constructor for exception org.apache.sysds.api.mlcontext.MLContextException
 
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(Script) - Constructor for class org.apache.sysds.api.mlcontext.MLResults
 
MLResults(LocalVariableMap) - Constructor for class org.apache.sysds.api.mlcontext.MLResults
 
MM - org.apache.sysds.common.Types.FileFormat
 
MM - org.apache.sysds.hops.AggBinaryOp.MMultMethod
 
MM - org.apache.sysds.hops.estim.SparsityEstimator.OpCode
 
mmChain(CompressedMatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, MapMultChain.ChainType, int) - Static method in interface org.apache.sysds.runtime.compress.lib.CLALibMMChain
 
MMChain - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
MMChain - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
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 - org.apache.sysds.lops.Lop.Type
 
MMCJ(Lop, Lop, Types.DataType, Types.ValueType, boolean, AggBinaryOp.SparkAggType, Types.ExecType) - Constructor for class org.apache.sysds.lops.MMCJ
 
MMCJ(Lop, Lop, Types.DataType, Types.ValueType, MMCJ.MMCJType, Types.ExecType) - Constructor for class org.apache.sysds.lops.MMCJ
Constructor to perform a cross product operation.
MMCJ.MMCJType - Enum in org.apache.sysds.lops
 
MMDicts(ADictionary, ADictionary, IColIndex, IColIndex, MatrixBlock) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.DictLibMatrixMult
Matrix Multiply the two dictionaries, note that the left side is considered transposed but not allocated transposed making the multiplication a: t(left) %*% right
MMDictsWithScaling(ADictionary, ADictionary, IColIndex, IColIndex, MatrixBlock, int[]) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.DictLibMatrixMult
Matrix multiply with scaling (left side transposed)
MMFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
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(MMNode, MMNode, SparsityEstimator.OpCode) - 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, 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
 
MMNode(MatrixBlock) - Constructor for class org.apache.sysds.hops.estim.MMNode
 
MMRJ - Class in org.apache.sysds.lops
Lop to perform cross product operation
MMRJ - org.apache.sysds.lops.Lop.Type
 
MMRJ(Lop, Lop, Types.DataType, Types.ValueType, Types.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 - org.apache.sysds.lops.Lop.Type
 
MMTSJ - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
MMTSJ - org.apache.sysds.runtime.instructions.gpu.GPUInstruction.GPUINSTRUCTION_TYPE
 
MMTSJ(Lop, Types.DataType, Types.ValueType, Types.ExecType, MMTSJ.MMTSJType) - Constructor for class org.apache.sysds.lops.MMTSJ
 
MMTSJ(Lop, Types.DataType, Types.ValueType, Types.ExecType, MMTSJ.MMTSJType, boolean) - Constructor for class org.apache.sysds.lops.MMTSJ
 
MMTSJ(Lop, Types.DataType, Types.ValueType, Types.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
 
mmWithDictionary(MatrixBlock, MatrixBlock, MatrixBlock, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.APreAgg
 
MMZip - Class in org.apache.sysds.lops
Lop to perform zip matrix multiplication
MMZip(Lop, Lop, Types.DataType, Types.ValueType, boolean, Types.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
 
MODIFY - org.apache.sysds.runtime.controlprogram.caching.CacheableData.CacheStatus
 
modifyFedRanges(long, int) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
Take the federated mapping and sets one dimension of all federated ranges to the specified value.
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.
MODULUS - org.apache.sysds.common.Types.OpOp2
 
MODULUS - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
MODULUS - org.apache.sysds.parser.Expression.BinaryOp
 
MOMENT - org.apache.sysds.common.Builtins
 
MOMENT - org.apache.sysds.common.Types.OpOp2
 
MOMENT - org.apache.sysds.common.Types.OpOp3
 
MONITORING_ADDRESS - Static variable in class org.apache.sysds.api.DMLScript
 
monitoringHostIdKey - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.CoordinatorModel
 
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
MoveVariable - org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
 
MR_BINARY_M - org.apache.sysds.hops.BinaryOp.MMBinaryMethod
 
MR_BINARY_OUTER_M - org.apache.sysds.hops.BinaryOp.MMBinaryMethod
 
MR_BINARY_OUTER_R - org.apache.sysds.hops.BinaryOp.MMBinaryMethod
 
MR_BINARY_R - org.apache.sysds.hops.BinaryOp.MMBinaryMethod
 
MR_BINARY_UAGG_CHAIN - org.apache.sysds.hops.BinaryOp.MMBinaryMethod
 
MR_FRAMEWORK_NAME - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
 
MR_GAPPEND - org.apache.sysds.hops.BinaryOp.AppendMethod
 
MR_JOBTRACKER_ADDRESS - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.stat.InfrastructureAnalyzer
 
MR_MAPPEND - org.apache.sysds.hops.BinaryOp.AppendMethod
 
MR_RAPPEND - org.apache.sysds.hops.BinaryOp.AppendMethod
 
MSVM - org.apache.sysds.common.Builtins
 
MSVMPREDICT - org.apache.sysds.common.Builtins
 
mtdExists() - Method in class org.apache.sysds.runtime.meta.MetaDataAll
 
MULT - org.apache.sysds.common.Types.OpOp2
 
MULT - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
MULT - org.apache.sysds.hops.estim.SparsityEstimator.OpCode
 
MULT - org.apache.sysds.lops.WeightedUnaryMM.WUMMType
 
MULT - org.apache.sysds.parser.Expression.BinaryOp
 
MULT_BASIC - org.apache.sysds.lops.WeightedDivMM.WDivMMType
 
MULT_LEFT - org.apache.sysds.lops.WeightedDivMM.WDivMMType
 
MULT_MINUS_4_LEFT - org.apache.sysds.lops.WeightedDivMM.WDivMMType
 
MULT_MINUS_4_RIGHT - org.apache.sysds.lops.WeightedDivMM.WDivMMType
 
MULT_MINUS_LEFT - org.apache.sysds.lops.WeightedDivMM.WDivMMType
 
MULT_MINUS_RIGHT - org.apache.sysds.lops.WeightedDivMM.WDivMMType
 
MULT_RIGHT - org.apache.sysds.lops.WeightedDivMM.WDivMMType
 
MULT2 - org.apache.sysds.common.Types.OpOp1
 
MULT2 - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
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_BLOCK - org.apache.sysds.hops.AggBinaryOp.SparkAggType
 
MULTI_CONSUMER - org.apache.sysds.hops.codegen.opt.InterestingPoint.DecisionType
 
MULTI_RETURN - org.apache.sysds.common.Types.ReturnType
 
MULTI_SCALAR - org.apache.sysds.hops.codegen.SpoofFusedOp.SpoofOutputDimsType
 
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
 
MULTI_THREADED_STAGES - Static variable in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
MultiAssignmentStatement - Class in org.apache.sysds.parser
 
MultiAssignmentStatement(ArrayList<DataIdentifier>, Expression) - Constructor for class org.apache.sysds.parser.MultiAssignmentStatement
 
MultiColBitmap - Class in org.apache.sysds.runtime.compress.bitmap
Uncompressed representation of one or more columns in bitmap format.
MultiColumnEncoder - Class in org.apache.sysds.runtime.transform.encode
 
MultiColumnEncoder() - Constructor for class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
MultiColumnEncoder(List<ColumnEncoderComposite>) - Constructor for class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
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
 
MULTILOGREG - org.apache.sysds.common.Builtins
 
MULTILOGREGPREDICT - org.apache.sysds.common.Builtins
 
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
 
multiplyScalar(double, double[], int, int, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Multiply the v value with the dictionary entry at dictIdx and add it to the ret matrix at the columns specified in the int array.
multiplyScalar(double, double[], int, int, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
multiplyScalar(double, double[], int, int, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
multiplyScalar(double, double[], int, int, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
multiplyScalar(double, double[], int, int, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
MULTIRETURN_BUILTIN - org.apache.sysds.hops.FunctionOp.FunctionType
 
MultiReturnBuiltin - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
MultiReturnBuiltin - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
MultiReturnBuiltinCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
multiReturnOperations(MatrixBlock, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibCommonsMath
 
multiReturnOperations(MatrixBlock, String, int, int, double) - Static method in class org.apache.sysds.runtime.matrix.data.LibCommonsMath
 
multiReturnOperations(MatrixBlock, String, int, long) - Static method in class org.apache.sysds.runtime.matrix.data.LibCommonsMath
 
MultiReturnParameterizedBuiltin - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
MultiReturnParameterizedBuiltin - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
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
 
MultiThreadedOperator - Class in org.apache.sysds.runtime.matrix.operators
 
MultiThreadedOperator() - Constructor for class org.apache.sysds.runtime.matrix.operators.MultiThreadedOperator
 
MultiThreadedOperator(boolean) - Constructor for class org.apache.sysds.runtime.matrix.operators.MultiThreadedOperator
 
MVImpute - org.apache.sysds.runtime.transform.encode.ColumnEncoder.EncoderType
 

N

N - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
 
NA_LOCF - org.apache.sysds.common.Builtins
 
NAIVE - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PTaskPartitioner
 
NAIVEBAYES - org.apache.sysds.common.Builtins
 
NAIVEBAYESPREDICT - org.apache.sysds.common.Builtins
 
name - Variable in class org.apache.sysds.parser.dml.DmlParser.BuiltinFunctionExpressionContext
 
name - Variable in class org.apache.sysds.parser.dml.DmlParser.ExternalFunctionDefExpressionContext
 
name - Variable in class org.apache.sysds.parser.dml.DmlParser.FunctionCallAssignmentStatementContext
 
name - Variable in class org.apache.sysds.parser.dml.DmlParser.FunctionCallMultiAssignmentStatementContext
 
name - Variable in class org.apache.sysds.parser.dml.DmlParser.IndexedExpressionContext
 
name - Variable in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
 
name - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.CoordinatorModel
 
name - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.WorkerModel
 
NAME_VALUE_SEPARATOR - Static variable in class org.apache.sysds.lops.Lop
 
namespace - Variable in class org.apache.sysds.parser.dml.DmlParser.ImportStatementContext
 
namespace - Variable in class org.apache.sysds.parser.dml.DmlSyntacticValidator.ConvertedDMLSyntax
 
namespaceResolutionOp() - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
Obtain the namespace separator (:: for DML that is used to specify a namespace and a function in that namespace.
namespaces - Variable in class org.apache.sysds.parser.dml.StatementInfo
 
NaN - org.apache.sysds.parser.BuiltinConstant
 
Nary - Class in org.apache.sysds.lops
Lop to perform an operation on a variable number of operands.
Nary - org.apache.sysds.lops.Lop.Type
 
Nary(Types.OpOpN, Types.DataType, Types.ValueType, Lop[], Types.ExecType) - Constructor for class org.apache.sysds.lops.Nary
 
NaryOp - Class in org.apache.sysds.hops
The NaryOp Hop allows for a variable number of operands.
NaryOp(String, Types.DataType, Types.ValueType, Types.OpOpN, Hop...) - Constructor for class org.apache.sysds.hops.NaryOp
NaryOp constructor.
naryOperations(Operator, MatrixBlock[], ScalarObject[], MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
NATIVE_BLAS - Static variable in class org.apache.sysds.conf.DMLConfig
 
NATIVE_BLAS_DIR - Static variable in class org.apache.sysds.conf.DMLConfig
 
native_contexts - Static variable in class org.apache.sysds.hops.codegen.SpoofCompiler
 
NativeHEHelper - Class in org.apache.sysds.runtime.controlprogram.paramserv
 
NativeHEHelper() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.NativeHEHelper
 
NativeHelper - Class in org.apache.sysds.utils
This class helps in loading native library.
NativeHelper() - Constructor for class org.apache.sysds.utils.NativeHelper
 
NativeHelper.NativeBlasState - Enum in org.apache.sysds.utils
 
NativeStatistics - Class in org.apache.sysds.utils.stats
 
NativeStatistics() - Constructor for class org.apache.sysds.utils.stats.NativeStatistics
 
NBATCHES - org.apache.sysds.parser.Statement.PSFrequency
 
NBINS_PREFIX - Static variable in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
NCOL - org.apache.sysds.common.Builtins
 
NCOL - org.apache.sysds.common.Types.OpOp1
 
NCOL - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
NCOL - org.apache.sysds.runtime.instructions.cp.AggregateUnaryCPInstruction.AUType
 
nCopies(int, Types.ValueType) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
NEQZERO - org.apache.sysds.hops.estim.SparsityEstimator.OpCode
 
NetworkTrafficCounter - Class in org.apache.sysds.runtime.controlprogram.paramserv
 
NetworkTrafficCounter(BiConsumer<Long, Long>) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.NetworkTrafficCounter
 
newInstance(int) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheBlockFactory
 
newInstance(CacheBlock<?>) - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheBlockFactory
 
NEWLINE - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
 
newMatrixObject(MatrixBlock) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
 
newMatrixObject(MatrixBlock, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
 
newSize() - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
next - Variable in class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap.DIListEntry
 
next - Variable in class org.apache.sysds.runtime.util.LongLongDoubleHashMap.ADoubleEntry
 
next() - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IIterate
Get next index
next() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AIterator
Increment the pointers such that the both index and dataIndex is incremented to the next entry.
next() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffsetIterator
Increment the pointer and return the new offset gained
next() - Method in class org.apache.sysds.runtime.frame.data.columns.Array.ArrayIterator
 
next() - Method in class org.apache.sysds.runtime.frame.data.iterators.ObjectRowIterator
 
next() - Method in class org.apache.sysds.runtime.frame.data.iterators.StringRowIterator
 
next() - Method in class org.apache.sysds.runtime.instructions.spark.data.LazyIterableIterator
 
next() - Method in class org.apache.sysds.runtime.matrix.data.BinaryBlockToTextCellConverter
 
next() - Method in interface org.apache.sysds.runtime.matrix.data.Converter
 
next() - Method in class org.apache.sysds.runtime.matrix.data.TextToBinaryCellConverter
 
next(int, int) - Method in class org.apache.sysds.runtime.codegen.SpoofOperator.SideInputSparseCell
 
next(MatrixIndexes, MatrixBlock) - Method in class org.apache.sysds.runtime.util.BinaryBlockRecordReader
 
nextDouble() - Method in class org.apache.sysds.runtime.iogen.FastStringTokenizer
 
nextDouble() - Method in class org.apache.sysds.runtime.util.FastStringTokenizer
 
nextDouble() - Method in class org.apache.sysds.runtime.util.NormalPRNGenerator
 
nextDouble() - Method in class org.apache.sysds.runtime.util.PoissonPRNGenerator
 
nextDouble() - Method in class org.apache.sysds.runtime.util.PRNGenerator
 
nextDouble() - Method in class org.apache.sysds.runtime.util.UniformPRNGenerator
 
nextInt() - Method in class org.apache.sysds.runtime.iogen.FastStringTokenizer
 
nextInt() - Method in class org.apache.sysds.runtime.util.FastStringTokenizer
 
nextIntPow2(int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
nextKeyMap(BufferedReader, HashMap<Integer, HashMap<Long, Long>>, int, int) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.util.StagingFileUtils
 
nextLineageCachedEntry - Variable in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
Head of the linked list of GPUObjects that point to the same lineage cached GPU pointer
nextLong() - Method in class org.apache.sysds.runtime.iogen.FastStringTokenizer
 
nextLong() - Method in class org.apache.sysds.runtime.util.FastStringTokenizer
 
nextRow() - Method in class org.apache.sysds.runtime.compress.readers.ReaderColumnSelection
Gets the next row, null when no more rows.
nextSizedKeyMap(BufferedReader, HashMap<Integer, HashMap<Long, Long>>, int, int) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.util.StagingFileUtils
 
nextToken() - Method in class org.apache.sysds.runtime.iogen.FastStringTokenizer
 
nextToken() - Method in class org.apache.sysds.runtime.util.FastStringTokenizer
Returns the next token in the string as a String.
ngramType - Variable in class org.apache.sysds.runtime.transform.tokenize.builder.TokenizerBuilderNgram
 
NIL_MESSAGE - Static variable in class org.apache.sysds.runtime.io.hdf5.H5Constants
 
nnz - Variable in class org.apache.sysds.runtime.instructions.gpu.context.CSRPointer
Number of non zeroes
nnzKnown() - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
 
nnzKnown() - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
 
nnzKnown() - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
 
NO_AGG - org.apache.sysds.lops.MMCJ.MMCJType
 
NO_AGG - org.apache.sysds.runtime.codegen.SpoofCellwise.CellType
 
NO_AGG - org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
 
NO_AGG_B1 - org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
 
NO_AGG_CONST - org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
 
NO_MORE_TASKS - Static variable in class org.apache.sysds.runtime.controlprogram.parfor.LocalTaskQueue
 
NO_RESET - org.apache.sysds.hops.recompile.Recompiler.ResetType
 
NO_RETURN - org.apache.sysds.common.Types.ReturnType
 
noFedRuntimeConversion - Variable in class org.apache.sysds.api.DMLOptions
 
noFedRuntimeConversion - Static variable in class org.apache.sysds.runtime.instructions.fed.FEDInstructionUtils
 
NOHOST - Static variable in class org.apache.sysds.runtime.controlprogram.federated.FederatedLookupTable
 
NonAggregate - org.apache.sysds.runtime.privacy.propagation.OperatorType
 
None - org.apache.sysds.runtime.privacy.PrivacyConstraint.PrivacyLevel
 
NONE - org.apache.sysds.api.mlcontext.MLContext.ExplainLevel
Explain disabled
NONE - org.apache.sysds.common.Types.CorrectionLocationType
 
NONE - org.apache.sysds.hops.AggBinaryOp.SparkAggType
 
NONE - org.apache.sysds.hops.codegen.SpoofCompiler.PlanCachePolicy
 
NONE - org.apache.sysds.hops.fedplanner.FTypes.FederatedPlanner
 
NONE - org.apache.sysds.hops.fedplanner.FTypes.FPartitioning
 
NONE - org.apache.sysds.hops.fedplanner.FTypes.FReplication
 
NONE - org.apache.sysds.lops.LeftIndex.LixCacheType
 
NONE - org.apache.sysds.lops.MapMultChain.ChainType
 
NONE - org.apache.sysds.lops.MMTSJ.MMTSJType
 
NONE - org.apache.sysds.lops.WeightedSquaredLoss.WeightsType
 
NONE - org.apache.sysds.parser.Statement.PSCheckpointing
 
NONE - org.apache.sysds.parser.Statement.PSRuntimeBalancing
 
NONE - org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator.ExcludeType
 
NONE - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PDataPartitioner
 
NONE - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PDataPartitionFormat
 
NONE - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.POptMode
 
NONE - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FederatedOutput
 
NONE - org.apache.sysds.runtime.lineage.LineageCacheConfig.ReuseCacheType
 
NONE - org.apache.sysds.utils.Explain.ExplainType
 
NONE - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
 
NOOP - org.apache.sysds.runtime.controlprogram.federated.FederatedRequest.RequestType
 
noOrderBuild() - Method in class org.apache.sysds.runtime.io.hdf5.H5BufferBuilder
 
NORMAL - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ProbabilityDistributionCode
 
NORMAL - org.apache.sysds.runtime.matrix.data.RandomMatrixGenerator.PDF
 
NORMALIZE - org.apache.sysds.common.Builtins
 
NORMALIZEAPPLY - org.apache.sysds.common.Builtins
 
NormalPRNGenerator - Class in org.apache.sysds.runtime.util
Class that can generate a stream of random numbers from standard normal distribution N(0,1).
NormalPRNGenerator() - Constructor for class org.apache.sysds.runtime.util.NormalPRNGenerator
 
Not - Class in org.apache.sysds.runtime.functionobjects
 
NOT - org.apache.sysds.common.Types.OpOp1
 
NOT - org.apache.sysds.parser.Expression.BooleanOp
 
NOT_ATTEMPTED_LOADING_NATIVE_BLAS - org.apache.sysds.utils.NativeHelper.NativeBlasState
 
NOT_FOUND_MSG - Static variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.Constants
 
NOT_SUPPORTED_PB - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
 
NOT_SUPPORTED_SPARK_INSTRUCTION - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
 
NOT_SUPPORTED_SPARK_PARFOR - Static variable in class org.apache.sysds.runtime.util.ProgramConverter
 
NOTEQUAL - org.apache.sysds.common.Types.OpOp2
 
NOTEQUAL - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
NOTEQUAL - org.apache.sysds.parser.Expression.RelationalOp
 
NotEquals - Class in org.apache.sysds.runtime.functionobjects
 
notFound(String) - Static method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.Response
 
NOTVISITED - org.apache.sysds.lops.Lop.VisitStatus
 
NROW - org.apache.sysds.common.Builtins
 
NROW - org.apache.sysds.common.Types.OpOp1
 
NROW - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
NROW - org.apache.sysds.runtime.instructions.cp.AggregateUnaryCPInstruction.AUType
 
NULL - Static variable in class org.apache.sysds.runtime.io.hdf5.H5Constants
 
num_features - Variable in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierHash
 
NUM_ITERATIONS - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.ParamType
 
NUM_MRJOBS - org.apache.sysds.hops.cost.CostEstimationWrapper.CostType
 
numBlocks() - Method in class org.apache.sysds.runtime.data.DenseBlock
Get the number of allocated blocks.
numBlocks() - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
 
numBlocks() - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
 
numBlocks() - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
 
numBlocks() - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
 
numBlocks() - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
 
numBlocks() - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
 
numBlocks() - Method in class org.apache.sysds.runtime.data.DenseBlockLString
 
numChkpts - Variable in class org.apache.sysds.utils.Explain.ExplainCounts
 
numCols() - Method in class org.apache.sysds.runtime.data.DenseBlock
Get the number of columns / first dimension
numCPInst - Variable in class org.apache.sysds.utils.Explain.ExplainCounts
 
numDims() - Method in class org.apache.sysds.runtime.data.DenseBlock
Get the number of dimensions.
numJobs - Variable in class org.apache.sysds.utils.Explain.ExplainCounts
 
numPartitions() - Method in class org.apache.sysds.runtime.instructions.spark.data.BlockPartitioner
 
numPathsInPBs(ArrayList<ProgramBlock>, ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageDedupUtils
 
numReblocks - Variable in class org.apache.sysds.utils.Explain.ExplainCounts
 
numRows() - Method in class org.apache.sysds.runtime.data.DenseBlock
Get the number of rows.
numRows() - Method in class org.apache.sysds.runtime.data.SparseBlock
Get the number of rows in the sparse block.
numRows() - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
numRows() - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
numRows() - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
 
numThreads - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
 
NVCC - org.apache.sysds.hops.codegen.SpoofCompiler.CompilerType
 
NVRTC - org.apache.sysds.hops.codegen.SpoofCompiler.CompilerType
 

O

O0_LOCAL_STATIC - org.apache.sysds.hops.OptimizerUtils.OptimizationLevel
 
O1_LOCAL_MEMORY_MIN - org.apache.sysds.hops.OptimizerUtils.OptimizationLevel
 
O2_LOCAL_MEMORY_DEFAULT - org.apache.sysds.hops.OptimizerUtils.OptimizationLevel
 
O3_LOCAL_RESOURCE_TIME_MEMORY - org.apache.sysds.hops.OptimizerUtils.OptimizationLevel
 
O4_GLOBAL_TIME_MEMORY - org.apache.sysds.hops.OptimizerUtils.OptimizationLevel
 
O5_DEBUG_MODE - org.apache.sysds.hops.OptimizerUtils.OptimizationLevel
 
OBJECT_MODIFICATION_TIME_MESSAGE - Static variable in class org.apache.sysds.runtime.io.hdf5.H5Constants
 
objectArrayCost(long) - Static method in class org.apache.sysds.utils.MemoryEstimates
Get the worst case memory usage for an array of objects.
ObjectRowIterator - Class in org.apache.sysds.runtime.frame.data.iterators
 
objectToBoolean(Types.ValueType, Object) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
objectToCharacter(Types.ValueType, Object) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
objectToDouble(Types.ValueType, Object) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
objectToDoubleSafe(Types.ValueType, Object) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
objectToFloat(Types.ValueType, Object) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
objectToInteger(Types.ValueType, Object) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
objectToLong(Types.ValueType, Object) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
objectToObject(Types.ValueType, Object) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
objectToObject(Types.ValueType, Object, boolean) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
objectToString(Object) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
objectToString(Object, boolean) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
Convert object to string
obtainProcessID() - Static method in class org.apache.sysds.runtime.controlprogram.parfor.util.IDHandler
 
of(MatrixObject, LineageItem) - Static method in class org.apache.sysds.runtime.controlprogram.federated.MatrixLineagePair
 
offset - Variable in class org.apache.sysds.hops.codegen.opt.ReachabilityGraph.SubProblem
 
OffsetByte - Class in org.apache.sysds.runtime.compress.colgroup.offset
 
OffsetChar - Class in org.apache.sysds.runtime.compress.colgroup.offset
 
OffsetColumnIndex - Class in org.apache.sysds.runtime.functionobjects
 
OffsetEmpty - Class in org.apache.sysds.runtime.compress.colgroup.offset
 
OffsetEmpty() - Constructor for class org.apache.sysds.runtime.compress.colgroup.offset.OffsetEmpty
 
OffsetFactory - Class in org.apache.sysds.runtime.compress.colgroup.offset
 
OffsetFactory.OFF_TYPE - Enum in org.apache.sysds.runtime.compress.colgroup.offset
The specific underlying types of offsets.
OffsetFactory.OFF_TYPE_SPECIALIZATIONS - Enum in org.apache.sysds.runtime.compress.colgroup.offset
Specialized types of underlying offsets.
OffsetSingle - Class in org.apache.sysds.runtime.compress.colgroup.offset
 
OffsetSingle(int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.offset.OffsetSingle
 
offsetSlice - Variable in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset.OffsetSliceInfo
 
OffsetTwo - Class in org.apache.sysds.runtime.compress.colgroup.offset
 
OffsetTwo(int, int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.offset.OffsetTwo
 
ok(String) - Static method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.Response
 
OLE - org.apache.sysds.runtime.compress.colgroup.AColGroup.CompressionType
 
omit(String[], TfUtils) - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
 
Omit - org.apache.sysds.runtime.transform.encode.ColumnEncoder.EncoderType
 
OMIT - org.apache.sysds.runtime.transform.TfUtils.TfMethod
 
onDiag() - Method in class org.apache.sysds.runtime.matrix.data.IJV
 
one() - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
Convenience method to get a pointer to value '1.0' on device.
op - Variable in class org.apache.sysds.parser.dml.DmlParser.AccumulatorAssignmentStatementContext
 
op - Variable in class org.apache.sysds.parser.dml.DmlParser.AddSubExpressionContext
 
op - Variable in class org.apache.sysds.parser.dml.DmlParser.AssignmentStatementContext
 
op - Variable in class org.apache.sysds.parser.dml.DmlParser.BooleanAndExpressionContext
 
op - Variable in class org.apache.sysds.parser.dml.DmlParser.BooleanNotExpressionContext
 
op - Variable in class org.apache.sysds.parser.dml.DmlParser.BooleanOrExpressionContext
 
op - Variable in class org.apache.sysds.parser.dml.DmlParser.IfdefAssignmentStatementContext
 
op - Variable in class org.apache.sysds.parser.dml.DmlParser.MatrixMulExpressionContext
 
op - Variable in class org.apache.sysds.parser.dml.DmlParser.ModIntDivExpressionContext
 
op - Variable in class org.apache.sysds.parser.dml.DmlParser.MultDivExpressionContext
 
op - Variable in class org.apache.sysds.parser.dml.DmlParser.PowerExpressionContext
 
op - Variable in class org.apache.sysds.parser.dml.DmlParser.RelationalExpressionContext
 
op - Variable in class org.apache.sysds.parser.dml.DmlParser.UnaryExpressionContext
 
op - Variable in class org.apache.sysds.runtime.matrix.data.sketch.CountDistinctSketch
 
Op - Class in org.apache.sysds.runtime.compress.workload
 
Op(Hop) - Constructor for class org.apache.sysds.runtime.compress.workload.Op
 
OPCODE - Static variable in class org.apache.sysds.hops.FunctionOp
 
OPCODE - Static variable in class org.apache.sysds.lops.Append
 
OPCODE - Static variable in class org.apache.sysds.lops.AppendG
 
OPCODE - Static variable in class org.apache.sysds.lops.AppendGAlignedSP
 
OPCODE - Static variable in class org.apache.sysds.lops.AppendM
 
OPCODE - Static variable in class org.apache.sysds.lops.AppendR
 
OPCODE - Static variable in class org.apache.sysds.lops.BinaryUAggChain
 
OPCODE - Static variable in class org.apache.sysds.lops.Compression
 
OPCODE - Static variable in class org.apache.sysds.lops.CSVReBlock
 
OPCODE - Static variable in class org.apache.sysds.lops.DeCompression
 
OPCODE - Static variable in class org.apache.sysds.lops.GroupedAggregateM
 
OPCODE - Static variable in class org.apache.sysds.lops.LeftIndex
 
OPCODE - Static variable in class org.apache.sysds.lops.Local
 
OPCODE - Static variable in class org.apache.sysds.lops.MapMult
 
OPCODE - Static variable in class org.apache.sysds.lops.MapMultChain
 
OPCODE - Static variable in class org.apache.sysds.lops.PickByCount
 
OPCODE - Static variable in class org.apache.sysds.lops.PMapMult
 
OPCODE - Static variable in class org.apache.sysds.lops.PMMJ
 
OPCODE - Static variable in class org.apache.sysds.lops.ReBlock
 
OPCODE - Static variable in class org.apache.sysds.lops.RightIndex
 
OPCODE - Static variable in class org.apache.sysds.lops.SortKeys
 
OPCODE - Static variable in class org.apache.sysds.lops.UAggOuterChain
 
OPCODE - Static variable in class org.apache.sysds.lops.WeightedCrossEntropy
 
OPCODE - Static variable in class org.apache.sysds.lops.WeightedCrossEntropyR
 
OPCODE - Static variable in class org.apache.sysds.lops.WeightedDivMM
 
OPCODE - Static variable in class org.apache.sysds.lops.WeightedDivMMR
 
OPCODE - Static variable in class org.apache.sysds.lops.WeightedSigmoid
 
OPCODE - Static variable in class org.apache.sysds.lops.WeightedSigmoidR
 
OPCODE - Static variable in class org.apache.sysds.lops.WeightedSquaredLoss
 
OPCODE - Static variable in class org.apache.sysds.lops.WeightedSquaredLossR
 
OPCODE - Static variable in class org.apache.sysds.lops.WeightedUnaryMM
 
OPCODE - Static variable in class org.apache.sysds.lops.WeightedUnaryMMR
 
OPCODE_C - Static variable in class org.apache.sysds.lops.TernaryAggregate
 
OPCODE_CP - Static variable in class org.apache.sysds.lops.MapMultChain
 
OPCODE_CP - Static variable in class org.apache.sysds.lops.WeightedCrossEntropy
 
OPCODE_CP - Static variable in class org.apache.sysds.lops.WeightedDivMM
 
OPCODE_CP - Static variable in class org.apache.sysds.lops.WeightedSigmoid
 
OPCODE_CP - Static variable in class org.apache.sysds.lops.WeightedSquaredLoss
 
OPCODE_CP - Static variable in class org.apache.sysds.lops.WeightedUnaryMM
 
OPCODE_RC - Static variable in class org.apache.sysds.lops.TernaryAggregate
 
open(InputStream) - Method in class org.apache.sysds.runtime.io.BinaryBlockSerialization.MatrixBlockDeserializer
 
open(OutputStream) - Method in class org.apache.sysds.runtime.io.BinaryBlockSerialization.MatrixBlockSerializer
 
open(Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateBase
Indicates if this template can be opened at the given hop, where hop represents bottom (first operation on the inputs) of the fused operator.
open(Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateCell
 
open(Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateMultiAgg
 
open(Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateOuterProduct
 
open(Hop) - Method in class org.apache.sysds.hops.codegen.template.TemplateRow
 
OPEN_INVALID - org.apache.sysds.hops.codegen.template.TemplateBase.CloseType
 
OPEN_VALID - org.apache.sysds.hops.codegen.template.TemplateBase.CloseType
 
openKeyMap(String) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.util.StagingFileUtils
 
OPERAND_DELIM - Static variable in class org.apache.sysds.runtime.instructions.Instruction
 
OPERAND_DELIMITOR - Static variable in class org.apache.sysds.lops.Lop
 
operation - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.EventStageModel
 
operation - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.HeavyHitterModel
 
OperationsOnMatrixValues - Class in org.apache.sysds.runtime.matrix.data
 
OperationsOnMatrixValues() - Constructor for class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
 
Operator - Class in org.apache.sysds.runtime.matrix.operators
 
Operator() - Constructor for class org.apache.sysds.runtime.matrix.operators.Operator
 
Operator(boolean) - Constructor for class org.apache.sysds.runtime.matrix.operators.Operator
 
OperatorOrderingUtils - Class in org.apache.sysds.lops
 
OperatorOrderingUtils() - Constructor for class org.apache.sysds.lops.OperatorOrderingUtils
 
OperatorType - Enum in org.apache.sysds.runtime.privacy.propagation
 
OpMetadata - Class in org.apache.sysds.runtime.compress.workload
 
OpMetadata(Hop, Hop) - Constructor for class org.apache.sysds.runtime.compress.workload.OpMetadata
 
OpNormal - Class in org.apache.sysds.runtime.compress.workload
 
OpNormal(Hop, boolean) - Constructor for class org.apache.sysds.runtime.compress.workload.OpNormal
 
OpSided - Class in org.apache.sysds.runtime.compress.workload
 
OpSided(Hop, boolean, boolean, boolean, boolean) - Constructor for class org.apache.sysds.runtime.compress.workload.OpSided
 
OPSTRING - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.ParamType
 
OPSTRING - Static variable in class org.apache.sysds.hops.IndexingOp
 
OPSTRING - Static variable in class org.apache.sysds.hops.LeftIndexingOp
 
OPT_LEVEL - org.apache.sysds.conf.CompilerConfig.ConfigType
 
OPT_LOG - Static variable in class org.apache.sysds.parser.ParForStatementBlock
 
OPT_MODE - Static variable in class org.apache.sysds.parser.ParForStatementBlock
 
OPT_NUMEPLANS - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
OPT_NUMTPLANS - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
OPT_OPTIMIZER - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
OPT_T - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
OPTIMIZATION_LEVEL - Static variable in class org.apache.sysds.conf.DMLConfig
 
OptimizationWrapper - Class in org.apache.sysds.runtime.controlprogram.parfor.opt
Wrapper to ParFOR cost estimation and optimizer.
OptimizationWrapper() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizationWrapper
 
optimize(ArrayList<Hop>, boolean) - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
Main interface of sum-product optimizer, statement block dag.
optimize(Hop, boolean) - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
Main interface of sum-product optimizer, predicate dag.
optimize(ParForStatementBlock, ParForProgramBlock, OptTree, CostEstimator, ExecutionContext) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.Optimizer
Optimize
optimize(ParForStatementBlock, ParForProgramBlock, OptTree, CostEstimator, ExecutionContext) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerConstrained
Main optimization procedure.
optimize(ParForStatementBlock, ParForProgramBlock, OptTree, CostEstimator, ExecutionContext) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerRuleBased
Main optimization procedure.
optimize(ParForProgramBlock.POptMode, ParForStatementBlock, ParForProgramBlock, ExecutionContext, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizationWrapper
Called once per top-level parfor (during runtime, on parfor execute) in order to optimize the specific parfor program block.
OPTIMIZE - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
Optimizer - Class in org.apache.sysds.runtime.controlprogram.parfor.opt
Generic optimizer super class that defines the interface of all implemented optimizers.
Optimizer.CostModelType - Enum in org.apache.sysds.runtime.controlprogram.parfor.opt
 
Optimizer.PlanInputType - Enum in org.apache.sysds.runtime.controlprogram.parfor.opt
 
OptimizerConstrained - Class in org.apache.sysds.runtime.controlprogram.parfor.opt
Rule-Based ParFor Optimizer (time: O(n)): Applied rule-based rewrites: - see base class.
OptimizerConstrained() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerConstrained
 
OptimizerHeuristic - Class in org.apache.sysds.runtime.controlprogram.parfor.opt
Heuristic ParFor Optimizer: This optimizer extends the rule-based optimizer by a time-based cost estimate for execution type decisions.
OptimizerHeuristic() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerHeuristic
 
OptimizerRuleBased - Class in org.apache.sysds.runtime.controlprogram.parfor.opt
Rule-Based ParFor Optimizer (time: O(n)): Applied rule-based rewrites - 1) rewrite set data partitioner (incl.
OptimizerRuleBased() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizerRuleBased
 
OptimizerUtils - Class in org.apache.sysds.hops
 
OptimizerUtils() - Constructor for class org.apache.sysds.hops.OptimizerUtils
 
OptimizerUtils.MemoryManager - Enum in org.apache.sysds.hops
Memory managers (static partitioned, unified)
OptimizerUtils.OptimizationLevel - Enum in org.apache.sysds.hops
Optimization Types for Compilation O0 STATIC - Decisions for scheduling operations on CP/MR are based on predefined set of rules, which check if the dimensions are below a fixed/static threshold (OLD Method of choosing between CP and MR).
OPTIONAL - org.apache.sysds.runtime.frame.data.columns.ArrayFactory.FrameArrayType
 
OptionalArray<T> - Class in org.apache.sysds.runtime.frame.data.columns
 
OptionalArray(Array<T>, boolean) - Constructor for class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
OptionalArray(Array<T>, ABooleanArray) - Constructor for class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
OptionalArray(T[]) - Constructor for class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
options - Variable in class org.apache.sysds.api.DMLOptions
 
OptNode - Class in org.apache.sysds.runtime.controlprogram.parfor.opt
Internal representation of a plan alternative for program blocks and instructions in order to enable efficient and simple recursive enumeration and plan changes.
OptNode(OptNode.NodeType) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
 
OptNode(OptNode.NodeType, OptNode.ExecType) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode
 
OptNode.ExecType - Enum in org.apache.sysds.runtime.controlprogram.parfor.opt
 
OptNode.NodeType - Enum in org.apache.sysds.runtime.controlprogram.parfor.opt
 
OptNode.ParamType - Enum in org.apache.sysds.runtime.controlprogram.parfor.opt
 
OptNodeStatistics - Class in org.apache.sysds.runtime.controlprogram.parfor.opt
TODO extend to right as well (see PerfTestTool, currently only trained with regard to left) TODO integrate mem and exec time for reuse?
OptNodeStatistics() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNodeStatistics
Default constructor, sets all internal statistics to their respective default values.
OptNodeStatistics(long, long, long, long, double, CostEstimator.DataFormat) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.OptNodeStatistics
 
OptTree - Class in org.apache.sysds.runtime.controlprogram.parfor.opt
Represents a complete plan of a top-level parfor.
OptTree(int, double, Optimizer.PlanInputType, OptNode, OptTreePlanMappingAbstract, OptTreePlanMappingRuntime) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTree
 
OptTree(int, double, OptNode) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTree
 
OptTreeConverter - Class in org.apache.sysds.runtime.controlprogram.parfor.opt
Converter for creating an internal plan representation for a given runtime program and to modify/create the runtime program according to the optimized plan.
OptTreeConverter() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
 
OptTreePlanChecker - Class in org.apache.sysds.runtime.controlprogram.parfor.opt
 
OptTreePlanChecker() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanChecker
 
OptTreePlanMapping - Class in org.apache.sysds.runtime.controlprogram.parfor.opt
Helper class for mapping nodes of the internal plan representation to statement blocks and hops / function call statements of a given DML program.
OptTreePlanMapping() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMapping
 
OptTreePlanMappingAbstract - Class in org.apache.sysds.runtime.controlprogram.parfor.opt
 
OptTreePlanMappingAbstract() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingAbstract
 
OptTreePlanMappingRuntime - Class in org.apache.sysds.runtime.controlprogram.parfor.opt
 
OptTreePlanMappingRuntime() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingRuntime
 
or(EstimatorBitsetMM.BitsetMatrix) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix1
 
or(EstimatorBitsetMM.BitsetMatrix) - Method in class org.apache.sysds.hops.estim.EstimatorBitsetMM.BitsetMatrix2
 
Or - Class in org.apache.sysds.runtime.functionobjects
 
OR - org.apache.sysds.common.Types.OpOp2
 
OR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
ORDER - org.apache.sysds.common.Builtins
 
org.apache.sysds.api - package org.apache.sysds.api
 
org.apache.sysds.api.jmlc - package org.apache.sysds.api.jmlc
 
org.apache.sysds.api.mlcontext - package org.apache.sysds.api.mlcontext
 
org.apache.sysds.common - package org.apache.sysds.common
 
org.apache.sysds.conf - package org.apache.sysds.conf
 
org.apache.sysds.hops - package org.apache.sysds.hops
 
org.apache.sysds.hops.codegen - package org.apache.sysds.hops.codegen
 
org.apache.sysds.hops.codegen.cplan - package org.apache.sysds.hops.codegen.cplan
 
org.apache.sysds.hops.codegen.cplan.cuda - package org.apache.sysds.hops.codegen.cplan.cuda
 
org.apache.sysds.hops.codegen.cplan.java - package org.apache.sysds.hops.codegen.cplan.java
 
org.apache.sysds.hops.codegen.opt - package org.apache.sysds.hops.codegen.opt
 
org.apache.sysds.hops.codegen.template - package org.apache.sysds.hops.codegen.template
 
org.apache.sysds.hops.cost - package org.apache.sysds.hops.cost
 
org.apache.sysds.hops.estim - package org.apache.sysds.hops.estim
 
org.apache.sysds.hops.fedplanner - package org.apache.sysds.hops.fedplanner
 
org.apache.sysds.hops.ipa - package org.apache.sysds.hops.ipa
 
org.apache.sysds.hops.recompile - package org.apache.sysds.hops.recompile
 
org.apache.sysds.hops.rewrite - package org.apache.sysds.hops.rewrite
 
org.apache.sysds.lops - package org.apache.sysds.lops
 
org.apache.sysds.lops.compile - package org.apache.sysds.lops.compile
 
org.apache.sysds.lops.compile.linearization - package org.apache.sysds.lops.compile.linearization
 
org.apache.sysds.lops.rewrite - package org.apache.sysds.lops.rewrite
 
org.apache.sysds.parser - package org.apache.sysds.parser
 
org.apache.sysds.parser.dml - package org.apache.sysds.parser.dml
 
org.apache.sysds.runtime - package org.apache.sysds.runtime
 
org.apache.sysds.runtime.codegen - package org.apache.sysds.runtime.codegen
 
org.apache.sysds.runtime.compress - package org.apache.sysds.runtime.compress
 
org.apache.sysds.runtime.compress.bitmap - package org.apache.sysds.runtime.compress.bitmap
 
org.apache.sysds.runtime.compress.cocode - package org.apache.sysds.runtime.compress.cocode
 
org.apache.sysds.runtime.compress.colgroup - package org.apache.sysds.runtime.compress.colgroup
 
org.apache.sysds.runtime.compress.colgroup.dictionary - package org.apache.sysds.runtime.compress.colgroup.dictionary
 
org.apache.sysds.runtime.compress.colgroup.functional - package org.apache.sysds.runtime.compress.colgroup.functional
 
org.apache.sysds.runtime.compress.colgroup.indexes - package org.apache.sysds.runtime.compress.colgroup.indexes
 
org.apache.sysds.runtime.compress.colgroup.insertionsort - package org.apache.sysds.runtime.compress.colgroup.insertionsort
 
org.apache.sysds.runtime.compress.colgroup.mapping - package org.apache.sysds.runtime.compress.colgroup.mapping
 
org.apache.sysds.runtime.compress.colgroup.offset - package org.apache.sysds.runtime.compress.colgroup.offset
 
org.apache.sysds.runtime.compress.colgroup.scheme - package org.apache.sysds.runtime.compress.colgroup.scheme
 
org.apache.sysds.runtime.compress.cost - package org.apache.sysds.runtime.compress.cost
 
org.apache.sysds.runtime.compress.estim - package org.apache.sysds.runtime.compress.estim
 
org.apache.sysds.runtime.compress.estim.encoding - package org.apache.sysds.runtime.compress.estim.encoding
 
org.apache.sysds.runtime.compress.estim.sample - package org.apache.sysds.runtime.compress.estim.sample
 
org.apache.sysds.runtime.compress.io - package org.apache.sysds.runtime.compress.io
 
org.apache.sysds.runtime.compress.lib - package org.apache.sysds.runtime.compress.lib
 
org.apache.sysds.runtime.compress.readers - package org.apache.sysds.runtime.compress.readers
 
org.apache.sysds.runtime.compress.utils - package org.apache.sysds.runtime.compress.utils
 
org.apache.sysds.runtime.compress.workload - package org.apache.sysds.runtime.compress.workload
 
org.apache.sysds.runtime.controlprogram - package org.apache.sysds.runtime.controlprogram
 
org.apache.sysds.runtime.controlprogram.caching - package org.apache.sysds.runtime.controlprogram.caching
 
org.apache.sysds.runtime.controlprogram.context - package org.apache.sysds.runtime.controlprogram.context
 
org.apache.sysds.runtime.controlprogram.federated - package org.apache.sysds.runtime.controlprogram.federated
 
org.apache.sysds.runtime.controlprogram.federated.monitoring - package org.apache.sysds.runtime.controlprogram.federated.monitoring
 
org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers - package org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers
 
org.apache.sysds.runtime.controlprogram.federated.monitoring.models - package org.apache.sysds.runtime.controlprogram.federated.monitoring.models
 
org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories - package org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories
 
org.apache.sysds.runtime.controlprogram.federated.monitoring.services - package org.apache.sysds.runtime.controlprogram.federated.monitoring.services
 
org.apache.sysds.runtime.controlprogram.paramserv - package org.apache.sysds.runtime.controlprogram.paramserv
 
org.apache.sysds.runtime.controlprogram.paramserv.dp - package org.apache.sysds.runtime.controlprogram.paramserv.dp
 
org.apache.sysds.runtime.controlprogram.paramserv.homomorphicEncryption - package org.apache.sysds.runtime.controlprogram.paramserv.homomorphicEncryption
 
org.apache.sysds.runtime.controlprogram.paramserv.rpc - package org.apache.sysds.runtime.controlprogram.paramserv.rpc
 
org.apache.sysds.runtime.controlprogram.parfor - package org.apache.sysds.runtime.controlprogram.parfor
 
org.apache.sysds.runtime.controlprogram.parfor.opt - package org.apache.sysds.runtime.controlprogram.parfor.opt
 
org.apache.sysds.runtime.controlprogram.parfor.stat - package org.apache.sysds.runtime.controlprogram.parfor.stat
 
org.apache.sysds.runtime.controlprogram.parfor.util - package org.apache.sysds.runtime.controlprogram.parfor.util
 
org.apache.sysds.runtime.data - package org.apache.sysds.runtime.data
 
org.apache.sysds.runtime.frame.data - package org.apache.sysds.runtime.frame.data
 
org.apache.sysds.runtime.frame.data.columns - package org.apache.sysds.runtime.frame.data.columns
 
org.apache.sysds.runtime.frame.data.compress - package org.apache.sysds.runtime.frame.data.compress
 
org.apache.sysds.runtime.frame.data.iterators - package org.apache.sysds.runtime.frame.data.iterators
 
org.apache.sysds.runtime.frame.data.lib - package org.apache.sysds.runtime.frame.data.lib
 
org.apache.sysds.runtime.functionobjects - package org.apache.sysds.runtime.functionobjects
 
org.apache.sysds.runtime.instructions - package org.apache.sysds.runtime.instructions
 
org.apache.sysds.runtime.instructions.cp - package org.apache.sysds.runtime.instructions.cp
 
org.apache.sysds.runtime.instructions.cpfile - package org.apache.sysds.runtime.instructions.cpfile
 
org.apache.sysds.runtime.instructions.fed - package org.apache.sysds.runtime.instructions.fed
 
org.apache.sysds.runtime.instructions.gpu - package org.apache.sysds.runtime.instructions.gpu
 
org.apache.sysds.runtime.instructions.gpu.context - package org.apache.sysds.runtime.instructions.gpu.context
 
org.apache.sysds.runtime.instructions.spark - package org.apache.sysds.runtime.instructions.spark
 
org.apache.sysds.runtime.instructions.spark.data - package org.apache.sysds.runtime.instructions.spark.data
 
org.apache.sysds.runtime.instructions.spark.functions - package org.apache.sysds.runtime.instructions.spark.functions
 
org.apache.sysds.runtime.instructions.spark.utils - package org.apache.sysds.runtime.instructions.spark.utils
 
org.apache.sysds.runtime.io - package org.apache.sysds.runtime.io
 
org.apache.sysds.runtime.io.hdf5 - package org.apache.sysds.runtime.io.hdf5
 
org.apache.sysds.runtime.io.hdf5.message - package org.apache.sysds.runtime.io.hdf5.message
 
org.apache.sysds.runtime.iogen - package org.apache.sysds.runtime.iogen
 
org.apache.sysds.runtime.lineage - package org.apache.sysds.runtime.lineage
 
org.apache.sysds.runtime.matrix.data - package org.apache.sysds.runtime.matrix.data
 
org.apache.sysds.runtime.matrix.data.sketch - package org.apache.sysds.runtime.matrix.data.sketch
 
org.apache.sysds.runtime.matrix.data.sketch.countdistinct - package org.apache.sysds.runtime.matrix.data.sketch.countdistinct
 
org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox - package org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox
 
org.apache.sysds.runtime.matrix.operators - package org.apache.sysds.runtime.matrix.operators
 
org.apache.sysds.runtime.meta - package org.apache.sysds.runtime.meta
 
org.apache.sysds.runtime.privacy - package org.apache.sysds.runtime.privacy
 
org.apache.sysds.runtime.privacy.finegrained - package org.apache.sysds.runtime.privacy.finegrained
 
org.apache.sysds.runtime.privacy.propagation - package org.apache.sysds.runtime.privacy.propagation
 
org.apache.sysds.runtime.transform - package org.apache.sysds.runtime.transform
 
org.apache.sysds.runtime.transform.decode - package org.apache.sysds.runtime.transform.decode
 
org.apache.sysds.runtime.transform.encode - package org.apache.sysds.runtime.transform.encode
 
org.apache.sysds.runtime.transform.meta - package org.apache.sysds.runtime.transform.meta
 
org.apache.sysds.runtime.transform.tokenize - package org.apache.sysds.runtime.transform.tokenize
 
org.apache.sysds.runtime.transform.tokenize.applier - package org.apache.sysds.runtime.transform.tokenize.applier
 
org.apache.sysds.runtime.transform.tokenize.builder - package org.apache.sysds.runtime.transform.tokenize.builder
 
org.apache.sysds.runtime.util - package org.apache.sysds.runtime.util
 
org.apache.sysds.utils - package org.apache.sysds.utils
 
org.apache.sysds.utils.stats - package org.apache.sysds.utils.stats
 
originalCost - Variable in class org.apache.sysds.runtime.compress.CompressionStatistics
Cost calculated by the cost estimator on input
originalSize - Variable in class org.apache.sysds.runtime.compress.CompressionStatistics
Size of the original input
ORLocalScheme - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
Data partitioner Overlap_Reshuffle: for each worker, use a new permutation multiply P %*% X, where P is constructed for example with P=table(seq(1,nrow(X),sample(nrow(X), nrow(X))))
ORLocalScheme() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.ORLocalScheme
 
ORSparkScheme - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
Spark data partitioner Overlap_Reshuffle:
OTHER - org.apache.sysds.hops.fedplanner.FTypes.FType
 
OTHER - Static variable in class org.apache.sysds.runtime.util.DMVUtils
 
otherParams - Variable in class org.apache.sysds.parser.dml.DmlParser.ExternalFunctionDefExpressionContext
 
out(String) - Method in class org.apache.sysds.api.mlcontext.Script
Register an output variable.
out(String...) - Method in class org.apache.sysds.api.mlcontext.Script
Register output variables.
out(List<String>) - Method in class org.apache.sysds.api.mlcontext.Script
Register output variables.
out(Seq<String>) - Method in class org.apache.sysds.api.mlcontext.Script
Register output variables.
OUTER - org.apache.sysds.common.Builtins
 
OUTER - org.apache.sysds.hops.codegen.template.TemplateBase.TemplateType
 
OUTER_VECTOR_VECTOR - org.apache.sysds.runtime.matrix.data.LibMatrixBincell.BinaryAccessType
 
outerProduct(double[], double[], double[], int, int) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupUtils
 
outerProduct(double[], double[], IColIndex, double[], int, int, int) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupUtils
 
outerProduct(double[], SparseBlock, IColIndex, double[], int, int, int) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupUtils
 
OuterVectorBinaryOpFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
 
OuterVectorBinaryOpFunction(BinaryOperator, PartitionedBroadcast<MatrixBlock>) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.OuterVectorBinaryOpFunction
 
outlier(FrameBlock, List<Integer>, double, double, int) - Static method in class org.apache.sysds.utils.DataAugmentation
This function modifies the given, preprocessed frame block to add outliers to some of the numeric data of the frame, adding or several times the standard deviation, and marking them with the label outlier.
OUTLIER - org.apache.sysds.common.Builtins
 
OUTLIER_ARIMA - org.apache.sysds.common.Builtins
 
OUTLIER_IQR - org.apache.sysds.common.Builtins
 
OUTLIER_IQR_APPLY - org.apache.sysds.common.Builtins
 
OUTLIER_SD - org.apache.sysds.common.Builtins
 
OUTLIER_SD_APPLY - org.apache.sysds.common.Builtins
 
output - Variable in class org.apache.sysds.runtime.instructions.cp.ComputationCPInstruction
 
output - Variable in class org.apache.sysds.runtime.instructions.fed.ComputationFEDInstruction
 
output - Variable in class org.apache.sysds.runtime.instructions.spark.ComputationSPInstruction
 
output - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
 
outputFormatClass - Variable in class org.apache.sysds.runtime.io.InputOutputInfo
 
OutputParameters - Class in org.apache.sysds.lops
class to maintain output parameters for a lop.
OutputParameters() - Constructor for class org.apache.sysds.lops.OutputParameters
 
outputParams - Variable in class org.apache.sysds.parser.dml.DmlParser.ExternalFunctionDefExpressionContext
 
outputParams - Variable in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
 
OutputStatement - Class in org.apache.sysds.parser
 
OutputStatement(ParserRuleContext, DataIdentifier, Expression.DataOp, String) - Constructor for class org.apache.sysds.parser.OutputStatement
 
OutputStatement(DataIdentifier, Expression.DataOp, ParseInfo) - Constructor for class org.apache.sysds.parser.OutputStatement
 
OUTPUTSTATEMENT - Static variable in class org.apache.sysds.parser.Statement
 
OVERLAP - org.apache.sysds.hops.fedplanner.FTypes.FReplication
 
OVERLAP_RESHUFFLE - org.apache.sysds.parser.Statement.PSScheme
 
overlaps(DataRange) - Method in class org.apache.sysds.runtime.privacy.finegrained.DataRange
Returns true if this data range overlaps with the given data range.

P

P - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
 
packDataForTransfer(ExecutionContext, ArrayList<MatrixObject>, ArrayList<ScalarObject>, MatrixObject, int, int, long, boolean, Pointer[]) - Method in interface org.apache.sysds.runtime.codegen.SpoofCUDAOperator
 
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
 
PADDING_STRING - Static variable in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplier
 
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_DDC_THRESHOLD - Static variable in class org.apache.sysds.runtime.compress.CompressionSettings
Parallelization threshold for DDC compression
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_MATRIX_OPERATIONS - org.apache.sysds.conf.CompilerConfig.ConfigType
 
PARALLEL_CP_READ_BINARYFORMATS - org.apache.sysds.conf.CompilerConfig.ConfigType
 
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_READ_TEXTFORMATS - org.apache.sysds.conf.CompilerConfig.ConfigType
 
PARALLEL_CP_WRITE_BINARYFORMATS - org.apache.sysds.conf.CompilerConfig.ConfigType
 
PARALLEL_CP_WRITE_PARALLELISM_MULTIPLIER - Static variable in class org.apache.sysds.hops.OptimizerUtils
 
PARALLEL_CP_WRITE_TEXTFORMATS - org.apache.sysds.conf.CompilerConfig.ConfigType
 
PARALLEL_ENCODE - Static variable in class org.apache.sysds.conf.DMLConfig
 
PARALLEL_ENCODE_APPLY_BLOCKS - Static variable in class org.apache.sysds.conf.DMLConfig
 
PARALLEL_ENCODE_BUILD_BLOCKS - Static variable in class org.apache.sysds.conf.DMLConfig
 
PARALLEL_ENCODE_NUM_THREADS - Static variable in class org.apache.sysds.conf.DMLConfig
 
PARALLEL_ENCODE_STAGED - Static variable in class org.apache.sysds.conf.DMLConfig
 
PARALLEL_LOCAL_OR_REMOTE_PARFOR - org.apache.sysds.conf.CompilerConfig.ConfigType
 
PARALLEL_TOKENIZE - Static variable in class org.apache.sysds.conf.DMLConfig
 
PARALLEL_TOKENIZE_NUM_BLOCKS - Static variable in class org.apache.sysds.conf.DMLConfig
 
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 - Class in org.apache.sysds.runtime.functionobjects
Function object for builtin function that takes a list of name=value parameters.
ParameterizedBuiltin - org.apache.sysds.lops.Lop.Type
 
ParameterizedBuiltin - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
ParameterizedBuiltin - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
ParameterizedBuiltin - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
ParameterizedBuiltin(HashMap<String, Lop>, Types.ParamBuiltinOp, Types.DataType, Types.ValueType, Types.ExecType) - Constructor for class org.apache.sysds.lops.ParameterizedBuiltin
 
ParameterizedBuiltin(HashMap<String, Lop>, Types.ParamBuiltinOp, Types.DataType, Types.ValueType, Types.ExecType, boolean) - Constructor for class org.apache.sysds.lops.ParameterizedBuiltin
 
ParameterizedBuiltin(HashMap<String, Lop>, Types.ParamBuiltinOp, Types.DataType, Types.ValueType, Types.ExecType, int) - Constructor for class org.apache.sysds.lops.ParameterizedBuiltin
 
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.RDDContainsFunction - Class in org.apache.sysds.runtime.instructions.spark
 
ParameterizedBuiltinSPInstruction.RDDFrameReplaceFunction - 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.RDDTokenizeFunction - 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 - Variable 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.BuiltinFunctionExpressionContext
 
parameterizedExpression() - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionCallAssignmentStatementContext
 
parameterizedExpression() - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionCallMultiAssignmentStatementContext
 
parameterizedExpression() - Method in class org.apache.sysds.parser.dml.DmlParser
 
parameterizedExpression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.BuiltinFunctionExpressionContext
 
parameterizedExpression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionCallAssignmentStatementContext
 
parameterizedExpression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.FunctionCallMultiAssignmentStatementContext
 
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
 
PARAMSERV - org.apache.sysds.common.Builtins
 
PARAMSERV - org.apache.sysds.common.Types.ParamBuiltinOp
 
PARAMSERV - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ParameterizedBuiltinCode
 
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
 
ParamServStatistics - Class in org.apache.sysds.utils.stats
 
ParamServStatistics() - Constructor for class org.apache.sysds.utils.stats.ParamServStatistics
 
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 - org.apache.sysds.runtime.compress.workload.AWTreeNode.WTNodeType
 
PARFOR - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.NodeType
 
PARFOR_COUNTER_GROUP_NAME - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
PARFOR_DATAPARTITIONER - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARFOR_DATAPARTITIONS_FNAME - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
PARFOR_EXECMODE - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARFOR_FNAME_PREFIX - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
PARFOR_INIT_DATA_T - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARFOR_INIT_PARWRK_T - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARFOR_INIT_TASKS_T - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARFOR_JITCOMPILE - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARFOR_JVMGC_COUNT - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARFOR_JVMGC_TIME - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
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
 
PARFOR_NUMITERS - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARFOR_NUMTASKS - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARFOR_NUMTHREADS - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARFOR_TASKPARTITIONER - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARFOR_TASKSIZE - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARFOR_WAIT_EXEC_T - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARFOR_WAIT_RESULTS_T - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
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(int, Program, String, HashMap<String, String>, ArrayList<ParForStatementBlock.ResultVar>) - Constructor for class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
ParForProgramBlock constructor.
ParForProgramBlock(Program, String, HashMap<String, String>, ArrayList<ParForStatementBlock.ResultVar>) - Constructor for class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
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
 
ParForStatistics - Class in org.apache.sysds.utils.stats
 
ParForStatistics() - Constructor for class org.apache.sysds.utils.stats.ParForStatistics
 
parse(Reader) - Static method in class org.apache.sysds.utils.JSONHelper
 
parse(String) - Static method in class org.apache.sysds.runtime.io.FileFormatPropertiesMM
 
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
 
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
 
parseAggregateUnaryRowIndexOperator(String, int, int) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
 
parseAndReturnPrivacyConstraint(JSONObject) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
Parses the privacy constraint of the given metadata object or returns null if no privacy constraint is set in the metadata.
parseAndSetPrivacyConstraint(CacheableData<?>) - Method in class org.apache.sysds.runtime.meta.MetaDataAll
 
parseAndSetPrivacyConstraint(Data, JSONObject) - Static method in class org.apache.sysds.runtime.privacy.propagation.PrivacyPropagator
Parses the privacy constraint of the given metadata object and sets the field of the given Data if the privacy constraint is not null.
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
Parse the given opcode into an aggregate unary operator.
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
 
parseBoolean(String) - Static method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
parseChar(String) - Static method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
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
 
parseDouble(String) - Static method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
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
 
parseFloat(String) - Static method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
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.BroadcastCPInstruction
 
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.DeCompressionCPInstruction
 
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.LocalCPInstruction
 
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.PrefetchCPInstruction
 
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.AggregateTernaryFEDInstruction
 
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.CastFEDInstruction
 
parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.CentralMomentFEDInstruction
 
parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.CovarianceFEDInstruction
 
parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.CtableFEDInstruction
 
parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.CumulativeOffsetFEDInstruction
 
parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.IndexingFEDInstruction
 
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.MMFEDInstruction
 
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.QuantilePickFEDInstruction
 
parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.QuaternaryFEDInstruction
 
parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.ReblockFEDInstruction
 
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.ReshapeFEDInstruction
 
parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.SpoofFEDInstruction
 
parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.TernaryFEDInstruction
 
parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.TsmmFEDInstruction
 
parseInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.fed.UnaryMatrixFEDInstruction
 
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.gpu.SpoofCUDAInstruction
 
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.AggregateUnarySketchSPInstruction
 
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.DeCompressionSPInstruction
 
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.LIBSVMReblockSPInstruction
 
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
 
parseInstruction(String, boolean) - Static method in class org.apache.sysds.runtime.instructions.fed.QuantileSortFEDInstruction
 
parseInstruction(AggregateBinaryCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.AggregateBinaryFEDInstruction
 
parseInstruction(AggregateTernaryCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.AggregateTernaryFEDInstruction
 
parseInstruction(AggregateUnaryCPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.AggregateUnaryFEDInstruction
 
parseInstruction(AppendCPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.AppendFEDInstruction
 
parseInstruction(BinaryCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.BinaryFEDInstruction
 
parseInstruction(BinaryMatrixScalarCPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.BinaryMatrixScalarFEDInstruction
 
parseInstruction(CentralMomentCPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.CentralMomentFEDInstruction
 
parseInstruction(CovarianceCPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.CovarianceFEDInstruction
 
parseInstruction(CtableCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.CtableFEDInstruction
 
parseInstruction(IndexingCPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.IndexingFEDInstruction
 
parseInstruction(MMChainCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.MMChainFEDInstruction
 
parseInstruction(MMTSJCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.TsmmFEDInstruction
 
parseInstruction(MultiReturnParameterizedBuiltinCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction
 
parseInstruction(ParameterizedBuiltinCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.ParameterizedBuiltinFEDInstruction
 
parseInstruction(QuantilePickCPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction
 
parseInstruction(QuantileSortCPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.QuantileSortFEDInstruction
 
parseInstruction(QuaternaryCPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.QuaternaryWCeMMFEDInstruction
 
parseInstruction(QuaternaryCPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.QuaternaryWDivMMFEDInstruction
 
parseInstruction(QuaternaryCPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.QuaternaryWSigmoidFEDInstruction
 
parseInstruction(QuaternaryCPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.QuaternaryWSLossFEDInstruction
 
parseInstruction(QuaternaryCPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.QuaternaryWUMMFEDInstruction
 
parseInstruction(QuaternaryCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.QuaternaryFEDInstruction
 
parseInstruction(ReorgCPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.ReorgFEDInstruction
 
parseInstruction(ReshapeCPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.ReshapeFEDInstruction
 
parseInstruction(SpoofCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.SpoofFEDInstruction
 
parseInstruction(TernaryCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.TernaryFEDInstruction
 
parseInstruction(TernaryFrameScalarCPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.TernaryFrameScalarFEDInstruction
 
parseInstruction(UnaryCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.UnaryFEDInstruction
 
parseInstruction(UnaryMatrixCPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.UnaryMatrixFEDInstruction
 
parseInstruction(VariableCPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.VariableFEDInstruction
 
parseInstruction(AggregateBinarySPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.MMFEDInstruction
 
parseInstruction(AggregateTernarySPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.AggregateTernaryFEDInstruction
 
parseInstruction(AggregateUnarySPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.AggregateUnaryFEDInstruction
 
parseInstruction(AppendSPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.AppendFEDInstruction
 
parseInstruction(BinaryMatrixScalarSPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.BinaryMatrixScalarFEDInstruction
 
parseInstruction(BinarySPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.BinaryFEDInstruction
 
parseInstruction(CastSPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.CastFEDInstruction
 
parseInstruction(CentralMomentSPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.CentralMomentFEDInstruction
 
parseInstruction(CovarianceSPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.CovarianceFEDInstruction
 
parseInstruction(CtableSPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.CtableFEDInstruction
 
parseInstruction(CumulativeOffsetSPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.CumulativeOffsetFEDInstruction
 
parseInstruction(IndexingSPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.IndexingFEDInstruction
 
parseInstruction(MatrixReshapeSPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.ReshapeFEDInstruction
 
parseInstruction(MultiReturnParameterizedBuiltinSPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction
 
parseInstruction(ParameterizedBuiltinSPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.ParameterizedBuiltinFEDInstruction
 
parseInstruction(QuantilePickSPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction
 
parseInstruction(QuantileSortSPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.QuantileSortFEDInstruction
 
parseInstruction(QuaternarySPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.QuaternaryWCeMMFEDInstruction
 
parseInstruction(QuaternarySPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.QuaternaryWDivMMFEDInstruction
 
parseInstruction(QuaternarySPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.QuaternaryWSigmoidFEDInstruction
 
parseInstruction(QuaternarySPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.QuaternaryWSLossFEDInstruction
 
parseInstruction(QuaternarySPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.QuaternaryWUMMFEDInstruction
 
parseInstruction(QuaternarySPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.QuaternaryFEDInstruction
 
parseInstruction(ReblockSPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.ReblockFEDInstruction
 
parseInstruction(ReorgSPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.ReorgFEDInstruction
 
parseInstruction(SpoofSPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.SpoofFEDInstruction
 
parseInstruction(TernaryFrameScalarSPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.TernaryFrameScalarFEDInstruction
 
parseInstruction(TernarySPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.TernaryFEDInstruction
 
parseInstruction(UnaryMatrixSPInstruction) - Static method in class org.apache.sysds.runtime.instructions.fed.UnaryMatrixFEDInstruction
 
parseInstruction(UnarySPInstruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.instructions.fed.UnaryFEDInstruction
 
parseInt(String) - Static method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
ParseIssue(int, int, String, String, CustomErrorListener.ParseIssueType) - Constructor for class org.apache.sysds.parser.dml.CustomErrorListener.ParseIssue
 
parseJsonArrayIDList(JSONArray, String[], int, int, boolean) - Static method in class org.apache.sysds.runtime.transform.meta.TfMetaUtils
 
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
 
parseJsonObjectID(JSONObject, String[], int, int, boolean) - 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
 
parseJsonPlainArrayIDList(JSONArray, String[], int, int, boolean) - 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.
parseLong(String) - Static method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
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.
parseMetaDataFileParameters(String, boolean, HashMap<String, Expression>) - Method in class org.apache.sysds.runtime.meta.MetaDataAll
 
parseMixedInstructions(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionParser
 
parseNComputeAutoDiffFromLineage(MatrixObject, String, ArrayList<String>, ExecutionContext) - Static method in class org.apache.sysds.runtime.util.AutoDiff
 
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
parseSchema(String) - Static method in class org.apache.sysds.runtime.controlprogram.caching.FrameObject
 
parseSingleInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.CPInstructionParser
 
parseSingleInstruction(String) - Static method in class org.apache.sysds.runtime.instructions.FEDInstructionParser
 
parseSingleInstruction(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(CPInstruction.CPType, String) - Static method in class org.apache.sysds.runtime.instructions.CPInstructionParser
 
parseSingleInstruction(FEDInstruction.FEDType, String) - Static method in class org.apache.sysds.runtime.instructions.FEDInstructionParser
 
parseSingleInstruction(GPUInstruction.GPUINSTRUCTION_TYPE, String) - Static method in class org.apache.sysds.runtime.instructions.GPUInstructionParser
 
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
 
parseString(String, Types.ValueType) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
parseTernaryOperator(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
 
parseTernaryOperator(String, int) - 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
 
parseUDFColIDs(JSONObject, String[], int, int) - Static method in class org.apache.sysds.runtime.transform.meta.TfMetaUtils
 
parseUnaryOperator(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
 
parseUnaryOperator(String, int) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
 
parseURL(String) - Static method in class org.apache.sysds.runtime.instructions.fed.InitFEDInstruction
 
parseURLNoFilePath(String) - Static method in class org.apache.sysds.runtime.instructions.fed.InitFEDInstruction
 
PART - org.apache.sysds.hops.fedplanner.FTypes.FType
 
PartialAggregate - Class in org.apache.sysds.lops
Lop to perform a partial aggregation.
PartialAggregate - org.apache.sysds.lops.Lop.Type
 
PartialAggregate(Lop, Types.AggOp, Types.Direction, Types.DataType, Types.ValueType, Types.ExecType, int) - Constructor for class org.apache.sysds.lops.PartialAggregate
 
PartialAggregate(Lop, Types.AggOp, Types.Direction, Types.DataType, Types.ValueType, AggBinaryOp.SparkAggType, Types.ExecType) - Constructor for class org.apache.sysds.lops.PartialAggregate
 
partiallyDecrypt(long, byte[]) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.NativeHEHelper
partially decrypts ciphertexts with the partial private key.
partiallyDecrypt(CiphertextMatrix) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.homomorphicEncryption.SEALClient
partially decrypts ciphertext with the partial private key.
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
 
partition(MatrixObject, MatrixObject, int) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.BalanceToAvgFederatedScheme
 
partition(MatrixObject, MatrixObject, int) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionFederatedScheme
 
partition(MatrixObject, MatrixObject, int) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.KeepDataOnWorkerFederatedScheme
 
partition(MatrixObject, MatrixObject, int) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.ReplicateToMaxFederatedScheme
 
partition(MatrixObject, MatrixObject, int) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.ShuffleFederatedScheme
 
partition(MatrixObject, MatrixObject, int) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.SubsampleToMinFederatedScheme
 
Partition - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
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(int, int, int) - 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
 
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
 
PARWRK_EXEC_T - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARWRK_ITER_T - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARWRK_NUMITERS - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARWRK_NUMTASKS - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARWRK_TASK_T - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PARWRK_TASKSIZE - org.apache.sysds.runtime.controlprogram.parfor.stat.Stat
 
PassThrough - org.apache.sysds.runtime.transform.decode.DecoderFactory.DecoderType
 
PassThrough - org.apache.sysds.runtime.transform.encode.ColumnEncoder.EncoderType
 
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
 
PATTERN - org.apache.sysds.runtime.io.FileFormatPropertiesMM.MMField
 
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
 
PCA - org.apache.sysds.common.Builtins
 
PCAINVERSE - org.apache.sysds.common.Builtins
 
PCATRANSFORM - org.apache.sysds.common.Builtins
 
PCHISQ - org.apache.sysds.common.Builtins
 
peek() - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox.SmallestPriorityQueue
 
peekFirstEntry() - Static method in class org.apache.sysds.runtime.lineage.LineageGPUCacheEviction
 
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, double, boolean, int, 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, 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, MatrixIndexes, MatrixValue, 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(IndexedMatrixValue, IndexRange, int) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
 
performSlice(Pair<Long, FrameBlock>, IndexRange, int) - 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.
performSlice(IndexRange, int, int, int, CacheBlock) - Static method in class org.apache.sysds.runtime.matrix.data.OperationsOnMatrixValues
Slice used in broadcasting matrix blocks for spark, since this slice up a given matrix into blocks.
performSlice(IndexRange, int, int, int, FrameBlock) - 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
 
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.matrix.data.MatrixBlock
 
permutationMatrixMultOperations(MatrixValue, MatrixValue, MatrixValue, int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
permutationMatrixMultOperations(MatrixValue, MatrixValue, MatrixValue, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
PERSISTENTREAD - org.apache.sysds.common.Types.OpOpData
 
PERSISTENTWRITE - org.apache.sysds.common.Types.OpOpData
 
PEXP - org.apache.sysds.common.Builtins
 
PF - org.apache.sysds.common.Builtins
 
pFeatures - Variable in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionLocalScheme.Result
 
pi - org.apache.sysds.parser.BuiltinConstant
 
PickByCount - Class in org.apache.sysds.lops
 
PickByCount(Lop, Lop, Types.DataType, Types.ValueType, PickByCount.OperationTypes, Types.ExecType) - Constructor for class org.apache.sysds.lops.PickByCount
 
PickByCount(Lop, Lop, Types.DataType, Types.ValueType, PickByCount.OperationTypes, Types.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.compress.CompressedMatrixBlock
 
pickValue(double, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
pickValues(MatrixValue, MatrixValue) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
pickValues(MatrixValue, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
PickValues - org.apache.sysds.lops.Lop.Type
 
pin(CacheableData<?>) - Static method in class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
 
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
 
PlaintextMatrix - Class in org.apache.sysds.runtime.instructions.cp
This class abstracts over an encrypted matrix of ciphertexts.
PlaintextMatrix(int[], DataCharacteristics, byte[]) - Constructor for class org.apache.sysds.runtime.instructions.cp.PlaintextMatrix
 
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
 
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
 
PLOGP - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
Plus - Class in org.apache.sysds.runtime.functionobjects
 
PLUS - org.apache.sysds.common.Types.OpOp2
 
PLUS - org.apache.sysds.common.Types.OpOpN
 
PLUS - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
PLUS - org.apache.sysds.hops.estim.SparsityEstimator.OpCode
 
PLUS - org.apache.sysds.parser.Expression.BinaryOp
 
PLUS_MULT - org.apache.sysds.common.Types.OpOp3
 
PLUS_MULT - org.apache.sysds.hops.codegen.cplan.CNodeTernary.TernaryType
 
PlusMult - org.apache.sysds.lops.Lop.Type
 
PlusMultiply - Class in org.apache.sysds.runtime.functionobjects
 
PMAPMM - org.apache.sysds.hops.AggBinaryOp.MMultMethod
 
PMAPMM - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
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
 
PMM - org.apache.sysds.hops.AggBinaryOp.MMultMethod
 
PMM - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
PMMJ - Class in org.apache.sysds.lops
 
PMMJ - org.apache.sysds.lops.Lop.Type
 
PMMJ - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
PMMJ(Lop, Lop, Lop, Types.DataType, Types.ValueType, boolean, boolean, Types.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
 
PNMF - org.apache.sysds.common.Builtins
 
PNORM - org.apache.sysds.common.Builtins
 
POISSON - org.apache.sysds.runtime.matrix.data.RandomMatrixGenerator.PDF
 
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
 
poll() - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox.SmallestPriorityQueue
 
pollFirstEntry() - Static method in class org.apache.sysds.runtime.lineage.LineageGPUCacheEviction
 
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
 
PorterStemmer - Class in org.apache.sysds.runtime.util
Stemmer, implementing the Porter Stemming Algorithm The Stemmer class transforms a word into its root form.
PorterStemmer() - Constructor for class org.apache.sysds.runtime.util.PorterStemmer
 
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) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
 
pos(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.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
 
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[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
 
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, int) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
 
pos(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
 
pos(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
 
pos(int, int) - Method in class org.apache.sysds.runtime.data.DenseBlockString
 
POS_NAN - Static variable in class org.apache.sysds.runtime.lineage.LineageDebugger
 
POS_NEGATIVE_INFINITY - Static variable in class org.apache.sysds.runtime.lineage.LineageDebugger
 
POS_POSITIVE_INFINITY - Static variable in class org.apache.sysds.runtime.lineage.LineageDebugger
 
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
 
POST - org.apache.sysds.lops.WeightedSquaredLoss.WeightsType
 
POST_NZ - org.apache.sysds.lops.WeightedSquaredLoss.WeightsType
 
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.CPInstruction
 
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
Propagate privacy constraints to output variables based on privacy constraint of CPOperand output in instruction which has been set during privacy propagation preprocessing.
postprocessUltraSparseOutput(MatrixObject, DataCharacteristics) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.SparkUtils
 
pow(int, int) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
POW - org.apache.sysds.common.Types.OpOp2
 
POW - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
POW - org.apache.sysds.parser.Expression.BinaryOp
 
POW2 - org.apache.sysds.common.Types.OpOp1
 
POW2 - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
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
 
PPCA - org.apache.sysds.common.Builtins
 
PPRED - org.apache.sysds.common.Builtins
 
PRE - org.apache.sysds.lops.WeightedSquaredLoss.WeightsType
 
PREAD_PREFIX - Static variable in class org.apache.sysds.lops.Data
 
preAggregate(MatrixBlock, double[], int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.APreAgg
Pre aggregate a matrix block into a pre aggregate target (first step of left matrix multiplication)
preAggregateDDC_DDC(AMapToData, ADictionary, Dictionary, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
PreAggregate into dictionary with two sides of DDC.
preAggregateDDC_DDCMultiCol(AMapToData, ADictionary, double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
preAggregateDDC_DDCMultiCol(AMapToData, ADictionary, double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
preAggregateDDC_DDCSingleCol(AMapToData, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
preAggregateDDC_DDCSingleCol(AMapToData, double[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
preAggregateDDC_RLE(int[], char[], ADictionary, Dictionary, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
 
preAggregateDDC_SDCZ(AMapToData, ADictionary, AOffset, Dictionary, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
PreAggregate into SDCZero dictionary from DDC dictionary.
preAggregateDDC_SDCZMultiCol(AMapToData, ADictionary, AOffset, double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
 
preAggregateDDC_SDCZSingleCol(AMapToData, double[], AOffset, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
 
preAggregateDense(MatrixBlock, double[], int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.APreAgg
Pre aggregate a dense matrix block into a pre aggregate target (first step of left matrix multiplication)
preAggregateDense(MatrixBlock, double[], int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
preAggregateDense(MatrixBlock, double[], int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
 
preAggregateDense(MatrixBlock, double[], int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
 
preAggregateDense(MatrixBlock, double[], int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
preAggregateDense(MatrixBlock, double[], int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
preAggregateDense(MatrixBlock, double[], int, int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Pre aggregate a dense matrix m into pre, subject to only including a row segment and column segment.
preAggregateDense(MatrixBlock, double[], int, int, int, int, AOffset) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
PreAggregate a Dense Matrix at index offsets.
preAggregateDenseMap(MatrixBlock, double[], int, int, int, int, int, AMapToData) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
 
preAggregateRLE_DDC(int[], char[], ADictionary, Dictionary, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
 
preAggregateSDCZ_DDC(AMapToData, ADictionary, AOffset, Dictionary, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
PreAggregate into DDC dictionary from SDCZero dictionary.
preAggregateSDCZ_SDCZ(AMapToData, ADictionary, AOffset, AOffset, Dictionary, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
 
preAggregateSparse(SparseBlock, double[], int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.APreAgg
 
preAggregateSparse(SparseBlock, double[], int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
preAggregateSparse(SparseBlock, double[], int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
 
preAggregateSparse(SparseBlock, double[], int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
 
preAggregateSparse(SparseBlock, double[], int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
preAggregateSparse(SparseBlock, double[], int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
preAggregateSparse(SparseBlock, double[], int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
PreAggregate the sparseblock in the range of rows given.
preAggregateSparse(SparseBlock, double[], int, int, AOffset) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
PreAggregate the SparseBlock in the range of rows given.
preAggregateSparseMap(SparseBlock, double[], int, int, int, AMapToData) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
 
preAggregateThatDDCStructure(ColGroupDDC, Dictionary) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
preAggregateThatDDCStructure(ColGroupDDC, Dictionary) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
preAggregateThatDDCStructure(ColGroupDDC, Dictionary) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
preAggregateThatIndexStructure(APreAgg) - Method in class org.apache.sysds.runtime.compress.colgroup.APreAgg
Pre aggregate into a dictionary.
preAggregateThatSDCSingleZerosStructure(ColGroupSDCSingleZeros, Dictionary) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
preAggregateThatSDCSingleZerosStructure(ColGroupSDCSingleZeros, Dictionary) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
preAggregateThatSDCSingleZerosStructure(ColGroupSDCSingleZeros, Dictionary) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
preAggregateThatSDCZerosStructure(ColGroupSDCZeros, Dictionary) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
preAggregateThatSDCZerosStructure(ColGroupSDCZeros, Dictionary) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
preAggregateThatSDCZerosStructure(ColGroupSDCZeros, Dictionary) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
preAggRows(ValueFunction) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupCompressed
 
preaggValuesFromDense(int, IColIndex, IColIndex, double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Pre Aggregate values for Right Matrix Multiplication.
preaggValuesFromDense(int, IColIndex, IColIndex, double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
preaggValuesFromDense(int, IColIndex, IColIndex, double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
preaggValuesFromDense(int, IColIndex, IColIndex, double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
preaggValuesFromDense(int, IColIndex, IColIndex, double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
preallocateSparseOutput(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNIm2Col
 
PrecisionProxy() - Constructor for class org.apache.sysds.runtime.codegen.SpoofCUDAOperator.PrecisionProxy
 
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
 
Prefetch - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
PREFETCH - org.apache.sysds.common.Types.OpOp1
 
prefetchActivated() - Method in class org.apache.sysds.hops.Hop
Checks if prefetch is activated for this hop.
prefetchActivated() - Method in class org.apache.sysds.lops.Lop
 
PrefetchCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
prepareAggregateUnaryOutput(AggregateUnaryOperator, MatrixValue, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
prepareBuildPartial() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
Allocates internal data structures for partial build.
prepareBuildPartial() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
prepareBuildPartial() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
prepareBuildPartial() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
prepareBuildPartial() - Method in interface org.apache.sysds.runtime.transform.encode.Encoder
Allocates internal data structures for partial build.
prepareBuildPartial() - Method in class org.apache.sysds.runtime.transform.encode.LegacyEncoder
Allocates internal data structures for partial build.
prepareBuildPartial() - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
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.
prepareMatrixPointers(ByteBuffer, ExecutionContext, MatrixObject, boolean) - Method in interface org.apache.sysds.runtime.codegen.SpoofCUDAOperator
 
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) - Static method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
 
prepMoveInstruction(String, 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
 
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
Propagate privacy constraints from input to output CPOperands in case the privacy constraints of the input are activated.
prepScalarInputOperand(String) - Method in class org.apache.sysds.lops.Lop
 
prepScalarInputOperand(Types.ExecType) - 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(Types.ExecType, String) - Method in class org.apache.sysds.lops.Lop
Function to be used in creating instructions for creating scalar operands.
PRINT - org.apache.sysds.common.Types.OpOp1
 
PRINT - org.apache.sysds.common.Types.OpOp2
 
PRINT - org.apache.sysds.parser.PrintStatement.PRINTTYPE
 
PRINT - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
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
 
PRINTF - org.apache.sysds.common.Types.OpOpN
 
PRINTF - org.apache.sysds.parser.PrintStatement.PRINTTYPE
 
PRINTF - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
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.
printStatus(String) - Static method in class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
Print current status of UMM, 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
 
printWithLineNumber(String) - Static method in class org.apache.sysds.runtime.codegen.CodegenUtils
 
PRIORITY_QUE - org.apache.sysds.runtime.compress.cocode.CoCoderFactory.PartitionerType
 
PRIVACY - Static variable in class org.apache.sysds.parser.DataExpression
 
PRIVACY_CONSTRAINT_MOCK - Static variable in class org.apache.sysds.conf.DMLConfig
 
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
 
privacyConstraintActivated(PrivacyConstraint) - Static method in class org.apache.sysds.runtime.privacy.PrivacyUtils
Returns true if the privacy constraint is not null and the privacy level is set to Private or PrivateAggregation.
privacyConstraintFineGrainedActivated(PrivacyConstraint) - Static method in class org.apache.sysds.runtime.privacy.PrivacyUtils
Returns true if the privacy constraint is not null and it has fine-grained constraints.
PrivacyConstraintLoader - Class in org.apache.sysds.hops.fedplanner
 
PrivacyConstraintLoader() - Constructor for class org.apache.sysds.hops.fedplanner.PrivacyConstraintLoader
 
PrivacyConstraintLoader.PrivacyConstraintRetriever - Class in org.apache.sysds.hops.fedplanner
FederatedUDF for retrieving privacy constraint of data stored in file name.
PrivacyConstraintLoaderMock - Class in org.apache.sysds.hops.fedplanner
This class is a mockup of the PrivacyConstraintLoader which replaces the call to loadFederatedPrivacyConstraints.
PrivacyConstraintLoaderMock(String) - Constructor for class org.apache.sysds.hops.fedplanner.PrivacyConstraintLoaderMock
Creates a mock of PrivacyConstraintLoader where the given privacy level is given to all federated data.
PrivacyConstraintRetriever(String) - Constructor for class org.apache.sysds.hops.fedplanner.PrivacyConstraintLoader.PrivacyConstraintRetriever
 
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
 
Private - org.apache.sysds.runtime.privacy.PrivacyConstraint.PrivacyLevel
 
PrivateAggregation - org.apache.sysds.runtime.privacy.PrivacyConstraint.PrivacyLevel
 
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(CacheableData<?>) - Static method in class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
 
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
 
processColumnQPick(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction
 
processColumnQSort(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.QuantileSortFEDInstruction
 
processCumulativeInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.CumulativeOffsetFEDInstruction
 
processCumulativeInstruction(ExecutionContext, MatrixObject) - Method in class org.apache.sysds.runtime.instructions.fed.UnaryMatrixFEDInstruction
 
processDedupItem(LineageMap, Long, LineageItem[], String, Map<String, Integer>) - Method in class org.apache.sysds.runtime.lineage.LineageMap
 
processFromLocalFedInit(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.InitFEDInstruction
 
processFunc(List<DataIdentifier>, LineageItem[], String, ExecutionContext, long) - Static method in class org.apache.sysds.runtime.lineage.LineageEstimator
 
processId - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.CoordinatorModel
 
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.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.BroadcastCPInstruction
 
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.DeCompressionCPInstruction
 
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.LocalCPInstruction
 
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.PrefetchCPInstruction
 
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.TernaryFrameScalarCPInstruction
 
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.AggregateTernaryFEDInstruction
 
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.CastFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.CentralMomentFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.CovarianceFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.CtableFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.CumulativeOffsetFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.IndexingFEDInstruction
 
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.MMFEDInstruction
 
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.QuantilePickFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.QuantileSortFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.QuaternaryWCeMMFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.QuaternaryWDivMMFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.QuaternaryWSigmoidFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.QuaternaryWSLossFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.QuaternaryWUMMFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.ReblockFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.ReorgFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.ReshapeFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.SpoofFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.TernaryFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.TernaryFrameScalarFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.TsmmFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.UnaryMatrixFEDInstruction
 
processInstruction(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.VariableFEDInstruction
 
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.gpu.SpoofCUDAInstruction
 
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.AggregateUnarySketchSPInstruction
 
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.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.DeCompressionSPInstruction
 
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.LIBSVMReblockSPInstruction
 
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.TernaryFrameScalarSPInstruction
 
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
processRowQPick(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction
 
processRowQSort(ExecutionContext) - Method in class org.apache.sysds.runtime.instructions.fed.QuantileSortFEDInstruction
 
processSingleInst(Instruction, ExecutionContext, long) - Static method in class org.apache.sysds.runtime.lineage.LineageEstimator
 
prod() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
prod() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Wrapper method for reduceall-product of a matrix.
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
 
prod(long[]) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
PROD - org.apache.sysds.common.Builtins
 
PROD - org.apache.sysds.common.Types.AggOp
 
product(double[], int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Calculate the product of the dictionary weighted by counts.
product(double[], int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
product(double[], int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
product(double[], int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
product(double[], int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
productAllRowsToDouble(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Method to product all rows to a column vector.
productAllRowsToDouble(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
productAllRowsToDouble(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
productAllRowsToDouble(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
productAllRowsToDouble(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
productAllRowsToDouble(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
productAllRowsToDoubleWithDefault(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Method to product all rows to a column vector with a default value added in the end.
productAllRowsToDoubleWithDefault(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
productAllRowsToDoubleWithDefault(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
productAllRowsToDoubleWithDefault(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
productAllRowsToDoubleWithDefault(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
productAllRowsToDoubleWithDefault(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
productAllRowsToDoubleWithReference(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Method to product all rows to a column vector with a reference values added to all cells, and a reference product in the end
productAllRowsToDoubleWithReference(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
productAllRowsToDoubleWithReference(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
productAllRowsToDoubleWithReference(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
productAllRowsToDoubleWithReference(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
productWithDefault(double[], int[], double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Calculate the product of the dictionary weighted by counts with a default value added .
productWithDefault(double[], int[], double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
productWithDefault(double[], int[], double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
productWithDefault(double[], int[], double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
productWithDefault(double[], int[], double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
productWithReference(double[], int[], double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Calculate the product of the dictionary weighted by counts and offset by reference
productWithReference(double[], int[], double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
productWithReference(double[], int[], double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
productWithReference(double[], int[], double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
productWithReference(double[], int[], double[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
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(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.
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.
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.AppendPropagator
 
propagate() - Method in class org.apache.sysds.runtime.privacy.propagation.ListAppendPropagator
 
propagate() - Method in class org.apache.sysds.runtime.privacy.propagation.ListRemovePropagator
 
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.
propagate() - Method in interface org.apache.sysds.runtime.privacy.propagation.PropagatorMultiReturn
Activates the propagation and returns the output privacy constraints.
Propagator - Interface in org.apache.sysds.runtime.privacy.propagation
Interface for all propagator instances with a single output.
PropagatorMultiReturn - Interface in org.apache.sysds.runtime.privacy.propagation
Interface for all propagator instances with multiple outputs.
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.
PROTO - org.apache.sysds.common.Types.FileFormat
 
proxy - Static variable in class org.apache.sysds.runtime.instructions.gpu.SpoofCUDAInstruction
 
PRUNE_COMPRESSED_INTERMEDIATES - Static variable in class org.apache.sysds.runtime.compress.workload.WorkloadAnalyzer
 
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_FED_AGGREGATION_FNAME - Static variable in class org.apache.sysds.parser.Statement
 
PS_FED_BATCH_SIZE - Static variable in class org.apache.sysds.parser.Statement
 
PS_FED_DATA_SIZE - Static variable in class org.apache.sysds.parser.Statement
 
PS_FED_GRADIENTS_FNAME - Static variable in class org.apache.sysds.parser.Statement
 
PS_FED_MODEL_VARID - Static variable in class org.apache.sysds.parser.Statement
 
PS_FED_NAMESPACE - Static variable in class org.apache.sysds.parser.Statement
 
PS_FED_POSS_BATCHES_LOCAL - Static variable in class org.apache.sysds.parser.Statement
 
PS_FED_RUNTIME_BALANCING - Static variable in class org.apache.sysds.parser.Statement
 
PS_FED_WEIGHTING - 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_HE - 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_MODELAVG - Static variable in class org.apache.sysds.parser.Statement
 
PS_NBATCHES - Static variable in class org.apache.sysds.parser.Statement
 
PS_NUM_BACKUP_WORKERS - 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_SEED - 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_FUN - 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
 
PT - org.apache.sysds.common.Builtins
 
PublicKey - Class in org.apache.sysds.runtime.controlprogram.paramserv.homomorphicEncryption
 
PublicKey(byte[]) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.homomorphicEncryption.PublicKey
 
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(int) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.SparkPSProxy
 
PULL - Static variable in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcObject
 
push(int, ListObject) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.HEParamServer
 
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(int, ListObject) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.SparkPSProxy
 
PUSH - Static variable in class org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcObject
 
put(Object) - Method in class org.apache.sysds.runtime.compress.SingletonLookupHashMap
 
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(Hop, List<HopRel>) - Method in class org.apache.sysds.hops.fedplanner.MemoTable
Memoize hopRels related to given root.
put(ColIndexes, CompressedSizeInfoColGroup) - Method in class org.apache.sysds.runtime.compress.cocode.Memorizer
 
put(CompressedSizeInfoColGroup) - Method in class org.apache.sysds.runtime.compress.cocode.Memorizer
 
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
 
PUT_VAR - org.apache.sysds.runtime.controlprogram.federated.FederatedRequest.RequestType
 
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
 
putCUDAOpID(String, int) - Static method in class org.apache.sysds.runtime.codegen.CodegenUtils
 
putCUDASource(int, String) - Static method in class org.apache.sysds.runtime.codegen.CodegenUtils
 
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
 
putFedReadObject(Data, LineageItem, ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageCache
 
putFineGrainedConstraintsFromString(FineGrainedPrivacy, String) - Static method in class org.apache.sysds.runtime.privacy.PrivacyUtils
 
putHopMapping(Hop, OptNode) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingAbstract
 
putInto(MatrixBlock, int, int, boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
putInto(MatrixBlock, int, int, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Method for copying this matrix into a target matrix.
putMapping(ProgramBlock, OptNode) - Method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreePlanMappingRuntime
 
putMapping(Instruction, 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
 
putSerializedObject(byte[], LineageItem, 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
 
putValue(FederatedUDF, ExecutionContext, long) - Static method in class org.apache.sysds.runtime.lineage.LineageCache
 
putValue(Instruction, ExecutionContext, long) - Static method in class org.apache.sysds.runtime.lineage.LineageCache
 
putValueAsyncOp(LineageItem, Data, MatrixBlock, 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
 
pythonPort - Variable in class org.apache.sysds.api.DMLOptions
 

Q

Q - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
 
QCHISQ - org.apache.sysds.common.Builtins
 
QDictionary - Class in org.apache.sysds.runtime.compress.colgroup.dictionary
This dictionary class aims to encapsulate the storage and operations over unique floating point values of a column group.
QEXP - org.apache.sysds.common.Builtins
 
QF - org.apache.sysds.common.Builtins
 
QNORM - org.apache.sysds.common.Builtins
 
QPick - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
QPick - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
QPick - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
QR - org.apache.sysds.common.Builtins
 
QSort - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
QSort - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
QSort - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
QT - org.apache.sysds.common.Builtins
 
QUANTILE - org.apache.sysds.common.Builtins
 
QUANTILE - org.apache.sysds.common.Types.OpOp2
 
QUANTILE - org.apache.sysds.common.Types.OpOp3
 
QuantilePickCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
QuantilePickFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
QuantilePickFEDInstruction(Operator, CPOperand, CPOperand, PickByCount.OperationTypes, boolean, String, String) - Constructor for class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction
 
QuantilePickFEDInstruction(Operator, CPOperand, CPOperand, CPOperand, PickByCount.OperationTypes, boolean, String, String) - Constructor for class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction
 
QuantilePickFEDInstruction(Operator, CPOperand, CPOperand, CPOperand, PickByCount.OperationTypes, boolean, String, String, FEDInstruction.FederatedOutput) - Constructor for class org.apache.sysds.runtime.instructions.fed.QuantilePickFEDInstruction
 
QuantilePickFEDInstruction.CreateMatrixFromFrame - Class in org.apache.sysds.runtime.instructions.fed
 
QuantilePickFEDInstruction.GetHistogram - Class in org.apache.sysds.runtime.instructions.fed
 
QuantilePickFEDInstruction.GetValuesInRange - Class in org.apache.sysds.runtime.instructions.fed
 
QuantilePickFEDInstruction.GetValuesInRanges - Class in org.apache.sysds.runtime.instructions.fed
 
QuantilePickFEDInstruction.MinMax - Class in org.apache.sysds.runtime.instructions.fed
 
QuantilePickSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
QuantileSortCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
This class supports two variants of sort operation on a 1-dimensional input matrix.
QuantileSortFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
QuantileSortSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
This class supports two variants of sort operation on a 1-dimensional input matrix.
Quaternary - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
Quaternary - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
Quaternary - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
QuaternaryCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
QuaternaryFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
QuaternaryOp - Class in org.apache.sysds.hops
Note: this hop should be called AggQuaternaryOp in consistency with AggUnaryOp and AggBinaryOp; however, since there does not exist a real QuaternaryOp yet - we can leave it as is for now.
QuaternaryOp(String, Types.DataType, Types.ValueType, Types.OpOp4, Hop, Hop, Hop) - Constructor for class org.apache.sysds.hops.QuaternaryOp
 
QuaternaryOp(String, Types.DataType, Types.ValueType, Types.OpOp4, Hop, Hop, Hop, boolean, boolean) - Constructor for class org.apache.sysds.hops.QuaternaryOp
Constructor for wsigmoid.
QuaternaryOp(String, Types.DataType, Types.ValueType, Types.OpOp4, Hop, Hop, Hop, boolean, Types.OpOp1, Types.OpOp2) - Constructor for class org.apache.sysds.hops.QuaternaryOp
 
QuaternaryOp(String, Types.DataType, Types.ValueType, Types.OpOp4, Hop, Hop, Hop, Hop, boolean) - Constructor for class org.apache.sysds.hops.QuaternaryOp
Constructor for wsloss.
QuaternaryOp(String, Types.DataType, Types.ValueType, Types.OpOp4, Hop, Hop, Hop, Hop, int, boolean, boolean) - Constructor for class org.apache.sysds.hops.QuaternaryOp
 
quaternaryOperations(QuaternaryOperator, MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
quaternaryOperations(QuaternaryOperator, MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
quaternaryOperations(QuaternaryOperator, MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
QuaternaryOperator - Class in org.apache.sysds.runtime.matrix.operators
 
QuaternaryOperator(WeightedCrossEntropy.WCeMMType) - Constructor for class org.apache.sysds.runtime.matrix.operators.QuaternaryOperator
wcemm
QuaternaryOperator(WeightedCrossEntropy.WCeMMType, double) - Constructor for class org.apache.sysds.runtime.matrix.operators.QuaternaryOperator
wcemm w/epsilon
QuaternaryOperator(WeightedDivMM.WDivMMType) - Constructor for class org.apache.sysds.runtime.matrix.operators.QuaternaryOperator
wdivmm
QuaternaryOperator(WeightedDivMM.WDivMMType, double) - Constructor for class org.apache.sysds.runtime.matrix.operators.QuaternaryOperator
wdivmm w/epsilon
QuaternaryOperator(WeightedSigmoid.WSigmoidType) - Constructor for class org.apache.sysds.runtime.matrix.operators.QuaternaryOperator
wsigmoid
QuaternaryOperator(WeightedSquaredLoss.WeightsType) - Constructor for class org.apache.sysds.runtime.matrix.operators.QuaternaryOperator
wsloss
QuaternaryOperator(WeightedUnaryMM.WUMMType, String) - Constructor for class org.apache.sysds.runtime.matrix.operators.QuaternaryOperator
wumm
QuaternarySPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
QuaternaryWCeMMFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
QuaternaryWDivMMFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
QuaternaryWSigmoidFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
QuaternaryWSLossFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
QuaternaryWUMMFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
quickGetValue(int, int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
quickGetValue(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
quickGetValueThreadSafe(int, int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
quickGetValueThreadSafe(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
quickSetValue(int, int, double) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
quickSetValue(int, int, double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
quote(String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
quotedString(String) - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
Return a double-quoted string with inner single and double quotes escaped.

R

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) - 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.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, String) - Method in class org.apache.sysds.parser.Statement
 
raiseValidateError(String, boolean, String) - Method in class org.apache.sysds.parser.StatementBlock
 
Rand - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
Rand - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
RAND - org.apache.sysds.common.Types.OpOpDG
 
RAND - org.apache.sysds.parser.Expression.DataOp
 
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
 
RANDOM_FOREST - org.apache.sysds.common.Builtins
 
RandomMatrixGenerator - Class in org.apache.sysds.runtime.matrix.data
 
RandomMatrixGenerator() - Constructor for class org.apache.sysds.runtime.matrix.data.RandomMatrixGenerator
 
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) - 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
RandomMatrixGenerator.PDF - Enum in org.apache.sysds.runtime.matrix.data
Types of Probability density functions
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.CompressedMatrixBlock
 
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.compress.CompressedMatrixBlock
 
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
 
RANGE - org.apache.sysds.common.Builtins
 
RANGE - org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex.ColIndexType
 
RANGE - org.apache.sysds.runtime.controlprogram.parfor.Task.TaskType
 
RangeIndex - Class in org.apache.sysds.runtime.compress.colgroup.indexes
 
RangeIndex(int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.indexes.RangeIndex
 
RangeIndex(int, int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.indexes.RangeIndex
 
RANGEPICK - org.apache.sysds.lops.PickByCount.OperationTypes
 
RANK_DIMS_COLS - org.apache.sysds.hops.codegen.SpoofFusedOp.SpoofOutputDimsType
 
RAppend - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
RawRow - Class in org.apache.sysds.runtime.iogen
 
RawRow(String) - Constructor for class org.apache.sysds.runtime.iogen.RawRow
 
RawRow(String, ArrayList<Integer>, String) - Constructor for class org.apache.sysds.runtime.iogen.RawRow
 
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(ExecutionContext, GPUContext, String, MatrixObject, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
 
RBIND - org.apache.sysds.common.Builtins
 
RBIND - org.apache.sysds.common.Types.OpOp2
 
RBIND - org.apache.sysds.common.Types.OpOpN
 
RBIND - org.apache.sysds.hops.estim.SparsityEstimator.OpCode
 
RBIND - org.apache.sysds.runtime.instructions.cp.AppendCPInstruction.AppendType
 
RBindPropagator - Class in org.apache.sysds.runtime.privacy.propagation
 
RBindPropagator(MatrixBlock, PrivacyConstraint, MatrixBlock, PrivacyConstraint) - Constructor for class org.apache.sysds.runtime.privacy.propagation.RBindPropagator
 
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
 
rContainsRead(Hop, String, boolean) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
rContainsSparkInstruction(ProgramBlock, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
 
rCreateAbstractOptNode(StatementBlock, ProgramBlock, LocalVariableMap, boolean, OptTreePlanMappingAbstract, Set<String>) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
 
rCreateAbstractOptNodes(Hop, LocalVariableMap, OptTreePlanMappingAbstract, 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, OptTreePlanMappingRuntime, 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
 
RDDContainsFunction(double) - Constructor for class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDContainsFunction
 
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
 
RDDFrameReplaceFunction(String, String) - Constructor for class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDFrameReplaceFunction
 
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(long, 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.
RDDTokenizeFunction(Tokenizer, int) - Constructor for class org.apache.sysds.runtime.instructions.spark.ParameterizedBuiltinSPInstruction.RDDTokenizeFunction
 
RDDTransformApplyFunction(Broadcast<MultiColumnEncoder>, 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) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
read(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
read(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
read(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
read(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
read(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
read(DataInput) - Static method in interface org.apache.sysds.runtime.compress.colgroup.dictionary.DictionaryFactory
 
read(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
read(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
read(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
read(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
read(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.indexes.ArrayIndex
 
read(DataInput) - Static method in interface org.apache.sysds.runtime.compress.colgroup.indexes.ColIndexFactory
 
read(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.indexes.RangeIndex
 
read(DataInput) - Static method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
read(DataInput) - Static method in class org.apache.sysds.runtime.frame.data.columns.ColumnMetadata
 
read(DataInput) - Method in class org.apache.sysds.runtime.instructions.cp.KahanObject
 
read(DataInput, int) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
read(DataInput, int) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
 
read(DataInput, int) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
 
read(DataInput, int) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
read(DataInput, int) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
read(DataInput, int) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
read(DataInput, int) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
read(DataInput, int) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
read(DataInput, int) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
 
read(String, DataCharacteristics) - Static method in class org.apache.sysds.runtime.io.ReaderWriterFederated
Read a federated map from disk, It is not initialized before it is used in: org.apache.sysds.runtime.instructions.fed.InitFEDInstruction
Read - org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
 
READ - org.apache.sysds.parser.Expression.DataOp
 
READ - org.apache.sysds.runtime.controlprogram.caching.CacheableData.CacheStatus
 
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
READ_VAR - org.apache.sysds.runtime.controlprogram.federated.FederatedRequest.RequestType
 
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
 
readBlock(String, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
 
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
 
readBufferFromAddress(long, int) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
readBufferFromAddressNoOrder(long, int) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
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
 
readBytesAsUnsignedInt(ByteBuffer, int) - Static method in class org.apache.sysds.runtime.io.hdf5.Utils
 
readBytesAsUnsignedLong(ByteBuffer, int) - Static method in class org.apache.sysds.runtime.io.hdf5.Utils
 
readCacheBlockFromLocal(String, boolean) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
Reads a matrix/frame block from local file system.
ReadCacheEntry() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.FederatedReadCache.ReadCacheEntry
 
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
 
readColGroup(DataInput, int) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupIO
 
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
 
readCompressedMatrixFromHDFS(String) - Static method in class org.apache.sysds.runtime.compress.io.ReaderCompressed
 
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.
readData(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.AColGroupOffset
 
readDMLScript(boolean, String) - Static method in class org.apache.sysds.api.DMLScript
Reads the DML/PyDML script into a String
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
 
readDoubleArray(int, DataInput) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupIO
 
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.readers
Base class for all column selection readers.
ReaderColumnSelectionDenseMultiBlock - Class in org.apache.sysds.runtime.compress.readers
 
ReaderColumnSelectionDenseMultiBlockTransposed - Class in org.apache.sysds.runtime.compress.readers
 
ReaderColumnSelectionDenseSingleBlock - Class in org.apache.sysds.runtime.compress.readers
 
ReaderColumnSelectionDenseSingleBlockTransposed - Class in org.apache.sysds.runtime.compress.readers
 
ReaderColumnSelectionSparse - Class in org.apache.sysds.runtime.compress.readers
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.
ReaderColumnSelectionSparseTransposed - Class in org.apache.sysds.runtime.compress.readers
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.
ReaderCompressed - Class in org.apache.sysds.runtime.compress.io
 
ReaderCompressed() - Constructor for class org.apache.sysds.runtime.compress.io.ReaderCompressed
 
ReaderHDF5 - Class in org.apache.sysds.runtime.io
 
ReaderHDF5(FileFormatPropertiesHDF5) - Constructor for class org.apache.sysds.runtime.io.ReaderHDF5
 
ReaderHDF5Parallel - Class in org.apache.sysds.runtime.io
 
ReaderHDF5Parallel(FileFormatPropertiesHDF5) - Constructor for class org.apache.sysds.runtime.io.ReaderHDF5Parallel
 
ReaderMapping - Class in org.apache.sysds.runtime.iogen
 
ReaderMapping(String) - Constructor for class org.apache.sysds.runtime.iogen.ReaderMapping
 
ReaderMapping.FrameReaderMapping - Class in org.apache.sysds.runtime.iogen
 
ReaderMapping.MatrixReaderMapping - Class in org.apache.sysds.runtime.iogen
 
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(FileFormatPropertiesLIBSVM) - Constructor for class org.apache.sysds.runtime.io.ReaderTextLIBSVM
 
ReaderTextLIBSVMParallel - Class in org.apache.sysds.runtime.io
 
ReaderTextLIBSVMParallel(FileFormatPropertiesLIBSVM) - Constructor for class org.apache.sysds.runtime.io.ReaderTextLIBSVMParallel
 
ReaderWriterFederated - Class in org.apache.sysds.runtime.io
This class serves as the reader for federated objects.
ReaderWriterFederated() - Constructor for class org.apache.sysds.runtime.io.ReaderWriterFederated
 
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.frame.data.FrameBlock
 
readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
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.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.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
 
readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.transform.decode.Decoder
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.transform.decode.DecoderComposite
 
readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.transform.decode.DecoderDummycode
 
readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.transform.decode.DecoderPassThrough
 
readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.transform.decode.DecoderRecode
 
readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
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.transform.encode.ColumnEncoderBin
 
readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderFeatureHash
 
readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
 
readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
 
readExternal(ObjectInput) - Method in class org.apache.sysds.runtime.transform.encode.LegacyEncoder
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.transform.encode.MultiColumnEncoder
 
readFields(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetByte
 
readFields(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetChar
 
readFields(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetEmpty
 
readFields(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetSingle
 
readFields(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetTwo
 
readFields(DataInput) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
readFields(DataInput) - Method in class org.apache.sysds.runtime.compress.io.CompressedWriteBlock
 
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.frame.data.columns.BitSetArray
 
readFields(DataInput) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
readFields(DataInput) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
readFields(DataInput) - Method in class org.apache.sysds.runtime.frame.data.columns.ColumnMetadata
 
readFields(DataInput) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
readFields(DataInput) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
readFields(DataInput) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
readFields(DataInput) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
readFields(DataInput) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
readFields(DataInput) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
readFields(DataInput) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
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.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, 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, Types.ValueType[], 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[], 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
 
readFrameFromHDFS(String, Types.ValueType[], String[], long, long) - Method in class org.apache.sysds.runtime.iogen.FrameGenerateReader
 
readFrameFromHDFS(String, Types.ValueType[], Map<String, Integer>, long, long) - Method in class org.apache.sysds.runtime.io.FrameReaderJSONL
 
readFrameFromInputStream(InputStream, 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, Types.ValueType[], String[], 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
 
readFrameFromInputStream(InputStream, Types.ValueType[], String[], long, long) - Method in class org.apache.sysds.runtime.iogen.FrameGenerateReader
 
readFully(byte[]) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataInput
 
readFully(byte[]) - 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.controlprogram.caching.CacheDataInput
 
readFully(byte[], int, int) - Method in class org.apache.sysds.runtime.util.ByteBufferDataInput
 
readFully(byte[], int, int) - Method in class org.apache.sysds.runtime.util.FastBufferedDataInputStream
 
readGroups(DataInput, int) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupIO
Read groups from a file.
readHeaderAndValidateSignature(H5RootObject, long) - Static method in class org.apache.sysds.runtime.io.hdf5.H5BTree
 
readIn(DataInput) - Static method in interface org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory
 
readIn(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory
Read in AOffset from the DataInput.
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
 
readListFromHDFS(String, String, FileFormatProperties) - Static method in class org.apache.sysds.runtime.io.ListReader
Reads a list object and all contained objects from a folder with related meta data.
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.
readMatrixFromHDF5(BufferedInputStream, String, MatrixBlock, int, long, long, int) - Static method in class org.apache.sysds.runtime.io.ReaderHDF5
 
readMatrixFromHDFS(String, long, long, int, long) - Method in class org.apache.sysds.runtime.compress.io.ReaderCompressed
 
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.ReaderHDF5
 
readMatrixFromHDFS(String, long, long, int, long) - Method in class org.apache.sysds.runtime.io.ReaderHDF5Parallel
 
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, long, long, int, long) - Method in class org.apache.sysds.runtime.iogen.MatrixGenerateReader
 
readMatrixFromHDFS(String, Types.FileFormat, long, long, int) - 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.HDFSTool
 
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, 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.
readMatrixFromInputStream(InputStream, long, long, int, long) - Method in class org.apache.sysds.runtime.compress.io.ReaderCompressed
 
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.ReaderHDF5
 
readMatrixFromInputStream(InputStream, long, long, int, long) - Method in class org.apache.sysds.runtime.io.ReaderHDF5Parallel
 
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
 
readMatrixFromInputStream(InputStream, long, long, int, long) - Method in class org.apache.sysds.runtime.iogen.MatrixGenerateReader
 
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.runtime.meta.MetaDataAll
 
READNNZPARAM - Static variable in class org.apache.sysds.parser.DataExpression
 
readObjectFromHDFSFile(String, Types.ValueType) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
readObjectHeaderMessage(H5RootObject, ByteBuffer) - Static method in class org.apache.sysds.runtime.io.hdf5.message.H5Message
 
readPointers(DataInput) - Static method in class org.apache.sysds.runtime.compress.colgroup.AColGroupOffset
 
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
 
readScalarObjectFromHDFSFile(String, Types.ValueType) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
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
 
readUntilNull(ByteBuffer) - Static method in class org.apache.sysds.runtime.io.hdf5.Utils
 
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.
REAL - org.apache.sysds.runtime.io.FileFormatPropertiesMM.MMField
 
Reblock - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
Reblock - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
ReBlock - Class in org.apache.sysds.lops
Lop to perform reblock operation
ReBlock - org.apache.sysds.lops.Lop.Type
 
ReBlock(Lop, int, Types.DataType, Types.ValueType, boolean, Types.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
 
ReblockFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
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
 
Recode - org.apache.sysds.runtime.transform.decode.DecoderFactory.DecoderType
 
Recode - org.apache.sysds.runtime.transform.encode.ColumnEncoder.EncoderType
 
RECODE - org.apache.sysds.runtime.transform.TfUtils.TfMethod
 
RECOMPILE_CODEGEN - Static variable in class org.apache.sysds.hops.codegen.SpoofCompiler
 
RECOMPILE_HOPS - org.apache.sysds.api.mlcontext.MLContext.ExplainLevel
Explain HOPs, including recompile
RECOMPILE_HOPS - org.apache.sysds.utils.Explain.ExplainType
 
RECOMPILE_RUNTIME - org.apache.sysds.api.mlcontext.MLContext.ExplainLevel
Explain runtime program, including recompile
RECOMPILE_RUNTIME - org.apache.sysds.utils.Explain.ExplainType
 
recompileHopsDag(Hop, LocalVariableMap, RecompileStatus, boolean, boolean, long) - Static method in class org.apache.sysds.hops.recompile.Recompiler
 
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
 
recompileHopsDag2Forced(Hop, long, Types.ExecType) - Static method in class org.apache.sysds.hops.recompile.Recompiler
 
recompileHopsDag2Forced(StatementBlock, ArrayList<Hop>, long, Types.ExecType) - Static method in class org.apache.sysds.hops.recompile.Recompiler
 
recompileHopsDagInstructions(Hop) - Static method in class org.apache.sysds.hops.recompile.Recompiler
 
recompileHopsDagInstructions(StatementBlock, ArrayList<Hop>) - Static method in class org.apache.sysds.hops.recompile.Recompiler
 
recompileProgramBlockHierarchy(ArrayList<ProgramBlock>, LocalVariableMap, long, boolean, Recompiler.ResetType) - Static method in class org.apache.sysds.hops.recompile.Recompiler
 
recompileProgramBlockHierarchy2Forced(ArrayList<ProgramBlock>, long, HashSet<String>, Types.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
 
recompileProgramBlocks(int, List<ProgramBlock>, boolean) - 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
 
RecompileStatistics - Class in org.apache.sysds.utils.stats
 
RecompileStatistics() - Constructor for class org.apache.sysds.utils.stats.RecompileStatistics
 
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
 
RecompileStatus(long, boolean, Recompiler.ResetType, boolean) - Constructor for class org.apache.sysds.hops.recompile.RecompileStatus
 
recomputeColumnCardinality() - Method in class org.apache.sysds.runtime.frame.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.compress.CompressedMatrixBlock
 
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.compress.CompressedMatrixBlock
 
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.compress.CompressedMatrixBlock
 
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(RecompileStatus, RecompileStatus, RecompileStatus, StatementBlock) - Static method in class org.apache.sysds.hops.recompile.Recompiler
 
reconcileUpdatedCallVarsIf(LocalVariableMap, 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
 
reconcileUpdatedCallVarsLoops(LocalVariableMap, LocalVariableMap, StatementBlock) - Static method in class org.apache.sysds.hops.recompile.Recompiler
 
RECURSIVE_CALL - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.ParamType
 
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
 
reduceSizes(List<Tuple2<MatrixIndexes, Long>>) - Static method in class org.apache.sysds.runtime.instructions.spark.CompressionSPInstruction
 
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
 
refSum(double[]) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupUtils
 
refSumSq(double[]) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupUtils
 
REG_ALLOC_POLICY - Static variable in class org.apache.sysds.hops.codegen.SpoofCompiler
 
regex - Variable in class org.apache.sysds.runtime.transform.tokenize.builder.TokenizerBuilderWhitespaceSplit
 
registerFedWorker(String, int) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
registerThread(int, FederatedPSControlThread) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.HEParamServer
 
regressMatrixBlock(MatrixBlock, IColIndex, boolean) - Static method in interface org.apache.sysds.runtime.compress.colgroup.functional.LinearRegression
 
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.
REJECT_READ_WRITE_UNKNOWNS - org.apache.sysds.conf.CompilerConfig.ConfigType
 
RelationalBinary - org.apache.sysds.runtime.instructions.gpu.GPUInstruction.GPUINSTRUCTION_TYPE
 
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.
release() - Method in class org.apache.sysds.runtime.controlprogram.context.MatrixObjectFuture
 
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.
RELU_BACKWARD - org.apache.sysds.common.Types.OpOpDnn
 
RELU_MAX_POOL - org.apache.sysds.common.Types.OpOpDnn
 
RELU_MAX_POOL_BACKWARD - org.apache.sysds.common.Types.OpOpDnn
 
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
 
REMOTE_SPARK - org.apache.sysds.parser.Statement.PSModeType
 
REMOTE_SPARK - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PDataPartitioner
 
REMOTE_SPARK - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PExecMode
 
REMOTE_SPARK - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PResultMerge
 
REMOTE_SPARK_DP - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PExecMode
 
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, boolean, 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, boolean, 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() - Method in class org.apache.sysds.runtime.frame.data.iterators.RowIterator
 
remove() - Method in class org.apache.sysds.runtime.instructions.spark.data.LazyIterableIterator
 
remove(int) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
Removes the element at the specified position from the list and returns that element as the only element in a new ListObject.
remove(Long) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.CoordinatorService
 
remove(Long) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.WorkerService
 
remove(String) - Method in class org.apache.sysds.runtime.controlprogram.LocalVariableMap
 
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(ColIndexes, ColIndexes) - Method in class org.apache.sysds.runtime.compress.cocode.Memorizer
 
REMOVE - org.apache.sysds.common.Builtins
 
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
 
removeAllEntitiesByField(String, Object, Class<T>) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.DerbyRepository
 
removeAllEntitiesByField(String, Object, Class<T>) - Method in interface org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.IRepository
 
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
removeDataObjects() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
removeECM(String, long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedLookupTable
Remove the ExecutionContextMap corresponding to the given host and pid of the requesting coordinator from the lookup table.
removeEmpty(FrameBlock, boolean, boolean, MatrixBlock) - Static method in class org.apache.sysds.runtime.frame.data.lib.FrameLibRemoveEmpty
 
removeEmpty(MatrixBlock, int, int) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DRRLocalScheme
 
removeEmptyOperations(boolean, boolean, MatrixBlock) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
removeEmptyOperations(MatrixBlock, boolean, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
removeEmptyOperations(MatrixBlock, boolean, boolean, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
removeEmptyOperations(MatrixBlock, boolean, boolean, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
removeEntity(Long, Class<T>) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.DerbyRepository
 
removeEntity(Long, Class<T>) - Method in interface org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.IRepository
 
removeEntry(LineageCacheEntry) - Static method in class org.apache.sysds.runtime.lineage.LineageGPUCacheEviction
 
removeEntry(LineageItem) - Static method in class org.apache.sysds.runtime.lineage.LineageCache
 
removeFEDOutputFlag(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
Removes federated output flag from the end of the instruction string if the flag is present.
removeFirst() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheEvictionQueue
 
removeFirstUnpinned(List<String>) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheEvictionQueue
 
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(GPUContext) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
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
removeInnerCharacterInPattern(String, char, char) - Static method in class org.apache.sysds.runtime.util.DMVUtils
 
removeInput(String) - Method in class org.apache.sysds.hops.DataOp
Remove an input from the list of inputs and from the parameter index map.
removeInput(Lop) - Method in class org.apache.sysds.lops.Lop
 
removeKey(int) - Method in class org.apache.sysds.runtime.compress.SingletonLookupHashMap
 
removeLineageItem(String) - Method in class org.apache.sysds.runtime.lineage.LineageMap
 
removeMetaData() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
removeMetaData() - Method in class org.apache.sysds.runtime.instructions.cp.Data
 
removeOperand(String, int) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
 
removeOutput(Lop) - Method in class org.apache.sysds.lops.Lop
Method to remove output from Lop
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.
removeUpperLowerCase(String) - Static method in class org.apache.sysds.runtime.util.DMVUtils
 
removeVariable(String) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
RemoveVariable - org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
 
RemoveVariableAndFile - org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
 
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
 
Reorg - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
Reorg - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
Reorg - org.apache.sysds.runtime.instructions.gpu.GPUInstruction.GPUINSTRUCTION_TYPE
 
Reorg - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
ReorgCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
ReorgFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
ReorgFEDInstruction(Operator, CPOperand, CPOperand, String, String) - Constructor for class org.apache.sysds.runtime.instructions.fed.ReorgFEDInstruction
 
ReorgFEDInstruction(Operator, CPOperand, CPOperand, String, String, FEDInstruction.FederatedOutput) - Constructor for class org.apache.sysds.runtime.instructions.fed.ReorgFEDInstruction
 
ReorgFEDInstruction.DiagMatrix - Class in org.apache.sysds.runtime.instructions.fed
 
ReorgFEDInstruction.Rdiag - Class in org.apache.sysds.runtime.instructions.fed
 
ReorgGPUInstruction - Class in org.apache.sysds.runtime.instructions.gpu
 
reorgInPlace(MatrixBlock, ReorgOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
 
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, ArrayList<Hop>) - Constructor for class org.apache.sysds.hops.ReorgOp
 
ReorgOp(String, Types.DataType, Types.ValueType, Types.ReOrgOp, Hop) - Constructor for class org.apache.sysds.hops.ReorgOp
 
reorgOperations(ReorgOperator, MatrixValue, int, int, int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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(double, double) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Make a copy of the column group values, and replace all values that match pattern with replacement value.
replace(double, double) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupValue
 
replace(double, double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
replace(double, double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
replace(double, double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
replace(double, double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
replace(double, double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
replace(double, double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
replace(double, double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
replace(double, double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
replace(double, double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
replace(double, double) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
replace(double, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Make a copy of the values, and replace all values that match pattern with replacement value.
replace(double, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
replace(double, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
replace(double, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
replace(double, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
replace(double, double, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
replace(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Replace v with r for all entries, NOTE! It is assumed that you call this correctly: - with two distinct values that is representable inside the given AMapToData.
replace(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
replace(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
replace(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
replace(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
replace(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
replace(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToUByte
 
replace(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
replace(LineageItem, LineageItem, LineageItem) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
 
REPLACE - org.apache.sysds.common.Builtins
 
REPLACE - org.apache.sysds.common.Types.ParamBuiltinOp
 
REPLACE - org.apache.sysds.hops.codegen.cplan.CNodeTernary.TernaryType
 
REPLACE - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ParameterizedBuiltinCode
 
REPLACE_NAN - org.apache.sysds.hops.codegen.cplan.CNodeTernary.TernaryType
 
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.
replaceInput(Lop, Lop) - Method in class org.apache.sysds.lops.Lop
Method to replace an input to a Lop
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(String, String) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
replaceOperations(MatrixValue, double, double) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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(List<ProgramBlock>, ProgramBlock, ProgramBlock) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
 
replaceProgramBlock(OptNode, OptNode, ProgramBlock, ProgramBlock, OptTreePlanMappingAbstract) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
 
replaceProgramBlock(OptNode, OptNode, ProgramBlock, ProgramBlock, OptTreePlanMappingRuntime) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptTreeConverter
 
replaceWithReference(double, double, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Make a copy of the values, and replace all values that match pattern with replacement value.
replaceWithReference(double, double, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
replaceWithReference(double, double, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
replaceWithReference(double, double, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
replaceWithReference(double, double, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
replaceWithReference(double, double, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
replaceWithUIDs() - Method in class org.apache.sysds.runtime.compress.utils.DblArrayCountHashMap
 
replaceWithUIDs() - Method in class org.apache.sysds.runtime.compress.utils.DoubleCountHashMap
 
replaceWithUIDsNoZero() - Method in class org.apache.sysds.runtime.compress.utils.DoubleCountHashMap
 
REPLICATE_TO_MAX - org.apache.sysds.parser.Statement.FederatedPSScheme
 
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
 
ReplicateToMaxFederatedScheme - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
Replicate to Max Federated scheme When the parameter server runs in federated mode it cannot pull in the data which is already on the workers.
ReplicateToMaxFederatedScheme() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.ReplicateToMaxFederatedScheme
 
ReplicateVectorFunction - Class in org.apache.sysds.runtime.instructions.spark.functions
 
ReplicateVectorFunction(boolean, long) - Constructor for class org.apache.sysds.runtime.instructions.spark.functions.ReplicateVectorFunction
 
RepMat - org.apache.sysds.lops.Lop.Type
 
Request - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring
 
Request() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.Request
 
requestFederatedData() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
RequestModel - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.models
 
RequestModel() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.RequestModel
 
RequestModel(Long, String, Long) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.RequestModel
 
RequestModel(String, Long) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.RequestModel
 
requests - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.StatisticsModel
 
requests - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.StatisticsOptions
 
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.ForStatementBlock
 
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() - Method in class org.apache.sysds.parser.StatementBlock
 
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
 
requiresRecompile() - Method in class org.apache.sysds.hops.Hop
Indicates if dynamic recompilation is required for this hop.
requiresRecompile() - Method in class org.apache.sysds.hops.recompile.RecompileStatus
 
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
reserveOutputMem() - Static method in class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
 
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.utils.DblArrayIntListHashMap
 
reset() - Static method in class org.apache.sysds.runtime.controlprogram.caching.CacheStatistics
 
reset() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics
 
reset() - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.IDSequence
 
reset() - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
 
reset() - 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() - Method in class org.apache.sysds.runtime.data.SparseBlock
Clears the sparse block by deleting non-zero values.
reset() - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
reset() - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
reset() - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
 
reset() - Method in class org.apache.sysds.runtime.data.TensorBlock
Reset all cells to 0.
reset() - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
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() - Static method in class org.apache.sysds.runtime.lineage.LineageEstimatorStatistics
 
reset() - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
 
reset() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
reset() - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
reset() - 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() - Static method in class org.apache.sysds.utils.DMLCompressionStatistics
 
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() - Static method in class org.apache.sysds.utils.stats.CodegenStatistics
 
reset() - Static method in class org.apache.sysds.utils.stats.NativeStatistics
 
reset() - Static method in class org.apache.sysds.utils.stats.ParamServStatistics
 
reset() - Static method in class org.apache.sysds.utils.stats.ParForStatistics
 
reset() - Static method in class org.apache.sysds.utils.stats.RecompileStatistics
 
reset() - Static method in class org.apache.sysds.utils.stats.SparkStatistics
 
reset() - Static method in class org.apache.sysds.utils.stats.TransformStatistics
 
reset(int) - Method in class org.apache.sysds.runtime.compress.utils.DblArrayCountHashMap
 
reset(int) - Method in class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap
 
reset(int) - Method in class org.apache.sysds.runtime.compress.utils.DoubleCountHashMap
 
reset(int) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Reset the Array and set to a different size.
reset(int) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
reset(int) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
reset(int) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
reset(int) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
reset(int) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
reset(int) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
reset(int) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
reset(int) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
reset(int) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
reset(int[]) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
 
reset(int[]) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
 
reset(int[]) - 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.TensorBlock
Reset data with new dimensions.
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(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlock
Resets the dense block by deleting non-zeros.
reset(int[], long) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
 
reset(int[], Types.ValueType[]) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
 
reset(int, boolean) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
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.SparseBlock
Clears the sparse block by deleting non-zero values.
reset(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
reset(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
reset(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(int, int) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
 
reset(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
reset(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
reset(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
 
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.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(int, int, boolean) - 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.MatrixBlock
 
reset(int, int, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
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.CM_N_COVCell
 
reset(int, int, boolean, long) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
reset(int, int, boolean, long) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
reset(int, int, boolean, long) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
 
reset(int, int, boolean, long, double) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
reset(int, int, boolean, long, double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Internal canonical reset of dense and sparse matrix blocks.
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.matrix.data.CM_N_COVCell
 
reset(int, int, double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
reset(int, int, double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
reset(int, int, double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
 
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(int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
reset(int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
reset(int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
 
reset(int, int, long) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
reset(long) - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.IDSequence
 
reset(String) - Method in class org.apache.sysds.runtime.iogen.FastStringTokenizer
 
reset(String) - Method in class org.apache.sysds.runtime.util.FastStringTokenizer
 
RESET - org.apache.sysds.hops.recompile.Recompiler.ResetType
 
RESET_KNOWN_DIMS - org.apache.sysds.hops.recompile.Recompiler.ResetType
 
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
 
resetEstimatorCache() - Static method in class org.apache.sysds.runtime.lineage.LineageEstimator
 
resetExecType() - Method in class org.apache.sysds.hops.Hop
 
resetFedDataID() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
resetFederatedCost() - Method in class org.apache.sysds.hops.Hop
Reset federated cost of this hop and all children of this hop.
resetFederatedSites() - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
 
resetFloatingPointPrecision() - Static method in class org.apache.sysds.runtime.instructions.gpu.SpoofCUDAInstruction
Sets the internal state based on the DMLScript.DATA_TYPE
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
 
resetHash() - Method in class org.apache.sysds.runtime.compress.utils.DblArray
 
resetHash() - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
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
 
resetInputs() - 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>, Types.ExecType, Recompiler.ResetType) - Static method in class org.apache.sysds.hops.Hop
 
resetRecompilationFlag(Hop, Types.ExecType, Recompiler.ResetType) - Static method in class org.apache.sysds.hops.Hop
 
resetReserved() - Method in class org.apache.sysds.runtime.iogen.RawRow
 
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
 
resetStats() - Method in class org.apache.sysds.runtime.compress.cocode.Memorizer
 
resetVisitStatus() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
 
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(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(List<CNode>) - Static method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
 
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
Non-recursive equivalent of LineageItem.resetVisitStatus() for robustness with regard to stack overflow errors.
resetVisitStatusNR(LineageItem[]) - Static method in class org.apache.sysds.runtime.lineage.LineageItem
Non-recursive equivalent of LineageItem.resetVisitStatus(LineageItem[]) for robustness with regard to stack overflow errors.
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(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(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 - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
Reshape - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
RESHAPE - org.apache.sysds.common.Types.ReOrgOp
 
RESHAPE - org.apache.sysds.hops.estim.SparsityEstimator.OpCode
 
RESHAPE_VALID_PARAM_NAMES - Static variable in class org.apache.sysds.parser.DataExpression
 
ReshapeCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
ReshapeFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
resize(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
 
resize(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
resize(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
resize(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
resize(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
resize(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
resize(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToUByte
 
resize(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
resize(AMapToData, int) - Static method in interface org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory
Reshape the map, to a smaller instance if applicable.
resizeForce(AMapToData, MapToFactory.MAP_TYPE) - Static method in interface org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory
Force the mapping into an other mapping type.
Response - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring
 
Response() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.Response
 
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(List<MatrixObject>, List<MatrixObject>, int, DataPartitionFederatedScheme.BalanceMetrics, List<Double>) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionFederatedScheme.Result
 
RESULT_LIX - org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator.ExcludeType
 
RESULT_MERGE - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.ParamType
 
RESULT_MERGE - Static variable in class org.apache.sysds.parser.ParForStatementBlock
 
ResultMerge<T extends CacheableData<?>> - Class in org.apache.sysds.runtime.controlprogram.parfor
 
ResultMerge(T, T[], String, boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.ResultMerge
 
ResultMergeFrameLocalMemory - Class in org.apache.sysds.runtime.controlprogram.parfor
 
ResultMergeFrameLocalMemory(FrameObject, FrameObject[], String, boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeFrameLocalMemory
 
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
 
ResultMergeMatrix - 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.
ResultMergeMatrix() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeMatrix
 
ResultMergeMatrix(MatrixObject, MatrixObject[], String, boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeMatrix
 
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
 
ret - Variable in class org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex.SliceResult
The already modified column index to return on slices
reuse(List<String>, List<DataIdentifier>, int, LineageItem[], String, ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageCache
 
reuse(FederatedUDF, ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageCache
 
reuse(Instruction, ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageCache
 
REUSE_FULL - org.apache.sysds.runtime.lineage.LineageCacheConfig.ReuseCacheType
 
REUSE_HYBRID - org.apache.sysds.runtime.lineage.LineageCacheConfig.ReuseCacheType
 
REUSE_MULTILEVEL - org.apache.sysds.runtime.lineage.LineageCacheConfig.ReuseCacheType
 
REUSE_PARTIAL - org.apache.sysds.runtime.lineage.LineageCacheConfig.ReuseCacheType
 
reuseFedRead(String, Types.DataType, LineageItem, ExecutionContext) - Static method in class org.apache.sysds.runtime.lineage.LineageCache
 
reuseSerialization(LineageItem) - 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(IndexedMatrixValue, long, int, ArrayList<IndexedMatrixValue>) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
 
rev(MatrixBlock, MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
 
REV - org.apache.sysds.common.Builtins
 
REV - org.apache.sysds.common.Types.ReOrgOp
 
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
 
reverse(int, AOffset) - Static method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
 
reverseFedMap() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
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.
RewriteAddBroadcastLop - Class in org.apache.sysds.lops.rewrite
 
RewriteAddBroadcastLop() - Constructor for class org.apache.sysds.lops.rewrite.RewriteAddBroadcastLop
 
RewriteAddChkpointLop - Class in org.apache.sysds.lops.rewrite
 
RewriteAddChkpointLop() - Constructor for class org.apache.sysds.lops.rewrite.RewriteAddChkpointLop
 
RewriteAddPrefetchLop - Class in org.apache.sysds.lops.rewrite
 
RewriteAddPrefetchLop() - Constructor for class org.apache.sysds.lops.rewrite.RewriteAddPrefetchLop
 
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: Compressed Re block if config compressed.linalg is enabled, we inject compression directions after read of matrices if number of rows is above 1000 and cols at least 1.
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
 
RewriteFixIDs - Class in org.apache.sysds.lops.rewrite
 
RewriteFixIDs() - Constructor for class org.apache.sysds.lops.rewrite.RewriteFixIDs
 
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
 
rewriteFunctionDynamic(FunctionStatementBlock, LocalVariableMap) - Method in class org.apache.sysds.hops.fedplanner.AFederatedPlanner
Selects a federated execution plan for the given function, taking into account federation types of the arguments.
rewriteFunctionDynamic(FunctionStatementBlock, LocalVariableMap) - Method in class org.apache.sysds.hops.fedplanner.FederatedPlannerCostbased
 
rewriteFunctionDynamic(FunctionStatementBlock, LocalVariableMap) - Method in class org.apache.sysds.hops.fedplanner.FederatedPlannerFedAll
 
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(ArrayList<Hop>, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.ProgramRewriter
 
rewriteHopDAG(Hop, ProgramRewriteStatus) - Method in class org.apache.sysds.hops.rewrite.HopRewriteRule
Handle a predicate hop DAG with exactly one root.
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
 
rewriteLopDAG(ArrayList<Lop>) - Method in class org.apache.sysds.lops.rewrite.LopRewriter
 
rewriteLopDAG(DMLProgram) - Method in class org.apache.sysds.parser.DMLTranslator
 
rewriteLopDAGsFunction(FunctionStatementBlock) - Method in class org.apache.sysds.lops.rewrite.LopRewriter
 
rewriteLOPinStatementBlock(StatementBlock) - Method in class org.apache.sysds.lops.rewrite.LopRewriteRule
 
rewriteLOPinStatementBlock(StatementBlock) - Method in class org.apache.sysds.lops.rewrite.RewriteAddBroadcastLop
 
rewriteLOPinStatementBlock(StatementBlock) - Method in class org.apache.sysds.lops.rewrite.RewriteAddChkpointLop
 
rewriteLOPinStatementBlock(StatementBlock) - Method in class org.apache.sysds.lops.rewrite.RewriteAddPrefetchLop
 
rewriteLOPinStatementBlock(StatementBlock) - Method in class org.apache.sysds.lops.rewrite.RewriteFixIDs
 
rewriteLOPinStatementBlocks(List<StatementBlock>) - Method in class org.apache.sysds.lops.rewrite.LopRewriteRule
 
rewriteLOPinStatementBlocks(List<StatementBlock>) - Method in class org.apache.sysds.lops.rewrite.RewriteAddBroadcastLop
 
rewriteLOPinStatementBlocks(List<StatementBlock>) - Method in class org.apache.sysds.lops.rewrite.RewriteAddChkpointLop
 
rewriteLOPinStatementBlocks(List<StatementBlock>) - Method in class org.apache.sysds.lops.rewrite.RewriteAddPrefetchLop
 
rewriteLOPinStatementBlocks(List<StatementBlock>) - Method in class org.apache.sysds.lops.rewrite.RewriteFixIDs
 
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.fedplanner.AFederatedPlanner
Selects a federated execution plan for the given program by setting the forced execution type.
rewriteProgram(DMLProgram, FunctionCallGraph, FunctionCallSizeInfo) - Method in class org.apache.sysds.hops.fedplanner.FederatedPlannerCostbased
 
rewriteProgram(DMLProgram, FunctionCallGraph, FunctionCallSizeInfo) - Method in class org.apache.sysds.hops.fedplanner.FederatedPlannerFedAll
 
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.IPAPassCompressionWorkloadAnalysis
 
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
 
rewriteProgram(DMLProgram, FunctionCallGraph, FunctionCallSizeInfo) - Method in class org.apache.sysds.hops.ipa.IPAPassReplaceEvalFunctionCalls
 
rewriteProgram(DMLProgram, FunctionCallGraph, FunctionCallSizeInfo) - Method in class org.apache.sysds.hops.ipa.IPAPassRewriteFederatedPlan
Estimates cost and selects a federated execution plan by setting the federated output value of each hop in the program.
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
 
rewriteProgramLopDAGs(DMLProgram) - Method in class org.apache.sysds.lops.rewrite.LopRewriter
 
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
 
RewriteRemoveForLoopEmptySequence - Class in org.apache.sysds.hops.rewrite
Rule: Simplify program structure by removing (par)for statements iterating over an empty sequence, i.e., (par)for-loops without a single iteration.
RewriteRemoveForLoopEmptySequence() - Constructor for class org.apache.sysds.hops.rewrite.RewriteRemoveForLoopEmptySequence
 
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(DMLProgram, StatementBlock, Map<String, Hop>) - Method in class org.apache.sysds.hops.fedplanner.FederatedPlannerCostbased
Estimates cost and enumerates federated execution plans in hopRelMemo.
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.RewriteRemoveForLoopEmptySequence
 
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.RewriteRemoveForLoopEmptySequence
 
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(CompressedMatrixBlock, MatrixBlock, double, boolean, boolean, boolean, int) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibRexpand
 
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)
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), the classic example of this operation is one hot encoding of a column to multiple columns.
rexpand(MatrixBlock, MatrixBlock, int, boolean, boolean, boolean, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
CP rexpand operation (single input, single output), the classic example of this operation is one hot encoding of a column to multiple columns.
REXPAND - org.apache.sysds.common.Types.ParamBuiltinOp
 
REXPAND - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ParameterizedBuiltinCode
 
rexpandCols(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Expand the column group to multiple columns.
rexpandCols(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupValue
 
rexpandCols(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
rexpandCols(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
rexpandCols(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
rexpandCols(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
rexpandCols(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
rexpandCols(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
rexpandCols(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
rexpandCols(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
rexpandCols(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Rexpand the dictionary (one hot encode)
rexpandCols(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
rexpandCols(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
rexpandCols(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
rexpandCols(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
rexpandColsWithReference(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Rexpand the dictionary (one hot encode)
rexpandColsWithReference(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
rexpandColsWithReference(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
rexpandColsWithReference(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
rexpandColsWithReference(int, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
rexpandOperations(MatrixBlock, double, boolean, boolean, boolean, int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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(Expression, boolean, ArrayList<Statement>, DMLProgram) - Static method in class org.apache.sysds.parser.StatementBlock
 
rHoistFunctionCallsFromExpressions(StatementBlock, DMLProgram) - Static method in class org.apache.sysds.parser.StatementBlock
 
rHoistFunctionCallsFromExpressions(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
 
RIGHT - org.apache.sysds.lops.AppendM.CacheType
 
RIGHT - org.apache.sysds.lops.GroupedAggregateM.CacheType
 
RIGHT - org.apache.sysds.lops.LeftIndex.LixCacheType
 
RIGHT - org.apache.sysds.lops.MapMult.CacheType
 
RIGHT - org.apache.sysds.lops.MMTSJ.MMTSJType
 
RIGHT_OUTER_PRODUCT - org.apache.sysds.runtime.codegen.SpoofOuterProduct.OutProdType
 
RIGHT_PART - org.apache.sysds.lops.AppendM.CacheType
 
RIGHT_PART - org.apache.sysds.lops.GroupedAggregateM.CacheType
 
RIGHT_PART - org.apache.sysds.lops.MapMult.CacheType
 
RightIndex - Class in org.apache.sysds.lops
 
RightIndex - org.apache.sysds.lops.Lop.Type
 
RightIndex(Lop, Lop, Lop, Lop, Lop, Types.DataType, Types.ValueType, Types.ExecType) - Constructor for class org.apache.sysds.lops.RightIndex
 
RightIndex(Lop, Lop, Lop, Lop, Lop, Types.DataType, Types.ValueType, Types.ExecType, boolean) - Constructor for class org.apache.sysds.lops.RightIndex
 
RightIndex(Lop, Lop, Lop, Lop, Lop, Types.DataType, Types.ValueType, AggBinaryOp.SparkAggType, Types.ExecType) - Constructor for class org.apache.sysds.lops.RightIndex
 
rightMultByMatrix(CompressedMatrixBlock, MatrixBlock, MatrixBlock, int) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibRightMultBy
 
rightMultByMatrix(CompressedMatrixBlock, MatrixBlock, MatrixBlock, int, boolean) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibRightMultBy
 
rightMultByMatrix(MatrixBlock) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Right matrix multiplication with this column group.
rightMultByMatrix(MatrixBlock, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Right matrix multiplication with this column group.
rightMultByMatrix(MatrixBlock, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.ADictBasedColGroup
 
rightMultByMatrix(MatrixBlock, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
rightMultByMatrix(MatrixBlock, IColIndex) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
rightMultByMatrix(MatrixBlock, IColIndex) - 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
 
RLE - org.apache.sysds.runtime.compress.colgroup.AColGroup.CompressionType
 
rlen - Variable in class org.apache.sysds.runtime.io.ReadProperties
 
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.
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 - org.apache.sysds.common.Builtins
 
RMEMPTY - org.apache.sysds.common.Types.ParamBuiltinOp
 
RMEMPTY - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ParameterizedBuiltinCode
 
RMM - org.apache.sysds.hops.AggBinaryOp.MMultMethod
 
RMM - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
RmmSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
ROOT - org.apache.sysds.runtime.compress.workload.AWTreeNode.WTNodeType
 
rootGroupSymbolTableAddress - Variable in class org.apache.sysds.runtime.io.hdf5.H5Superblock
 
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
ROUND - org.apache.sysds.common.Builtins
 
ROUND - org.apache.sysds.common.Types.OpOp1
 
ROUND - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
ROUND - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
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 - org.apache.sysds.common.Types.Direction
 
ROW - org.apache.sysds.hops.codegen.template.TemplateBase.TemplateType
 
ROW - org.apache.sysds.hops.fedplanner.FTypes.AlignType
 
ROW - org.apache.sysds.hops.fedplanner.FTypes.FPartitioning
 
ROW - org.apache.sysds.hops.fedplanner.FTypes.FType
 
ROW_AGG - org.apache.sysds.runtime.codegen.SpoofCellwise.CellType
 
ROW_AGG - org.apache.sysds.runtime.codegen.SpoofRowwise.RowType
 
ROW_BLOCK_WISE - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PDataPartitionFormat
 
ROW_BLOCK_WISE_N - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PDataPartitionFormat
 
ROW_COUNT_DISTINCT - org.apache.sysds.common.Builtins
 
ROW_COUNT_DISTINCT - org.apache.sysds.common.Types.AggOp
 
ROW_COUNTNNZS - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
ROW_DIMS - org.apache.sysds.hops.codegen.SpoofFusedOp.SpoofOutputDimsType
 
ROW_MAXS - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
ROW_MEANS - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
ROW_MINS - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
ROW_RANK_DIMS - org.apache.sysds.hops.codegen.SpoofFusedOp.SpoofOutputDimsType
 
ROW_SUMS - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
ROW_SUMSQS - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
ROW_T - org.apache.sysds.hops.fedplanner.FTypes.AlignType
 
ROW_VECTOR - org.apache.sysds.lops.BinaryM.VectorType
 
ROW_VECTOR_MATRIX - org.apache.sysds.runtime.matrix.data.LibMatrixBincell.BinaryAccessType
 
ROW_WISE - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PDataPartitionFormat
 
ROW_WISE - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
 
ROWBLOCKCOUNTPARAM - Static variable in class org.apache.sysds.parser.DataExpression
 
RowCol - org.apache.sysds.common.Types.Direction
 
rowCount - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.StatisticsOptions
 
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
ROWINDEXMAX - org.apache.sysds.common.Builtins
 
ROWINDEXMIN - org.apache.sysds.common.Builtins
 
RowIterator<T> - Class in org.apache.sysds.runtime.frame.data.iterators
 
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
 
ROWMAX - org.apache.sysds.common.Builtins
 
ROWMAXS_VECTMULT - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
rowMaxsVectMult(double[], double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
 
rowMaxsVectMult(double[], double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
 
ROWMEAN - org.apache.sysds.common.Builtins
 
ROWMIN - org.apache.sysds.common.Builtins
 
rowPointers() - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
Get raw access to underlying array of row pointers For use in GPU code
ROWPROD - org.apache.sysds.common.Builtins
 
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
ROWSD - org.apache.sysds.common.Builtins
 
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
 
rowSum() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Wrapper method for single threaded reduceall-rowSum of a matrix.
rowSum(int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Wrapper method for multi threaded reduceall-rowSum of a matrix.
rowSum(MatrixBlock, int, int, int, int) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibLeftMultBy
 
ROWSUM - org.apache.sysds.common.Builtins
 
rowUpper - Variable in class org.apache.sysds.parser.dml.DmlParser.IndexedExpressionContext
 
ROWVAR - org.apache.sysds.common.Builtins
 
rRecompileProgramBlock2Forced(ProgramBlock, long, HashSet<String>, Types.ExecType) - Static method in class org.apache.sysds.hops.recompile.Recompiler
 
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
Non-recursive equivalent of LineageItemUtils.rReplace(LineageItem, LineageItem, LineageItem) for robustness with regard to stack overflow errors.
rRewriteLop(StatementBlock) - Method in class org.apache.sysds.lops.rewrite.LopRewriter
 
rRewriteLops(ArrayList<StatementBlock>) - Method in class org.apache.sysds.lops.rewrite.LopRewriter
 
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, Types.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
 
RULEBASED - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.POptMode
 
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.monitoring.FederatedMonitoringServer
 
run() - Method in class org.apache.sysds.runtime.controlprogram.parfor.LocalParWorker
 
run() - Method in class org.apache.sysds.runtime.instructions.cp.TriggerBroadcastTask
 
run() - Method in class org.apache.sysds.runtime.instructions.cp.TriggerCheckpointTask
 
run() - Method in class org.apache.sysds.runtime.instructions.cp.TriggerPrefetchTask
 
run() - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUMemoryEviction
 
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, Set<String>, List<ParForStatementBlock.ResultVar>, boolean, int, boolean) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.RemoteParForSpark
 
runMapping() - Method in class org.apache.sysds.runtime.iogen.ReaderMapping
 
RUNTIME - org.apache.sysds.api.mlcontext.MLContext.ExplainLevel
Explain runtime program
RUNTIME - org.apache.sysds.hops.codegen.SpoofCompiler.IntegrationType
 
RUNTIME - org.apache.sysds.hops.fedplanner.FTypes.FederatedPlanner
 
RUNTIME - org.apache.sysds.utils.Explain.ExplainType
 
RUNTIME_METRICS - org.apache.sysds.runtime.controlprogram.parfor.opt.Optimizer.CostModelType
 
RUNTIME_PLAN - org.apache.sysds.runtime.controlprogram.parfor.opt.Optimizer.PlanInputType
 
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

S - Variable in class org.apache.sysds.runtime.iogen.ValueTrimFormat
 
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
 
sameIndexStructure(AColGroupCompressed) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
sameIndexStructure(AColGroupCompressed) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
sameIndexStructure(AColGroupCompressed) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
SAMPLE - org.apache.sysds.common.Builtins
 
SAMPLE - org.apache.sysds.common.Types.OpOpDG
 
SAMPLE_OPCODE - Static variable in class org.apache.sysds.lops.DataGen
 
SampleEstimatorFactory - Interface in org.apache.sysds.runtime.compress.estim.sample
 
SampleEstimatorFactory.EstimationType - Enum in org.apache.sysds.runtime.compress.estim.sample
 
sampleOperations(long, int, boolean, long) - Static method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
samplePower - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
The sampling ratio power to use when choosing sample size.
SampleProperties - Class in org.apache.sysds.runtime.iogen
 
SampleProperties(String) - Constructor for class org.apache.sysds.runtime.iogen.SampleProperties
 
SampleProperties(String, FrameBlock) - Constructor for class org.apache.sysds.runtime.iogen.SampleProperties
 
SampleProperties(String, MatrixBlock) - Constructor for class org.apache.sysds.runtime.iogen.SampleProperties
 
samplingRatio - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
The sampling ratio used when choosing ColGroups.
sanitizeSpaces(String) - Static method in class org.apache.sysds.runtime.transform.TfUtils
 
satisfiesAggressiveCompressionCondition(Hop) - Static method in class org.apache.sysds.hops.rewrite.RewriteCompressedReblock
 
satisfiesCompressionCondition(Hop) - Static method in class org.apache.sysds.hops.rewrite.RewriteCompressedReblock
 
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, boolean, boolean, long, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
 
satisfiesMultiThreadingConstraints(MatrixBlock, 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, MatrixBlock, boolean, boolean, long, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
 
satisfiesMultiThreadingConstraints(MatrixBlock, MatrixBlock, AggregateUnaryOperator, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixAgg
 
satisfiesSizeConstraintsForCompression(Hop) - Static method in class org.apache.sysds.hops.rewrite.RewriteCompressedReblock
 
saveReplaceFilenameThreadID(String, String, String) - Static method in class org.apache.sysds.runtime.util.ProgramConverter
 
SBP - org.apache.sysds.parser.Statement.PSUpdateType
 
sc() - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
Obtain SparkContext from MLContextProxy.
Scalar - org.apache.sysds.lops.Lop.SimpleInstType
 
SCALAR - org.apache.sysds.common.Types.DataType
 
SCALAR - org.apache.sysds.hops.codegen.SpoofFusedOp.SpoofOutputDimsType
 
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.AColGroup
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.ColGroupConst
 
scalarOperation(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
scalarOperation(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
scalarOperation(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
scalarOperation(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
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.ColGroupSDC
 
scalarOperation(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
scalarOperation(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
scalarOperation(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
scalarOperation(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
scalarOperation(ScalarOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
scalarOperations(ScalarOperator, CompressedMatrixBlock, MatrixValue) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibScalar
 
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
 
SCALE - org.apache.sysds.common.Builtins
 
SCALE_BATCH - org.apache.sysds.parser.Statement.PSRuntimeBalancing
 
SCALE_MINMAX - org.apache.sysds.common.Builtins
 
SCALEAPPLY - org.apache.sysds.common.Builtins
 
scaleTuples(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Scale all tuples contained in the dictionary by the scaling factor given in the int list.
scaleTuples(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
scaleTuples(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
scaleTuples(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
scaleTuples(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
scaleTuples(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
SCHEMA_SEPARATOR - Static variable in interface org.apache.sysds.runtime.frame.data.lib.FrameUtil
 
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
 
SD - org.apache.sysds.common.Builtins
 
SDC - org.apache.sysds.runtime.compress.colgroup.AColGroup.CompressionType
 
SDCFOR - org.apache.sysds.runtime.compress.colgroup.AColGroup.CompressionType
 
sdcSortType - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
The sorting type used in sorting/joining offsets to create SDC groups
SEALClient - Class in org.apache.sysds.runtime.controlprogram.paramserv.homomorphicEncryption
 
SEALClient(byte[]) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.homomorphicEncryption.SEALClient
 
SEALServer - Class in org.apache.sysds.runtime.controlprogram.paramserv.homomorphicEncryption
 
SEALServer() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.homomorphicEncryption.SEALServer
 
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.api.DMLOptions
 
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.api.DMLScript
 
SEED - Static variable in class org.apache.sysds.runtime.controlprogram.paramserv.ParamservUtils
 
seekBufferToNextMultipleOfEight(ByteBuffer) - Static method in class org.apache.sysds.runtime.io.hdf5.Utils
 
select(boolean[], int) - Method in class org.apache.sysds.runtime.frame.data.columns.ABooleanArray
 
select(boolean[], int) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Slice out the true indices in the select input and return the sub array.
select(boolean[], int) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
select(boolean[], int) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
select(boolean[], int) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
select(boolean[], int) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
select(boolean[], int) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
select(boolean[], int) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
select(boolean[], int) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
select(boolean[], int) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
select(boolean[], int) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
select(int[]) - Method in class org.apache.sysds.runtime.frame.data.columns.ABooleanArray
 
select(int[]) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Slice out the specified indices and return the sub array.
select(int[]) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
select(int[]) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
select(int[]) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
select(int[]) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
select(int[]) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
select(int[]) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
select(int[]) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
select(int[]) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
select(int[]) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
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
 
SELVARTHRESH - org.apache.sysds.common.Builtins
 
sempred(RuleContext, int, int) - Method in class org.apache.sysds.parser.dml.DmlParser
 
SEQ - org.apache.sysds.common.Builtins
 
SEQ - org.apache.sysds.common.Types.OpOpDG
 
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_RIX - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
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.CompressedMatrixBlock
 
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
 
SERIALIZATION_OPCODE - Static variable in class org.apache.sysds.runtime.lineage.LineageItemUtils
 
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() - Method in class org.apache.sysds.runtime.lineage.Lineage
 
serialize(MatrixBlock) - Method in class org.apache.sysds.runtime.io.BinaryBlockSerialization.MatrixBlockSerializer
 
serializeBlock(CacheBlock<?>) - Method in class org.apache.sysds.runtime.controlprogram.caching.ByteBuffer
 
serializeData(ByteBuffer, CacheBlock<?>) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheMaintenanceService
 
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
 
serializeProgram(Program, ArrayList<ProgramBlock>, 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
 
serializeSingleTrace(CPOperand) - Method in class org.apache.sysds.runtime.lineage.Lineage
 
serializeSingleTrace(LineageItem) - Static method in class org.apache.sysds.runtime.lineage.Lineage
 
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(double) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
 
set(double) - Method in class org.apache.sysds.runtime.data.DenseBlock
Set the given value for the entire dense block (fill).
set(double) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
 
set(double) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
 
set(double, double) - Method in class org.apache.sysds.runtime.instructions.cp.KahanObject
 
set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlock
Set the specified cell to the given value.
set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
 
set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
 
set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
 
set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
 
set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
 
set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
 
set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
 
set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
 
set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
 
set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
 
set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
 
set(int[], double) - Method in class org.apache.sysds.runtime.data.DenseBlockString
 
set(int[], long) - 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.DenseBlockBool
 
set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
 
set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
 
set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
 
set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
 
set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
 
set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
 
set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
 
set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
 
set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
 
set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
 
set(int[], long) - Method in class org.apache.sysds.runtime.data.DenseBlockString
 
set(int[], Object) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
 
set(int[], Object) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
 
set(int[], Object) - Method in class org.apache.sysds.runtime.data.TensorBlock
Set a cell to the value given as an `Object`.
set(int[], String) - 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.DenseBlockBool
 
set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
 
set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
 
set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
 
set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
 
set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
 
set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
 
set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
 
set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
 
set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
 
set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
 
set(int[], String) - Method in class org.apache.sysds.runtime.data.DenseBlockString
 
set(int, boolean) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
set(int, boolean) - Method in class org.apache.sysds.runtime.lineage.BooleanArray32
 
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(int, double) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Set index to given double value (cast to the correct type of this array)
set(int, double) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
set(int, double) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
set(int, double) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
set(int, double) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
set(int, double) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
set(int, double) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
set(int, double) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
set(int, double) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
set(int, double) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
set(int, double[]) - Method in class org.apache.sysds.runtime.data.DenseBlock
Copy the given vector into the given row.
set(int, double[]) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
 
set(int, double[]) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
 
set(int, double[]) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
 
set(int, double[]) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
 
set(int, double[]) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
 
set(int, double[]) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
 
set(int, double[]) - Method in class org.apache.sysds.runtime.data.DenseBlockString
 
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, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Set the index to the value.
set(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
set(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
set(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
set(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
set(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
set(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
set(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue.CellIndex
 
set(int, int, double) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
 
set(int, int, double) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
 
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, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
 
set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
 
set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
 
set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
 
set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
 
set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
 
set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP32
 
set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
 
set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt32
 
set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLInt64
 
set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
 
set(int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockString
 
set(int, int, double) - Method in class org.apache.sysds.runtime.data.SparseBlock
Set the value of a matrix cell (r,c).
set(int, int, double) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
set(int, int, double) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
set(int, int, double) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
 
set(int, int, double) - Method in class org.apache.sysds.runtime.data.TensorBlock
Set a cell in a 2-dimensional tensor.
set(int, int, double) - Method in class org.apache.sysds.runtime.matrix.data.IJV
 
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, int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockDRB
 
set(int, int, int, int, double) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
 
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(int, int, int, int, DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
 
set(int, int, int, int, DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
 
set(int, int, Object) - Method in class org.apache.sysds.runtime.frame.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, String) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
Sets the value in position (r,c), to the input string value, and at the individual arrays, convert to correct type.
set(int, int, Array<Boolean>) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
set(int, int, Array<Boolean>) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
set(int, int, Array<Boolean>, int) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
set(int, int, Array<Boolean>, int) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
set(int, int, Array<Character>) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
set(int, int, Array<Character>, int) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
set(int, int, Array<Double>) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
set(int, int, Array<Double>, int) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
set(int, int, Array<Float>) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
set(int, int, Array<Float>, int) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
set(int, int, Array<Integer>) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
set(int, int, Array<Integer>, int) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
set(int, int, Array<Long>) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
set(int, int, Array<Long>, int) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
set(int, int, Array<String>) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
set(int, int, Array<String>, int) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
set(int, int, Array<T>) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Set range to given arrays value
set(int, int, Array<T>) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
set(int, int, Array<T>, int) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Set range to given arrays value with an offset into other array
set(int, int, Array<T>, int) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
set(int, int, ListObject) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
set(int, Boolean) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
set(int, Boolean) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
set(int, Character) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
set(int, Double) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
set(int, Float) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
set(int, Integer) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
set(int, Long) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
set(int, String) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Set index to the given value of the string parsed.
set(int, String) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
set(int, String) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
set(int, String) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
set(int, String) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
set(int, String) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
set(int, String) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
set(int, String) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
set(int, String) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
set(int, String) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
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, SparseRow, boolean) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
set(int, SparseRow, boolean) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
set(int, SparseRow, boolean) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
 
set(int, Data) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
set(int, Data, LineageItem) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
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(int, T) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Set index to the given value of same type
set(int, T) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
set(long[], int) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
 
set(long[], int) - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
 
set(long[], int, long) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
 
set(long[], int, long) - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
 
set(long, long, int) - 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.DataCharacteristics
 
set(long, long, int, long) - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
 
set(long, long, long, long) - Method in class org.apache.sysds.runtime.util.IndexRange
 
set(Object) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
 
set(Object) - Method in class org.apache.sysds.runtime.data.DataTensorBlock
 
set(Object) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
set(String) - Method in class org.apache.sysds.runtime.data.DenseBlock
Set the given string for the entire dense block (fill).
set(String) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
 
set(String) - Method in class org.apache.sysds.runtime.data.DenseBlockLBool
 
set(String) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
 
set(String) - Method in class org.apache.sysds.runtime.data.DenseBlockString
 
set(String, String, 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, Data, LineageItem) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
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(K, V) - Method in class org.apache.sysds.runtime.matrix.data.Pair
 
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(BasicTensorBlock) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
 
set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlock
Copy the given dense block.
set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockBool
 
set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockFP32
 
set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockFP64
 
set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockInt32
 
set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockInt64
 
set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockLDRB
 
set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockLFP64
 
set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockLString
 
set(DenseBlock) - Method in class org.apache.sysds.runtime.data.DenseBlockString
 
set(TensorIndexes, TensorBlock) - Method in class org.apache.sysds.runtime.data.IndexedTensorBlock
 
set(Array<?>, Array<?>, int, int, int) - Static method in interface org.apache.sysds.runtime.frame.data.columns.ArrayFactory
Set the target array in the range of rl to ru with the src array.
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.data.DenseBlock
Copy the given kahan object sum and correction.
set(KahanObject) - Method in class org.apache.sysds.runtime.instructions.cp.KahanObject
 
set(MatrixBlock) - Method in class org.apache.sysds.runtime.data.BasicTensorBlock
 
set(MatrixBlock) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
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(DataCharacteristics) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
 
set(DataCharacteristics) - Method in class org.apache.sysds.runtime.meta.MatrixCharacteristics
 
set(DataCharacteristics) - Method in class org.apache.sysds.runtime.meta.TensorCharacteristics
 
SET - org.apache.sysds.runtime.controlprogram.parfor.Task.TaskType
 
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
 
setAllNonZeros() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
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
 
setAndGet(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Set the index to the value and get the contained value after.
setAndGet(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
setAndGet(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
setAndGet(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
setAndGet(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
setAndGet(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
setAndGet(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToUByte
 
setAndGet(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
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
 
setAsynchronous(boolean) - Method in class org.apache.sysds.lops.Lop
 
setAtLeastOneError(boolean) - Method in class org.apache.sysds.parser.dml.CustomErrorListener
 
setAtLeastOneWarning(boolean) - Method in class org.apache.sysds.parser.dml.CustomErrorListener
 
setAtPos(int, int, double) - Method in class org.apache.sysds.runtime.data.SparseRowVector
 
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
 
setBinMethod(String) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
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(int) - Method in class org.apache.sysds.hops.Hop
 
setBlocksize(int) - Method in class org.apache.sysds.hops.rewrite.ProgramRewriteStatus
 
setBlocksize(int) - Method in class org.apache.sysds.parser.Identifier
 
setBlocksize(int) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
 
setBlocksize(long) - 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, 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
 
setBody(String) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.Request
 
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(MatrixObject) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
 
setBroadcastHandle(BroadcastObject) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
setBufferedInputStream(BufferedInputStream) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
setBufferedOutputStream(BufferedOutputStream) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
setCache(SoftReference<HashMap<T, Long>>) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Set the cached hashmap cache of this Array allocation, to be used in transformEncode.
setCachedJobConf(JobConf) - Static method in class org.apache.sysds.conf.ConfigurationManager
 
setCacheLineage(LineageItem) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
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() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
 
setCheckPrivacy(boolean) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
 
setCheckPrivacy(boolean) - Static method in class org.apache.sysds.runtime.privacy.PrivacyMonitor
 
setChecksum() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRequest
 
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
 
setClassLoader(ClassLoader) - Static method in class org.apache.sysds.runtime.codegen.CodegenUtils
 
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
 
setCoCodePercentage(double) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
Set the coCode percentage, the effect is different based on the coCoding strategy, but the general effect is that higher values results in more coCoding while lower values result in less.
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
 
setCol(long) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
setColID(int) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
setColList(int[]) - Method in class org.apache.sysds.runtime.transform.encode.LegacyEncoder
 
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, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
setColumnMetadata(int, ColumnMetadata) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
setColumnMetadata(ColumnMetadata[]) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
setColumnName(int, String) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
setColumnNames(String[]) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
setColumnPartitioner(CoCoderFactory.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
 
setCompressedOutput(boolean) - Method in class org.apache.sysds.hops.Hop
 
setCompressedSize(long) - Method in class org.apache.sysds.hops.Hop
 
setCompressedSize(long) - Method in class org.apache.sysds.lops.OutputParameters
 
setCompressedSize(long) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
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
 
setConfigTypes(boolean, CompilerConfig.ConfigType...) - Method in class org.apache.sysds.api.jmlc.Connection
Sets compiler configs.
setConfiguredPlanSelector() - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
 
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) - Method in class org.apache.sysds.runtime.matrix.operators.ScalarOperator
 
setConstant(double, int) - Method in class org.apache.sysds.runtime.matrix.operators.LeftScalarOperator
 
setConstant(double, int) - Method in class org.apache.sysds.runtime.matrix.operators.RightScalarOperator
 
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
 
setContainsRemoteParfor(boolean) - Method in class org.apache.sysds.parser.DMLProgram
 
setContainsSeq(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeCell
 
setContext(HttpRequest) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.Request
 
setCoordinatorHostId(String) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.CoordinatorConnectionModel
 
setCoordinatorName(String) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.EventModel
 
setCostType(CostEstimatorFactory.CostType) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
Set the cost type used for estimating the cost of column groups default is memory based.
setCPCaching(boolean) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
setCtxCreateTime(long) - Static method in class org.apache.sysds.utils.stats.SparkStatistics
 
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(String, CacheableData<?>) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedReadCache
Set the data for the ReadCacheEntry with specified filename.
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
 
setDataLayoutClass(byte) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
setDataLayoutVersion(byte) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
setDataOpType(Types.OpOpData) - Method in class org.apache.sysds.hops.DataOp
 
setDataPartitioner(ParForProgramBlock.PDataPartitioner) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
setDatasetName(String) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
setDataSpaceVersion(byte) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
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
 
setDecompressing() - Method in class org.apache.sysds.runtime.compress.workload.Op
 
setDecompressing() - Method in class org.apache.sysds.runtime.compress.workload.WTreeRoot
 
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
 
setDegreeOfParallelismFixed(boolean) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
setDelim(String) - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesCSV
 
setDelim(String) - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesLIBSVM
 
setDelim(String) - Method in class org.apache.sysds.runtime.meta.MetaDataAll
 
setDenseBlock(DenseBlock) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
setDenseBlock(DenseBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
setDensePointer(Pointer) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
Convenience method to directly set the dense matrix pointer on GPU
setDensifying() - Method in class org.apache.sysds.runtime.compress.workload.Op
 
setDensifying(boolean) - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
setDescription(String) - Method in class org.apache.sysds.runtime.io.FileFormatProperties
 
setDiag(boolean) - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
 
SETDIFF - org.apache.sysds.common.Builtins
 
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(int[]) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
setDimensions(long, long) - Method in class org.apache.sysds.parser.Identifier
 
setDimensions(long, long, long, long) - Method in class org.apache.sysds.lops.OutputParameters
 
setDimensions(long, long, long, long, boolean) - Method in class org.apache.sysds.lops.OutputParameters
 
setDimensions(long, 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, MatrixObject.UpdateType, long) - Method in class org.apache.sysds.lops.OutputParameters
 
setDimensions(OutputParameters) - Method in class org.apache.sysds.lops.OutputParameters
 
setDimensions(DataCharacteristics) - Method in class org.apache.sysds.lops.OutputParameters
 
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(int[]) - Method in class org.apache.sysds.runtime.data.DenseBlock
Set the dimensions of the dense MatrixBlock.
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
 
setDirty(boolean) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
 
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
 
setEstimationType(SampleEstimatorFactory.EstimationType) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
Set the estimation type used for the sampled estimates.
setEstimator(boolean) - Static method in class org.apache.sysds.runtime.lineage.LineageCacheConfig
 
setEstMetaSize(long) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
setEstNumDistincts(int) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
setExecMode(ParForProgramBlock.PExecMode) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
setExecType(Types.ExecType) - Method in class org.apache.sysds.hops.Hop
 
setExecType(Types.ExecType) - Method in class org.apache.sysds.lops.Data
Data-Lop-specific method to set the execution type for persistent write.
setExecType(Types.ExecType) - Method in class org.apache.sysds.lops.Lop
Set the execution type of LOP.
setExecType(Types.ExecType) - Method in class org.apache.sysds.lops.LopProperties
 
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(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.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
 
setFederatedCost(FederatedCost) - Method in class org.apache.sysds.hops.Hop
 
setFederatedDefault() - Method in class org.apache.sysds.parser.DataExpression
 
setFederatedOutput(FEDInstruction.FederatedOutput) - Method in class org.apache.sysds.hops.Hop
 
setFederatedOutput(FEDInstruction.FederatedOutput) - Method in class org.apache.sysds.lops.Lop
 
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.AppendPropagator
 
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.hops.DataOp
 
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.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.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.ProgramBlock
 
setFileName(String) - Method in class org.apache.sysds.hops.DataOp
 
setFileName(String) - Method in class org.apache.sysds.parser.dml.CustomErrorListener.ParseIssue
 
setFileName(String) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
SetFileName - org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
 
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
 
setFillValueVersion(byte) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
setFinalFedouts() - Method in class org.apache.sysds.hops.fedplanner.FederatedPlannerCostbased
Set final fedouts of all hops starting from terminal hops.
setFineGrainedPrivacy(String) - Method in class org.apache.sysds.runtime.meta.MetaDataAll
 
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.
setFirstColIndex(int) - Method in class org.apache.sysds.runtime.iogen.CustomProperties
 
setFirstRowIndex(int) - Method in class org.apache.sysds.runtime.iogen.CustomProperties
 
setFn(IndexFunction) - Method in class org.apache.sysds.runtime.matrix.operators.ReorgOperator
 
setForcedExecType(Types.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
 
setFormatTypeString(String) - Method in class org.apache.sysds.runtime.meta.MetaDataAll
 
setFrame(String, 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>) - 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>) - 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.
setFrameDefault() - Method in class org.apache.sysds.parser.DataExpression
 
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
 
setFromOtherType(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Set range to given arrays value
setFromOtherType(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
setFromOtherType(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
setFromOtherType(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
setFromOtherType(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
setFromOtherType(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
setFromOtherType(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
setFromOtherType(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
setFromOtherType(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
setFromOtherType(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
setFromOtherTypeNz(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Set non default values in the range from the value array given
setFromOtherTypeNz(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
setFromOtherTypeNz(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
setFromOtherTypeNz(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
setFromOtherTypeNz(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
setFromOtherTypeNz(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
setFromOtherTypeNz(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
setFromOtherTypeNz(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
setFromOtherTypeNz(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
setFromOtherTypeNz(int, int, Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
setFromOtherTypeNz(Array<?>) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Set non default values from the value array given
setFType(FTypes.FType) - Method in class org.apache.sysds.hops.cost.HopRel
 
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
 
setGeneratorAPI(SpoofCompiler.GeneratorAPI) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeTpl
 
setGlobalConfig(CompilerConfig) - Static method in class org.apache.sysds.conf.ConfigurationManager
 
setGlobalConfig(DMLConfig) - Static method in class org.apache.sysds.conf.ConfigurationManager
Sets a global configuration as a basis for any thread-local configurations.
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
setGPULineageCacheLimit() - Static method in class org.apache.sysds.runtime.lineage.LineageGPUCacheEviction
Set the max constraint for the lineage cache in GPU
setGPUObject(GPUContext, GPUObject) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
setGPUValue(GPUObject, long) - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
 
setGroupSymbolTableNodeVersion(byte) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
setHasHeader(boolean) - Method in class org.apache.sysds.runtime.meta.MetaDataAll
 
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
 
setHeight(long) - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
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
 
setIndexDelim(String) - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesLIBSVM
 
setIndexes(int[]) - Method in class org.apache.sysds.runtime.data.SparseRowVector
 
setIndexes(long[]) - Method in class org.apache.sysds.runtime.data.TensorIndexes
 
setIndexes(long, long) - Method in class org.apache.sysds.runtime.matrix.data.MatrixIndexes
 
setIndexes(long, long, long) - Method in class org.apache.sysds.runtime.matrix.data.TripleIndexes
 
setIndexes(TensorIndexes) - Method in class org.apache.sysds.runtime.data.TensorIndexes
 
setIndexes(MatrixIndexes) - Method in class org.apache.sysds.runtime.matrix.data.MatrixIndexes
 
setIndexes(TripleIndexes) - Method in class org.apache.sysds.runtime.matrix.data.TripleIndexes
 
setIndexRange(int, int, double[], int[], int, int) - Method in class org.apache.sysds.runtime.data.SparseRowVector
 
setIndexRange(int, int, double[], int, int) - Method in class org.apache.sysds.runtime.data.SparseRowVector
 
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, 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.SparseBlockCSR
 
setIndexRange(int, int, int, double[], int[], int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
 
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) - 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) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
 
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).
setIndices(ArrayList<ArrayList<Expression>>) - Method in class org.apache.sysds.parser.IndexedIdentifier
 
setInfo(List<CompressedSizeInfoColGroup>) - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfo
 
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(int, LineageItem) - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
setInput(String, Hop, boolean) - Method in class org.apache.sysds.hops.DataGenOp
 
setInputBlocksize(long) - Method in class org.apache.sysds.hops.DataOp
 
setInputDefaults(ArrayList<Expression>) - Method in class org.apache.sysds.parser.FunctionStatement
 
setInputParams(ArrayList<DataIdentifier>) - Method in class org.apache.sysds.parser.FunctionStatement
 
setInputTotalCost(double) - Method in class org.apache.sysds.hops.cost.FederatedCost
 
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
 
setInvalid() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedReadCache.ReadCacheEntry
 
setInvalid(String) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedReadCache
Set the ReadCacheEntry of a given filename to invalid.
setIsInSparkInstruction() - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
Inform the compression that it is executed in a spark instruction.
setIsLinCached(boolean) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
 
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
 
setLastIndex(int) - Method in class org.apache.sysds.runtime.iogen.RawRow
 
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(Lineage) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
setLineage(LineageCacheConfig.ReuseCacheType) - Method in class org.apache.sysds.api.mlcontext.MLContext
Set type of lineage-based reuse caching and enable lineage tracing
setLineageCacheCandidate(boolean) - Method in class org.apache.sysds.lops.OutputParameters
 
setLineageCached() - Method in class org.apache.sysds.runtime.instructions.spark.data.LineageObject
 
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(String, LineageItem) - Method in class org.apache.sysds.runtime.lineage.Lineage
 
setLiteral(String, LineageItem) - Method in class org.apache.sysds.runtime.lineage.LineageMap
 
setLiteral(ScalarObject) - Method in class org.apache.sysds.runtime.instructions.cp.CPOperand
 
setLiveIn(VariableSet) - Method in class org.apache.sysds.parser.LiveVariableAnalysis
 
setLiveOut(VariableSet) - Method in class org.apache.sysds.parser.LiveVariableAnalysis
 
setLocalConfig(CompilerConfig) - Static method in class org.apache.sysds.conf.ConfigurationManager
Sets the current thread-local compiler configuration to the given config.
setLocalConfig(DMLConfig) - Static method in class org.apache.sysds.conf.ConfigurationManager
Sets the current thread-local dml 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
 
setLocalHeapVersion(byte) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
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
 
setLogLevel(Level) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.opt.OptimizationWrapper
 
setLops(ArrayList<Lop>) - Method in class org.apache.sysds.parser.StatementBlock
 
setLops(Lop) - Method in class org.apache.sysds.hops.Hop
 
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, Future<MatrixBlock>) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
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
 
setMatrixOutputAndLineage(String, Future<MatrixBlock>, LineageItem) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
setMatrixOutputAndLineage(String, MatrixBlock, LineageItem) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
setMaxCol(long) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
setMaxColGroupCoCode(int) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
Set the maximum number of columns to CoCode together in the CoCoding strategy.
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
 
setMaxRow(long) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
setMaxSampleSize(int) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
Set the maximum sample size to extract from a given matrix, this overrules the sample percentage if the sample percentage extracted is higher than this maximum bound.
setMaxSizes(int[]) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
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
setMemo(MemoTable) - Static method in class org.apache.sysds.utils.Explain
Store memo table for adding additional explain info regarding hops.
setMessage(String) - Method in class org.apache.sysds.parser.dml.CustomErrorListener.ParseIssue
 
setMetaData(String, long, long) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
setMetaData(String, MetaData) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
setMetaData(MetaData) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
setMetaData(MetaData) - Method in class org.apache.sysds.runtime.instructions.cp.Data
 
setMinimumCompressionRatio(double) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
Set the minimum compression ratio to be achieved by the compression.
setMinimumSampleSize(int) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
Set the minimum sample size to extract from a given matrix, this overrules the sample percentage if the sample percentage extracted is lower than this minimum bound.
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.frame.data.columns.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
 
setNames(List<String>) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
setNamespace(String) - Method in class org.apache.sysds.parser.ImportStatement
 
setNaStrings(HashSet<String>) - Method in class org.apache.sysds.runtime.iogen.FastStringTokenizer
 
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
 
setNewID() - Method in class org.apache.sysds.lops.Lop
 
setNewID() - Method in class org.apache.sysds.lops.LopProperties
 
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
 
setNoEmptyBlocks(boolean) - Method in class org.apache.sysds.runtime.meta.DataCharacteristics
 
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
 
setNoSet() - Method in class org.apache.sysds.runtime.iogen.ValueTrimFormat
 
setNumCols(long) - Method in class org.apache.sysds.hops.codegen.cplan.CNode
 
setNumCols(long) - Method in class org.apache.sysds.lops.OutputParameters
 
setNumColumns(int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
setNumColumns(Long) - Method in class org.apache.sysds.api.mlcontext.Metadata
Set the number of columns
setNumDistinct(long) - Method in class org.apache.sysds.runtime.frame.data.columns.ColumnMetadata
 
setNumericLastIndex(int) - Method in class org.apache.sysds.runtime.iogen.RawRow
 
setNumNonZeros(Long) - Method in class org.apache.sysds.api.mlcontext.Metadata
Set the number of non-zero values
setNumPartitions(int, int) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
setNumPathsInPBs(ArrayList<ProgramBlock>, ExecutionContext) - Method in class org.apache.sysds.runtime.lineage.LineageDedupBlock
 
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.
setNumRows(long) - Method in class org.apache.sysds.hops.codegen.cplan.CNode
 
setNumRows(long) - Method in class org.apache.sysds.lops.OutputParameters
 
setNumRows(Long) - Method in class org.apache.sysds.api.mlcontext.Metadata
Set the number of rows
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
 
setNumThreads(int) - Method in class org.apache.sysds.runtime.matrix.operators.MultiThreadedOperator
 
setNumVectorIntermediates(int) - Method in class org.apache.sysds.hops.codegen.cplan.CNodeRow
 
setNz(int, int, Array<Boolean>) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
setNz(int, int, Array<Boolean>) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
setNz(int, int, Array<Character>) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
setNz(int, int, Array<Double>) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
setNz(int, int, Array<Float>) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
setNz(int, int, Array<Integer>) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
setNz(int, int, Array<Long>) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
setNz(int, int, Array<String>) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
setNz(int, int, Array<T>) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Set non default values in the range from the value array given
setNz(int, int, Array<T>) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
setNz(Array<T>) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Set non default values from the value array given
setObjectHeaderVersion(byte) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
setObjectModificationTimeVersion(byte) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
setOff(int) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AIterator
 
setOffset(int) - Method in class org.apache.sysds.runtime.functionobjects.OffsetColumnIndex
 
setOnlineStatus(boolean) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.WorkerModel
 
setOnlyRDD(boolean) - Method in class org.apache.sysds.hops.DataOp
 
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(Builtins) - Method in class org.apache.sysds.parser.ParameterizedBuiltinFunctionExpression
 
setOpCode(Expression.DataOp) - Method in class org.apache.sysds.parser.DataExpression
 
setOptimizationMode(ParForProgramBlock.POptMode) - Method in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
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
 
setOverlapping() - Method in class org.apache.sysds.runtime.compress.workload.Op
 
setOverlapping(boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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(ArrayList<Instruction>) - Method in class org.apache.sysds.runtime.controlprogram.IfProgramBlock
 
setPredicate(ArrayList<Instruction>) - Method in class org.apache.sysds.runtime.controlprogram.WhileProgramBlock
 
setPredicate(ConditionalPredicate) - Method in class org.apache.sysds.parser.WhileStatement
 
setPredicate(Expression) - Method in class org.apache.sysds.parser.ConditionalPredicate
 
setPredicate(IterablePredicate) - Method in class org.apache.sysds.parser.ForStatement
 
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
 
setPriority(int) - Method in class org.apache.sysds.runtime.util.DependencyTask
 
setPrivacy(PrivacyConstraint) - Method in class org.apache.sysds.hops.Hop
 
setPrivacy(PrivacyConstraint) - Method in class org.apache.sysds.parser.Identifier
 
setPrivacy(PrivacyConstraint.PrivacyLevel) - Method in class org.apache.sysds.parser.Identifier
 
setPrivacyConstraint(Lop) - Method in class org.apache.sysds.runtime.instructions.Instruction
 
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(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>, Types.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
 
setPublicKey(long, byte[]) - Static method in class org.apache.sysds.runtime.controlprogram.paramserv.NativeHEHelper
sets the public key and stores it in client
setPublicKey(PublicKey) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.FederatedPSControlThread
 
setPublicKey(PublicKey) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.homomorphicEncryption.SEALClient
sets the public key and stores it in ctx
setRandDefault() - Method in class org.apache.sysds.parser.DataExpression
 
setRank(int) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
setRawLastIndex(int) - Method in class org.apache.sysds.runtime.iogen.RawRow
 
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.
setRDDHandleForVariable(String, RDDObject) - Method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
 
setRDDValue(RDDObject, long) - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
 
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() - Method in class org.apache.sysds.hops.Hop
 
setRequiresCompression(AWTreeNode) - Method in class org.apache.sysds.hops.Hop
 
setRequiresDeCompression() - 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.parser.ParForStatementBlock
 
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
 
setrmVarPending(boolean) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUObject
 
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
 
setRow(long) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
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
 
setSampleFrame(FrameBlock) - Method in class org.apache.sysds.runtime.iogen.SampleProperties
 
setSampleMatrix(MatrixBlock) - Method in class org.apache.sysds.runtime.iogen.SampleProperties
 
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, 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, 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, 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(String) - Method in class org.apache.sysds.runtime.controlprogram.caching.FrameObject
 
setSchema(String) - Method in class org.apache.sysds.runtime.meta.MetaDataAll
 
setSchema(List<Types.ValueType>) - Method in class org.apache.sysds.api.mlcontext.FrameSchema
Set the frame schema
setSchema(Types.ValueType[]) - Method in class org.apache.sysds.runtime.controlprogram.caching.FrameObject
 
setSchema(Types.ValueType[]) - Method in class org.apache.sysds.runtime.frame.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.
setSDCSortType(InsertionSorterFactory.SORT_TYPE) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
Set the sort type to use.
setSealClient(SEALClient) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
 
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
 
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
 
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.compress.CompressedMatrixBlock
 
setSparseBlock(SparseBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
setSparseDelim(boolean) - Method in class org.apache.sysds.runtime.meta.MetaDataAll
 
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
 
setSpecialValueBit(int, boolean) - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
setSpecialValueBits(int) - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
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(AssignmentStatement, boolean) - Method in class org.apache.sysds.parser.StatementBlock
 
setStatementFormatType(OutputStatement, 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
 
setSuperblock(H5Superblock) - Method in class org.apache.sysds.runtime.io.hdf5.H5RootObject
 
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(String) - 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(FTypes.FType) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederationMap
 
setUDFResponse(FederatedUDF, MatrixObject) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
 
setUMMLimit(long) - Static method in class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
 
setUnique(int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Set number of unique values.
setUnoptimizedFunctionCalls(StatementBlock) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
setup(double) - Method in class org.apache.sysds.runtime.controlprogram.paramserv.FederatedPSControlThread
Sets up the federated worker and control thread
setup(double, long) - Method in class org.apache.sysds.runtime.util.PoissonPRNGenerator
 
setupBufferPool(long, boolean) - 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
 
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<AColGroup.CompressionType>) - Method in class org.apache.sysds.runtime.compress.CompressionSettingsBuilder
Set the valid compression strategies used for the compression.
setValue(byte[], long) - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
 
setValue(double) - Method in class org.apache.sysds.parser.DoubleIdentifier
 
setValue(double) - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.Cell
 
setValue(double) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
setValue(int) - Method in class org.apache.sysds.runtime.lineage.BooleanArray32
 
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(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(ArrayList<Expression>) - Method in class org.apache.sysds.parser.ExpressionList
 
setValue(CacheableData<?>) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedReadCache.ReadCacheEntry
 
setValue(ScalarObject, long) - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
 
setValue(MatrixBlock) - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
 
setValue(MatrixBlock, long) - Method in class org.apache.sysds.runtime.lineage.LineageCacheEntry
 
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, 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, 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
 
setVarName(String) - Method in class org.apache.sysds.hops.codegen.cplan.CNode
 
setVarParams(HashMap<String, Expression>) - Method in class org.apache.sysds.parser.DataExpression
 
setVisited() - Method in class org.apache.sysds.hops.codegen.cplan.CNode
 
setVisited() - Method in class org.apache.sysds.hops.Hop
 
setVisited() - Method in class org.apache.sysds.lops.Lop
 
setVisited() - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
setVisited(boolean) - Method in class org.apache.sysds.hops.codegen.cplan.CNode
 
setVisited(boolean) - Method in class org.apache.sysds.hops.Hop
 
setVisited(boolean) - Method in class org.apache.sysds.runtime.lineage.LineageItem
 
setVisited(Lop.VisitStatus) - Method in class org.apache.sysds.lops.Lop
set visit status of node
SETWD - Static variable in class org.apache.sysds.parser.Statement
 
setWeight(double) - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
 
setWriteBufferLimit(long) - Static method in class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
 
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
 
shallowCopyGPUObject(GPUObject, MatrixObject) - Method in class org.apache.sysds.runtime.instructions.gpu.context.GPUContext
Shallow copy the given source GPUObject to a new GPUObject and assign that to the given MatrixObject.
SHARED_READ - org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator.ExcludeType
 
sharedMemBytes - Variable in class org.apache.sysds.runtime.instructions.gpu.context.ExecutionConfig
 
SHERLOCK - org.apache.sysds.common.Builtins
 
SHERLOCKPREDICT - org.apache.sysds.common.Builtins
 
shift(int) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.ArrayIndex
 
shift(int) - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex
Return a new column index where the values are shifted by the specified amount.
shift(int) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.RangeIndex
 
shift(int) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.SingleIndex
 
shift(int) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.TwoIndex
 
shift(long, long) - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedRange
 
shiftCol(int) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
 
shiftCol(int) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
shiftColIndices(int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Shift all column indexes contained by an offset.
shiftCols(int) - Method in class org.apache.sysds.runtime.transform.encode.LegacyEncoder
 
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.
SHLOSSER_JACKKNIFE_ALPHA - Static variable in interface org.apache.sysds.runtime.compress.estim.sample.ShlosserJackknifeEstimator
 
ShlosserEstimator - org.apache.sysds.runtime.compress.estim.sample.SampleEstimatorFactory.EstimationType
 
ShlosserEstimator - Interface in org.apache.sysds.runtime.compress.estim.sample
 
ShlosserJackknifeEstimator - org.apache.sysds.runtime.compress.estim.sample.SampleEstimatorFactory.EstimationType
 
ShlosserJackknifeEstimator - Interface in org.apache.sysds.runtime.compress.estim.sample
 
ShlosserJackknifeEstimator.CriticalValue - Class in org.apache.sysds.runtime.compress.estim.sample
 
SHORTESTPATH - org.apache.sysds.common.Builtins
 
shortToBa(int, byte[], int) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
 
shouldSparsify() - Method in class org.apache.sysds.runtime.compress.cost.ACostEstimate
Ask the cost estimator if it is a good idea to try to sparsify a column group.
shouldSparsify() - Method in class org.apache.sysds.runtime.compress.cost.ComputationCostEstimator
 
shouldSparsify() - Method in class org.apache.sysds.runtime.compress.cost.DistinctCostEstimator
 
shouldSparsify() - Method in class org.apache.sysds.runtime.compress.cost.HybridCostEstimator
 
shouldSparsify() - Method in class org.apache.sysds.runtime.compress.cost.MemoryCostEstimator
 
shouldTryToCompress() - Method in class org.apache.sysds.runtime.compress.cost.CostEstimatorBuilder
 
SHUFFLE - org.apache.sysds.parser.Statement.FederatedPSScheme
 
ShuffleFederatedScheme - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
Shuffle Federated scheme When the parameter server runs in federated mode it cannot pull in the data which is already on the workers.
ShuffleFederatedScheme() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.ShuffleFederatedScheme
 
shutdown() - Method in class org.apache.sysds.runtime.util.CommonThreadPool
 
shutdown() - Method in class org.apache.sysds.runtime.util.DependencyThreadPool
 
shutdownAsyncRDDPool() - Static 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
SIGMOID - org.apache.sysds.common.Builtins
 
SIGMOID - org.apache.sysds.common.Types.OpOp1
 
SIGMOID - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
SIGMOID - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
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
SIGN - org.apache.sysds.common.Builtins
 
SIGN - org.apache.sysds.common.Types.OpOp1
 
SIGN - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
SIGN - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
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
SIN - org.apache.sysds.common.Builtins
 
SIN - org.apache.sysds.common.Types.OpOp1
 
SIN - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
SIN - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
SINGLE - org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex.ColIndexType
 
SINGLE_BLOCK - org.apache.sysds.hops.AggBinaryOp.SparkAggType
 
single_exponential_smoothing(Double[], Double) - Static method in class org.apache.sysds.runtime.util.EMAUtils
 
SINGLE_NODE - org.apache.sysds.common.Types.ExecMode
 
SINGLE_OFFSET - org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory.OFF_TYPE_SPECIALIZATIONS
 
SINGLE_RETURN - org.apache.sysds.common.Types.ReturnType
 
SingleIndex - Class in org.apache.sysds.runtime.compress.colgroup.indexes
 
SingleIndex(int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.indexes.SingleIndex
 
SinglePrecision() - Constructor for class org.apache.sysds.runtime.instructions.gpu.SpoofCUDAInstruction.SinglePrecision
 
SinglePrecisionCudaSupportFunctions - Class in org.apache.sysds.runtime.matrix.data
 
SinglePrecisionCudaSupportFunctions() - Constructor for class org.apache.sysds.runtime.matrix.data.SinglePrecisionCudaSupportFunctions
 
SingletonLookupHashMap - Class in org.apache.sysds.runtime.compress
This class allows sharing of objects across the entire program.
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
SINH - org.apache.sysds.common.Builtins
 
SINH - org.apache.sysds.common.Types.OpOp1
 
SINH - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
SINH - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
SINIT - org.apache.sysds.common.Types.OpOpDG
 
SINIT_OPCODE - Static variable in class org.apache.sysds.lops.DataGen
 
size - Variable in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
 
size - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.DataObjectModel
 
size() - Method in class org.apache.sysds.api.jmlc.ResultVariables
Obtain the number of output data held by this ResultVariables object.
size() - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable
 
size() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.ArrayIndex
 
size() - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex
Get the size of the index aka, how many columns is contained
size() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.RangeIndex
 
size() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.SingleIndex
 
size() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.TwoIndex
 
size() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
The size of the Mapping object, signaling how many value cells are stored in this mapping object.
size() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
size() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
size() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
size() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
size() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
size() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
size() - Method in class org.apache.sysds.runtime.compress.utils.DblArrayCountHashMap
 
size() - Method in class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap
 
size() - Method in class org.apache.sysds.runtime.compress.utils.DoubleCountHashMap
 
size() - Method in class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap
 
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() - Method in class org.apache.sysds.runtime.data.SparseBlock
Get the number of non-zero values in the sparse block.
size() - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
size() - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
size() - 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.frame.data.columns.Array
Get the number of elements in the array, this does not necessarily reflect the current allocated size.
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.matrix.data.sketch.countdistinctapprox.SmallestPriorityQueue
 
size() - Method in class org.apache.sysds.runtime.util.LongLongDoubleHashMap
 
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(int) - Method in class org.apache.sysds.runtime.data.SparseBlock
Get the number of non-zero values in row r.
size(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
size(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
size(int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
 
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) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
size(int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
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.SparseBlock
Get the number of non-zeros values in the row and column range of [rl/cl, ru/cu);
size(int, int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
size(int, int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
size(int, int, int, int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
 
SizeFunction() - Constructor for class org.apache.sysds.runtime.instructions.spark.CompressionSPInstruction.SizeFunction
 
sizeInBytes - Variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNConvolutionAlgorithm
 
sizeOfDataType - Static variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
 
sizeOfLengths - Variable in class org.apache.sysds.runtime.io.hdf5.H5Superblock
 
sizeOfOffsets - Variable in class org.apache.sysds.runtime.io.hdf5.H5Superblock
 
SKEW_SYMMETRIC - org.apache.sysds.runtime.io.FileFormatPropertiesMM.MMSymmetry
 
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
 
skipTo(int) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AIterator
Skip values until index is achieved.
skipTranspose(CNode, Hop, HashMap<Long, CNode>, boolean) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
slice(int) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
slice(int[], TensorBlock) - Method in class org.apache.sysds.runtime.data.TensorBlock
Slice the current block and write into the outBlock.
slice(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.ArrayIndex
 
slice(int, int) - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex
 
slice(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.RangeIndex
 
slice(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.SingleIndex
 
slice(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.TwoIndex
 
slice(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Slice out the range from lower to upper from this map toData.
slice(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
slice(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
slice(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
slice(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
slice(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
slice(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
slice(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
 
slice(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetEmpty
 
slice(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetSingle
 
slice(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetTwo
 
slice(int, int) - 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) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
slice(int, int) - Method in class org.apache.sysds.runtime.frame.data.columns.ABooleanArray
 
slice(int, int) - Method in class org.apache.sysds.runtime.frame.data.columns.Array
Slice out the sub range and return new array with the specified type.
slice(int, int) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
slice(int, int) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
slice(int, int) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
slice(int, int) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
slice(int, int) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
slice(int, int) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
slice(int, int) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
slice(int, int) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
slice(int, int) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
slice(int, int) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
slice(int, int) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
 
slice(int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
slice(int, int, boolean) - 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, boolean) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
slice(int, int, boolean) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
slice(int, int, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
slice(int, int, int, int) - 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) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
slice(int, int, int, int) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
slice(int, int, int, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
slice(int, int, int, int, boolean) - 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, boolean) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
slice(int, int, int, int, boolean) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
slice(int, int, int, int, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
slice(int, int, int, int, boolean, TensorBlock) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
slice(int, int, int, int, boolean, FrameBlock) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
slice(int, int, int, int, boolean, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
slice(int, int, int, int, boolean, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
slice(int, int, int, int, boolean, T) - 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, TensorBlock) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
slice(int, int, int, int, FrameBlock) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
slice(int, int, int, int, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
slice(int, int, int, int, T) - 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(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(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(ArrayList<IndexedMatrixValue>, IndexRange, int, int, int, int, int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
slice(ArrayList<IndexedMatrixValue>, IndexRange, int, int, int, int, int) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
 
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
Slice out up to 4 matrixBlocks that are separated by the row and col Cuts.
slice(ArrayList<Pair<Long, FrameBlock>>, IndexRange, int) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
slice(CompressedMatrixBlock, int, int, int, int, boolean) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibSlice
 
slice(IndexRange, TensorBlock) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
slice(IndexRange, FrameBlock) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
slice(IndexRange, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
slice(IndexRange, T) - 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.
sliceBlocks(CompressedMatrixBlock, int) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibSlice
Slice blocks of compressed matrices from the compressed representation.
sliceColumn(int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Slice out a single column from the column group.
sliceColumns(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Slice out the columns within the range of cl and cu to remove the dictionary values related to these columns.
sliceColumns(CompressedMatrixBlock, int, int) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibSlice
 
SLICEFINDER - org.apache.sysds.common.Builtins
 
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.
sliceOutColumnRange(int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Modify the dictionary by removing columns not within the index range.
sliceOutColumnRange(int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
sliceOutColumnRange(int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
sliceOutColumnRange(int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
sliceOutColumnRange(int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
sliceOutColumnRange(int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
sliceRows(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Slice range of rows out of the column group and return a new column group only containing the row segment.
sliceRows(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
sliceRows(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
sliceRows(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
sliceRows(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
sliceRows(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
sliceRows(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
 
sliceRows(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
 
sliceRows(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
sliceRows(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
sliceRows(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
sliceRows(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
sliceRows(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
sliceRows(int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
SmallestPriorityQueue - Class in org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox
Deceiving name, but is used to contain the k smallest values inserted.
SmallestPriorityQueue(int) - Constructor for class org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox.SmallestPriorityQueue
 
smmdd(FloatBuffer, FloatBuffer, FloatBuffer, int, int, int, int) - Static method in class org.apache.sysds.utils.NativeHelper
 
SmoothedJackknifeEstimator - org.apache.sysds.runtime.compress.estim.sample.SampleEstimatorFactory.EstimationType
 
SmoothedJackknifeEstimator - Interface in org.apache.sysds.runtime.compress.estim.sample
 
SMOTE - org.apache.sysds.common.Builtins
 
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
SOFTMAX - org.apache.sysds.common.Builtins
 
SOFTMAX - org.apache.sysds.common.Types.OpOp1
 
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)
SOLVE - org.apache.sysds.common.Builtins
 
SOLVE - org.apache.sysds.common.Types.OpOp2
 
someConstraintSetBinary(PrivacyConstraint...) - Static method in class org.apache.sysds.runtime.privacy.PrivacyUtils
Returns true if some constraints are set for either of two input privacy constraints.
someConstraintSetUnary(PrivacyConstraint) - Static method in class org.apache.sysds.runtime.privacy.PrivacyUtils
Returns true if the constraint is set for the input privacy constraint.
someInputFederated() - Method in class org.apache.sysds.hops.Hop
 
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() - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
sort() - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
sort() - 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(int) - Method in class org.apache.sysds.runtime.data.SparseBlock
Sort all non-zero value/index pairs of row r column index.
sort(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCOO
 
sort(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
sort(int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
 
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
 
SORT - org.apache.sysds.common.Types.ReOrgOp
 
sort_alpha - Variable in class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierCount
 
SORT_RECODE_MAP - Static variable in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
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.
sortCPRecodeMaps() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
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 - org.apache.sysds.lops.Lop.Type
 
SortKeys(Lop, boolean, SortKeys.OperationTypes, Types.DataType, Types.ValueType, Types.ExecType) - Constructor for class org.apache.sysds.lops.SortKeys
 
SortKeys(Lop, Lop, SortKeys.OperationTypes, Types.DataType, Types.ValueType, Types.ExecType, int) - Constructor for class org.apache.sysds.lops.SortKeys
 
SortKeys(Lop, SortKeys.OperationTypes, Types.DataType, Types.ValueType, Types.ExecType, int) - Constructor for class org.apache.sysds.lops.SortKeys
 
SortKeys.OperationTypes - Enum in org.apache.sysds.lops
 
sortOperations() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
sortOperations(MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
sortOperations(MatrixValue, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
sortOperations(MatrixValue, MatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
sortOperations(MatrixValue, MatrixBlock, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
sortSparseRows() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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.compress.CompressedMatrixBlock
 
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.
sortTuplesByFrequency - 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)
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
 
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_GAlignedAppend - org.apache.sysds.hops.BinaryOp.AppendMethod
 
SP_GLEFTINDEX - org.apache.sysds.hops.LeftIndexingOp.LeftIndexingMethod
 
SP_INST_PREFIX - Static variable in class org.apache.sysds.runtime.instructions.Instruction
 
SP_MLEFTINDEX_L - org.apache.sysds.hops.LeftIndexingOp.LeftIndexingMethod
 
SP_MLEFTINDEX_R - org.apache.sysds.hops.LeftIndexingOp.LeftIndexingMethod
 
SPACE - Static variable in class org.apache.sysds.runtime.util.DMVUtils
 
spark() - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
Obtain SparkSession from MLContextProxy.
SPARK - org.apache.sysds.api.mlcontext.MLContext.ExecutionType
 
SPARK - org.apache.sysds.common.Types.ExecMode
 
SPARK - org.apache.sysds.common.Types.ExecType
 
SPARK - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.ExecType
 
SPARK - org.apache.sysds.runtime.instructions.Instruction.IType
 
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.
SparkParamservUtils - Class in org.apache.sysds.runtime.controlprogram.paramserv
 
SparkParamservUtils() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.SparkParamservUtils
 
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, boolean, HashMap<String, byte[]>, SparkConf, int, LongAccumulator, LongAccumulator, LongAccumulator, LongAccumulator, LongAccumulator, LongAccumulator, LongAccumulator, LongAccumulator, int, boolean) - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.SparkPSWorker
 
SparkStatistics - Class in org.apache.sysds.utils.stats
 
SparkStatistics() - Constructor for class org.apache.sysds.utils.stats.SparkStatistics
 
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 - org.apache.sysds.runtime.controlprogram.parfor.opt.CostEstimator.DataFormat
 
SPARSE_BLOCK - org.apache.sysds.common.Types.BlockType
 
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[], double[], 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[], 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
 
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.
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.
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(int, int) - Constructor for class org.apache.sysds.runtime.data.SparseBlockMCSR
 
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.
SparseEncoding - Class in org.apache.sysds.runtime.compress.estim.encoding
Most common is zero encoding
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
 
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(double[]) - Constructor for class org.apache.sysds.runtime.data.SparseRowVector
Sparse row vector constructor that take a dense array, and allocate sparsely by ignoring zero values
SparseRowVector(int) - Constructor for class org.apache.sysds.runtime.data.SparseRowVector
 
SparseRowVector(int, double[], 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.compress.CompressedMatrixBlock
 
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() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
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.
sparseUnaryOperationsInPlace(UnaryOperator) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
sparseUnaryOperationsInPlace(UnaryOperator) - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
 
sparsifyFOR() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
sparsifyFOR() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
sparsifyFOR(ColGroupDDC) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
sparsifyFOR(ColGroupSDC) - Static method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
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() - Constructor for class org.apache.sysds.runtime.matrix.data.MatrixBlock.SparsityEstimate
 
SparsityEstimate(boolean, long) - 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.
SPLIT - org.apache.sysds.common.Builtins
 
SPLIT_BALANCED - org.apache.sysds.common.Builtins
 
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[]) - 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
 
splitIntoNgrams(int, int) - Method in class org.apache.sysds.runtime.transform.tokenize.DocumentRepresentation
 
splitIntoNgrams(Token, int, int) - Method in class org.apache.sysds.runtime.transform.tokenize.builder.TokenizerBuilderNgram
 
splitRecodeEntry(String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
splitRecodeMapEntry(String) - Static method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
Splits a Recode map entry into its token and code.
splitToTokens(String) - Method in class org.apache.sysds.runtime.transform.tokenize.builder.TokenizerBuilderWhitespaceSplit
 
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.GeneratorAPI - 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
 
SpoofCUDACellwise - Class in org.apache.sysds.runtime.codegen
 
SpoofCUDACellwise(SpoofCellwise.CellType, boolean, boolean, SpoofCellwise.AggOp, int, SpoofCUDAOperator.PrecisionProxy, SpoofCellwise) - Constructor for class org.apache.sysds.runtime.codegen.SpoofCUDACellwise
 
SpoofCUDAInstruction - Class in org.apache.sysds.runtime.instructions.gpu
 
SpoofCUDAInstruction.DoublePrecision - Class in org.apache.sysds.runtime.instructions.gpu
 
SpoofCUDAInstruction.SinglePrecision - Class in org.apache.sysds.runtime.instructions.gpu
 
SpoofCUDAOperator - Interface in org.apache.sysds.runtime.codegen
 
SpoofCUDAOperator.PrecisionProxy - Class in org.apache.sysds.runtime.codegen
 
SpoofCUDARowwise - Class in org.apache.sysds.runtime.codegen
 
SpoofCUDARowwise(SpoofRowwise.RowType, long, boolean, int, int, SpoofCUDAOperator.PrecisionProxy) - Constructor for class org.apache.sysds.runtime.codegen.SpoofCUDARowwise
 
SpoofFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
SpoofFused - Class in org.apache.sysds.lops
 
SpoofFused - org.apache.sysds.lops.Lop.Type
 
SpoofFused - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
SpoofFused - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
SpoofFused - org.apache.sysds.runtime.instructions.gpu.GPUInstruction.GPUINSTRUCTION_TYPE
 
SpoofFused - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
SpoofFused(ArrayList<Lop>, Types.DataType, Types.ValueType, Class<?>, SpoofCompiler.GeneratorAPI, String, int, Types.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<?>, SpoofCompiler.GeneratorAPI, String, 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
 
SPROP - org.apache.sysds.common.Types.OpOp1
 
SPROP - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
SPROP - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
Sql - Class in org.apache.sysds.lops
 
Sql - org.apache.sysds.lops.Lop.Type
 
Sql - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
Sql(HashMap<String, Lop>, Types.DataType, Types.ValueType) - Constructor for class org.apache.sysds.lops.Sql
 
SQL - org.apache.sysds.parser.Expression.DataOp
 
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
 
SQLREAD - org.apache.sysds.common.Types.OpOpData
 
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
SQRT - org.apache.sysds.common.Builtins
 
SQRT - org.apache.sysds.common.Types.OpOp1
 
SQRT - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
SQRT - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
squash(int) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
squash(CompressedMatrixBlock, int) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibSquash
 
SSP - org.apache.sysds.parser.Statement.PSUpdateType
 
STABLE_MARRIAGE - org.apache.sysds.common.Builtins
 
stages - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.EventModel
 
StagingFileUtils - Class in org.apache.sysds.runtime.controlprogram.parfor.util
 
StagingFileUtils() - Constructor for class org.apache.sysds.runtime.controlprogram.parfor.util.StagingFileUtils
 
StandardJava - org.apache.sysds.utils.Hash.HashType
 
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
 
startEnumerationTimer() - Static method in class org.apache.sysds.hops.fedplanner.FederatedCompilationTimer
 
startPrivFetchTimer(long) - Static method in class org.apache.sysds.hops.fedplanner.FederatedCompilationTimer
 
startPrivProcessTimer() - Static method in class org.apache.sysds.hops.fedplanner.FederatedCompilationTimer
 
startRunTimer() - Static method in class org.apache.sysds.utils.Statistics
Starts the timer, should be invoked immediately before invoking Program.execute()
startSelectPlanTimer() - Static method in class org.apache.sysds.hops.fedplanner.FederatedCompilationTimer
 
startTime - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.EventStageModel
 
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 - Variable in class org.apache.sysds.parser.dml.DmlParser.IfStatementContext
 
statement - Variable in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
 
statement - Variable in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
 
statement - Variable in class org.apache.sysds.parser.dml.DmlParser.ProgramrootContext
 
statement - Variable in class org.apache.sysds.parser.dml.DmlParser.WhileStatementContext
 
statement() - Method in class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
 
statement() - Method in class org.apache.sysds.parser.dml.DmlParser.IfStatementContext
 
statement() - Method in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
 
statement() - Method in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
 
statement() - Method in class org.apache.sysds.parser.dml.DmlParser.ProgramrootContext
 
statement() - Method in class org.apache.sysds.parser.dml.DmlParser
 
statement() - Method in class org.apache.sysds.parser.dml.DmlParser.WhileStatementContext
 
statement(int) - Method in class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
 
statement(int) - Method in class org.apache.sysds.parser.dml.DmlParser.IfStatementContext
 
statement(int) - Method in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
 
statement(int) - Method in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
 
statement(int) - Method in class org.apache.sysds.parser.dml.DmlParser.ProgramrootContext
 
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.FederatedPSScheme - Enum in org.apache.sysds.parser
 
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.PSRuntimeBalancing - 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() - Constructor for class org.apache.sysds.parser.dml.DmlParser.StatementContext
 
StatementContext(ParserRuleContext, int) - 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
 
STATIC - org.apache.sysds.hops.cost.CostEstimationWrapper.CostType
 
STATIC - org.apache.sysds.runtime.compress.cocode.CoCoderFactory.PartitionerType
 
STATIC - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PTaskPartitioner
 
STATIC_HEADER_SIZE - Static variable in class org.apache.sysds.runtime.io.hdf5.H5Constants
 
STATIC_MEM_METRIC - org.apache.sysds.runtime.controlprogram.parfor.opt.Optimizer.CostModelType
 
STATIC_MEMORY_MANAGER - org.apache.sysds.hops.OptimizerUtils.MemoryManager
 
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() - 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 - Static variable in class org.apache.sysds.api.DMLScript
 
STATISTICS_COUNT - Static variable in class org.apache.sysds.api.DMLScript
 
STATISTICS_MAX_WRAP_LEN - Static variable in class org.apache.sysds.api.DMLScript
 
StatisticsController - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers
 
StatisticsController() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.StatisticsController
 
StatisticsModel - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.models
 
StatisticsModel() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.StatisticsModel
 
StatisticsModel(List<UtilizationModel>, List<TrafficModel>, List<EventModel>, List<DataObjectModel>, List<RequestModel>, List<HeavyHitterModel>) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.StatisticsModel
 
StatisticsOptions - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.models
 
StatisticsOptions() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.StatisticsOptions
 
StatisticsService - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.services
 
StatisticsService() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.StatisticsService
 
stats - Variable in class org.apache.sysds.api.DMLOptions
 
stats() - Method in class org.apache.sysds.runtime.compress.cocode.Memorizer
 
STATS_MAX_WRAP_LEN - Static variable in class org.apache.sysds.conf.DMLConfig
 
statsCount - Variable in class org.apache.sysds.api.DMLOptions
 
STATSNA - org.apache.sysds.common.Builtins
 
stem(String) - Static method in class org.apache.sysds.runtime.util.PorterStemmer
 
STEPLM - org.apache.sysds.common.Builtins
 
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.
STOP - org.apache.sysds.common.Types.OpOp1
 
STOP - org.apache.sysds.parser.PrintStatement.PRINTTYPE
 
STOP - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
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.
STOPBACKGROUNDEVICTION - Static variable in class org.apache.sysds.runtime.lineage.LineageCacheConfig
 
stopCompileTimer() - Static method in class org.apache.sysds.utils.Statistics
 
stopEnumerationTimer() - Static method in class org.apache.sysds.hops.fedplanner.FederatedCompilationTimer
 
stopEstimator(List<DataIdentifier>, LineageItem[], String) - Static method in class org.apache.sysds.runtime.lineage.LineageEstimator
 
stopPrivProcessTimer() - Static method in class org.apache.sysds.hops.fedplanner.FederatedCompilationTimer
 
stopRunTimer() - Static method in class org.apache.sysds.utils.Statistics
Stops the timer, should be invoked immediately after invoking Program.execute()
stopSelectPlanTimer() - Static method in class org.apache.sysds.hops.fedplanner.FederatedCompilationTimer
 
stopTime() - Method in class org.apache.sysds.hops.fedplanner.FederatedCompilationTimer.TimeEntry
 
STRATSTATS - org.apache.sysds.common.Builtins
 
stream - Variable in class org.apache.sysds.runtime.instructions.gpu.context.ExecutionConfig
 
strictParameterizedExpression - Variable 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.ForStatementContext
 
strictParameterizedExpression() - Method in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
 
strictParameterizedExpression() - Method in class org.apache.sysds.parser.dml.DmlParser
 
strictParameterizedExpression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.ForStatementContext
 
strictParameterizedExpression(int) - Method in class org.apache.sysds.parser.dml.DmlParser.ParForStatementContext
 
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() - Method in class org.apache.sysds.parser.dml.DmlParser
 
strictParameterizedKeyValueString(int) - Method in class org.apache.sysds.parser.dml.DmlParser.ExternalFunctionDefExpressionContext
 
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 - org.apache.sysds.common.Types.ValueType
 
STRING - org.apache.sysds.runtime.frame.data.columns.ArrayFactory.FrameArrayType
 
STRING - org.apache.sysds.runtime.instructions.cp.AppendCPInstruction.AppendType
 
STRING - Static variable in class org.apache.sysds.parser.dml.DmlLexer
 
STRING - Static variable in class org.apache.sysds.parser.dml.DmlParser
 
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_VALUE_TYPE - Static variable in class org.apache.sysds.parser.Statement
 
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
 
StringArray - Class in org.apache.sysds.runtime.frame.data.columns
 
StringArray(String[]) - Constructor for class org.apache.sysds.runtime.frame.data.columns.StringArray
 
stringArrayCost(String[]) - Static method in class org.apache.sysds.utils.MemoryEstimates
Get the worst case memory usage of an array containing strings.
stringCost(long) - Static method in class org.apache.sysds.utils.MemoryEstimates
Get the worst case memory usage of a single string, assuming given length.
stringCost(String) - Static method in class org.apache.sysds.utils.MemoryEstimates
Get the worst case memory usage of a single string.
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
 
StringInit - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
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
 
StringRowIterator - Class in org.apache.sysds.runtime.frame.data.iterators
 
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
 
stringToValueType(String[]) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
Generates a ValueType array from a String array
stripThreadCount(String) - Static method in class org.apache.sysds.runtime.instructions.InstructionUtils
 
STRUCTURAL_PRUNING - Static variable in class org.apache.sysds.hops.codegen.opt.PlanSelectionFuseCostBasedV2
 
submit(Runnable) - Method in class org.apache.sysds.runtime.util.CommonThreadPool
 
submit(Runnable, T) - Method in class org.apache.sysds.runtime.util.CommonThreadPool
 
submit(Callable<T>) - Method in class org.apache.sysds.runtime.util.CommonThreadPool
 
submitAll(List<? extends Callable<?>>, List<List<? extends Callable<?>>>) - Method in class org.apache.sysds.runtime.util.DependencyThreadPool
 
submitAll(List<DependencyTask<?>>) - Method in class org.apache.sysds.runtime.util.DependencyThreadPool
 
submitAllAndWait(List<DependencyTask<?>>) - Method in class org.apache.sysds.runtime.util.DependencyThreadPool
 
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.EncoderMVImpute
 
subRangeEncoder(IndexRange) - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
 
subRangeEncoder(IndexRange) - Method in class org.apache.sysds.runtime.transform.encode.LegacyEncoder
Returns a new Encoder that only handles a sub range of columns.
subRangeEncoder(IndexRange) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
subRangeEncoder(IndexRange, Class<T>) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
SUBSAMPLE_TO_MIN - org.apache.sysds.parser.Statement.FederatedPSScheme
 
SubsampleToMinFederatedScheme - Class in org.apache.sysds.runtime.controlprogram.paramserv.dp
Subsample to Min Federated scheme When the parameter server runs in federated mode it cannot pull in the data which is already on the workers.
SubsampleToMinFederatedScheme() - Constructor for class org.apache.sysds.runtime.controlprogram.paramserv.dp.SubsampleToMinFederatedScheme
 
subsumes(CPlanMemoTable.MemoTableEntry) - Method in class org.apache.sysds.hops.codegen.template.CPlanMemoTable.MemoTableEntry
 
SubToken(String, long) - Constructor for class org.apache.sysds.runtime.transform.tokenize.Token.SubToken
 
SUBTRACT_NZ - org.apache.sysds.common.Types.OpOp1
 
subtractDefaultTuple() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
subtractTuple(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Allocate a new dictionary where the tuple given is subtracted from all tuples in the previous dictionary.
subtractTuple(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
subtractTuple(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
subtractTuple(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
subtractTuple(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
SUCCESS - org.apache.sysds.runtime.controlprogram.federated.FederatedResponse.ResponseType
 
SUCCESS - org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcResponse.Type
 
SUCCESS_EMPTY - org.apache.sysds.runtime.controlprogram.federated.FederatedResponse.ResponseType
 
SUCCESS_EMPTY - org.apache.sysds.runtime.controlprogram.paramserv.rpc.PSRpcResponse.Type
 
SUCCESSFULLY_LOADED_NATIVE_BLAS_AND_IN_USE - org.apache.sysds.utils.NativeHelper.NativeBlasState
 
SUCCESSFULLY_LOADED_NATIVE_BLAS_AND_NOT_IN_USE - org.apache.sysds.utils.NativeHelper.NativeBlasState
 
sum() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
sum() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Wrapper method for reduceall-sum of a matrix.
sum(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Get the sum of the values contained in the dictionary
sum(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
sum(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
sum(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
sum(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
sum(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
SUM - org.apache.sysds.common.Builtins
 
SUM - org.apache.sysds.common.Types.AggOp
 
SUM - org.apache.sysds.runtime.codegen.SpoofCellwise.AggOp
 
SUM - org.apache.sysds.runtime.matrix.operators.CMOperator.AggregateOperationTypes
 
SUM_PROD - org.apache.sysds.common.Types.AggOp
 
SUM_SQ - org.apache.sysds.common.Types.AggOp
 
SUM_SQ - org.apache.sysds.runtime.codegen.SpoofCellwise.AggOp
 
sumAllRowsToDouble(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Method used as a pre-aggregate of each tuple in the dictionary, to single double values.
sumAllRowsToDouble(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
sumAllRowsToDouble(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
sumAllRowsToDouble(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
sumAllRowsToDouble(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
sumAllRowsToDouble(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
sumAllRowsToDoubleSq(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Method used as a pre-aggregate of each tuple in the dictionary, to single double values.
sumAllRowsToDoubleSq(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
sumAllRowsToDoubleSq(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
sumAllRowsToDoubleSq(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
sumAllRowsToDoubleSq(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
sumAllRowsToDoubleSq(int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
sumAllRowsToDoubleSqWithDefault(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Method used as a pre-aggregate of each tuple in the dictionary, to single double values.
sumAllRowsToDoubleSqWithDefault(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
sumAllRowsToDoubleSqWithDefault(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
sumAllRowsToDoubleSqWithDefault(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
sumAllRowsToDoubleSqWithDefault(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
sumAllRowsToDoubleSqWithReference(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Method used as a pre-aggregate of each tuple in the dictionary, to single double values.
sumAllRowsToDoubleSqWithReference(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
sumAllRowsToDoubleSqWithReference(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
sumAllRowsToDoubleSqWithReference(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
sumAllRowsToDoubleSqWithReference(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
sumAllRowsToDoubleWithDefault(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Do exactly the same as the sumAllRowsToDouble but also sum the array given to a extra index in the end of the array.
sumAllRowsToDoubleWithDefault(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
sumAllRowsToDoubleWithDefault(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
sumAllRowsToDoubleWithDefault(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
sumAllRowsToDoubleWithDefault(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
sumAllRowsToDoubleWithDefault(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
sumAllRowsToDoubleWithReference(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Method used as a pre-aggregate of each tuple in the dictionary, to single double values with a reference.
sumAllRowsToDoubleWithReference(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
sumAllRowsToDoubleWithReference(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
sumAllRowsToDoubleWithReference(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
sumAllRowsToDoubleWithReference(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
sumAllRowsToDoubleWithReference(double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
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
 
sumNonZeros(Future<FederatedResponse>[]) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
sumRowWithReference(int, int, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
sumSq() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
sumSq() - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
Wrapper method for reduceall-sumSq of a matrix.
sumSq(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Get the square sum of the values contained in the dictionary
sumSq(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
sumSq(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
sumSq(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
sumSq(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
sumSq(int[], int) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
sumSqWithReference(int[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Get the square sum of the values contained in the dictionary with a reference offset on each value.
sumSqWithReference(int[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
sumSqWithReference(int[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
sumSqWithReference(int[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
sumSqWithReference(int[], double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
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.compress.CompressedMatrixBlock
 
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
 
SVD - org.apache.sysds.common.Builtins
 
SVD - org.apache.sysds.common.Types.OpOp1
 
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
 
SYMBOL_TABLE_MESSAGE - Static variable in class org.apache.sysds.runtime.io.hdf5.H5Constants
 
SYMMETRIC - org.apache.sysds.runtime.io.FileFormatPropertiesMM.MMSymmetry
 
SYMMETRICDIFFERENCE - org.apache.sysds.common.Builtins
 
SYNCHRONIZE_GPU - Static variable in class org.apache.sysds.api.DMLScript
 
SYNCHRONIZE_GPU - Static variable in class org.apache.sysds.conf.DMLConfig
 
syncWorkerStatisticsWithDB(StatisticsModel, Long) - Static method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.WorkerService
 
syntacticalPatternDiscovery(FrameBlock, double, String) - Static method in class org.apache.sysds.runtime.util.DMVUtils
 
SYNTAX_ERROR - org.apache.sysds.parser.dml.CustomErrorListener.ParseIssueType
 
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

T - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ProbabilityDistributionCode
 
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
 
TABLE - org.apache.sysds.common.Builtins
 
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
TAN - org.apache.sysds.common.Builtins
 
TAN - org.apache.sysds.common.Types.OpOp1
 
TAN - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
TAN - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
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
TANH - org.apache.sysds.common.Builtins
 
TANH - org.apache.sysds.common.Types.OpOp1
 
TANH - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
TANH - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
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_PARTITIONER - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.ParamType
 
TASK_PARTITIONER - Static variable in class org.apache.sysds.parser.ParForStatementBlock
 
TASK_SIZE - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.ParamType
 
TASK_SIZE - Static variable in class org.apache.sysds.parser.ParForStatementBlock
 
Task.TaskType - Enum in org.apache.sysds.runtime.controlprogram.parfor
 
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
 
teardown() - Method in class org.apache.sysds.runtime.controlprogram.paramserv.FederatedPSControlThread
cleans up the execution context of the federated worker
TEMPLATE_CHANGE - org.apache.sysds.hops.codegen.opt.InterestingPoint.DecisionType
 
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
 
TENSOR - org.apache.sysds.common.Types.DataType
 
TENSOR - org.apache.sysds.parser.Expression.DataOp
 
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(double) - Constructor for class org.apache.sysds.runtime.data.TensorBlock
Create a [1,1] basic FP64 TensorBlock containing the given value.
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 data TensorBlock with the given schema and the given dimensions.
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(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[], int) - Constructor for class org.apache.sysds.runtime.meta.TensorCharacteristics
 
TensorCharacteristics(long[], int, long) - Constructor for class org.apache.sysds.runtime.meta.TensorCharacteristics
 
TensorCharacteristics(long[], 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(String, MetaData) - 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(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
 
tercellOp(MatrixBlock, MatrixBlock, MatrixBlock, MatrixBlock, TernaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixTercell
 
Ternary - Class in org.apache.sysds.hops.codegen.cplan.cuda
 
Ternary - Class in org.apache.sysds.hops.codegen.cplan.java
 
Ternary - Class in org.apache.sysds.lops
Lop to perform Sum of a matrix with another matrix multiplied by Scalar.
Ternary - org.apache.sysds.lops.Lop.Type
 
Ternary - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
Ternary - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
Ternary - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
Ternary() - Constructor for class org.apache.sysds.hops.codegen.cplan.cuda.Ternary
 
Ternary() - Constructor for class org.apache.sysds.hops.codegen.cplan.java.Ternary
 
Ternary(Types.OpOp3, Lop, Lop, Lop, Types.DataType, Types.ValueType, Types.ExecType, int) - Constructor for class org.apache.sysds.lops.Ternary
 
TernaryAggregate - Class in org.apache.sysds.lops
 
TernaryAggregate - org.apache.sysds.lops.Lop.Type
 
TernaryAggregate(Lop, Lop, Lop, Types.AggOp, Types.OpOp2, Types.Direction, Types.DataType, Types.ValueType, Types.ExecType, int) - Constructor for class org.apache.sysds.lops.TernaryAggregate
 
TernaryCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
TernaryFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
TernaryFrameScalarCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
TernaryFrameScalarFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
TernaryFrameScalarSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
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, Hop) - Constructor for class org.apache.sysds.hops.TernaryOp
 
ternaryOperations(TernaryOperator, MatrixBlock, MatrixBlock, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
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, int) - 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
 
TEXT - org.apache.sysds.common.Types.FileFormat
 
TEXT_TO_MATRIX_CELL - org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtilsExt.RDDConverterTypes
 
TextCellInputOutputInfo - Static variable in class org.apache.sysds.runtime.io.InputOutputInfo
 
textCellToBinaryBlock(JavaSparkContext, JavaPairRDD<LongWritable, Text>, DataCharacteristics, boolean, FileFormatPropertiesMM) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.RDDConverterUtils
 
textCellToBinaryBlock(JavaSparkContext, JavaPairRDD<LongWritable, Text>, DataCharacteristics, Types.ValueType[]) - Static method in class org.apache.sysds.runtime.instructions.spark.utils.FrameRDDConverterUtils
 
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 - org.apache.sysds.common.Builtins
 
TIME - org.apache.sysds.common.Types.OpOpDG
 
TIME_OPCODE - Static variable in class org.apache.sysds.lops.DataGen
 
TimeEntry(String) - Constructor for class org.apache.sysds.hops.fedplanner.FederatedCompilationTimer.TimeEntry
 
timestamp - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.TrafficModel
 
timestamp - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.UtilizationModel
 
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
 
TO_ONE_HOT - org.apache.sysds.common.Builtins
 
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
 
toBuffer() - Method in class org.apache.sysds.runtime.io.hdf5.H5BTree
 
toBuffer() - Method in class org.apache.sysds.runtime.io.hdf5.H5ObjectHeader
 
toBuffer(H5BufferBuilder) - Method in class org.apache.sysds.runtime.io.hdf5.H5BTree
 
toBuffer(H5BufferBuilder) - Method in class org.apache.sysds.runtime.io.hdf5.H5DoubleDataType
 
toBuffer(H5BufferBuilder) - Method in class org.apache.sysds.runtime.io.hdf5.H5GroupSymbolTableNode
 
toBuffer(H5BufferBuilder) - Method in class org.apache.sysds.runtime.io.hdf5.H5LocalHeap
 
toBuffer(H5BufferBuilder) - Method in class org.apache.sysds.runtime.io.hdf5.H5ObjectHeader
 
toBuffer(H5BufferBuilder) - Method in class org.apache.sysds.runtime.io.hdf5.H5Superblock
 
toBuffer(H5BufferBuilder) - Method in class org.apache.sysds.runtime.io.hdf5.H5SymbolTableEntry
 
toBuffer(H5BufferBuilder) - Method in class org.apache.sysds.runtime.io.hdf5.message.H5DataLayoutMessage
 
toBuffer(H5BufferBuilder) - Method in class org.apache.sysds.runtime.io.hdf5.message.H5DataSpaceMessage
 
toBuffer(H5BufferBuilder) - Method in class org.apache.sysds.runtime.io.hdf5.message.H5DataTypeMessage
 
toBuffer(H5BufferBuilder) - Method in class org.apache.sysds.runtime.io.hdf5.message.H5FillValueMessage
 
toBuffer(H5BufferBuilder) - Method in class org.apache.sysds.runtime.io.hdf5.message.H5NilMessage
 
toBuffer(H5BufferBuilder) - Method in class org.apache.sysds.runtime.io.hdf5.message.H5ObjectModificationTimeMessage
 
toBuffer(H5BufferBuilder) - Method in class org.apache.sysds.runtime.io.hdf5.message.H5SymbolTableMessage
 
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(int[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
 
toDouble(long[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
 
toDouble(String[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
 
toDouble(BitSet, int) - 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(JavaPairRDD<Long, FrameBlock>, Types.ValueType[], int, int) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
 
toFrameBlock(RDDObject, 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(MatrixIndexes, MatrixBlock) - 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
 
toIndexedTensorBlock(TensorIndexes, TensorBlock) - 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
 
toInputStream(String) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
 
toInt(double) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
toInt(double[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
 
toInt(long) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
 
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.
Token - Class in org.apache.sysds.runtime.transform.tokenize
 
Token(String, long) - Constructor for class org.apache.sysds.runtime.transform.tokenize.Token
 
Token(List<String>, List<Long>) - Constructor for class org.apache.sysds.runtime.transform.tokenize.Token
 
Token(List<Token>) - Constructor for class org.apache.sysds.runtime.transform.tokenize.Token
 
Token.SubToken - Class in org.apache.sysds.runtime.transform.tokenize
 
tokenize(String) - Method in class org.apache.sysds.runtime.lineage.LineageTokenizer
 
tokenize(FrameBlock) - Method in class org.apache.sysds.runtime.transform.tokenize.Tokenizer
 
tokenize(FrameBlock, int) - Method in class org.apache.sysds.runtime.transform.tokenize.Tokenizer
 
TOKENIZE - org.apache.sysds.common.Builtins
 
TOKENIZE - org.apache.sysds.common.Types.ParamBuiltinOp
 
TOKENIZE - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ParameterizedBuiltinCode
 
TOKENIZE_NUM_BLOCKS - Static variable in class org.apache.sysds.runtime.transform.tokenize.Tokenizer
 
Tokenizer - Class in org.apache.sysds.runtime.transform.tokenize
 
TokenizerApplier - Class in org.apache.sysds.runtime.transform.tokenize.applier
 
TokenizerApplier(int, int, boolean, boolean) - Constructor for class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplier
 
TokenizerApplierCount - Class in org.apache.sysds.runtime.transform.tokenize.applier
 
TokenizerApplierCount(int, int, boolean, boolean, JSONObject) - Constructor for class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierCount
 
TokenizerApplierHash - Class in org.apache.sysds.runtime.transform.tokenize.applier
 
TokenizerApplierHash(int, int, boolean, boolean, JSONObject) - Constructor for class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierHash
 
TokenizerApplierPosition - Class in org.apache.sysds.runtime.transform.tokenize.applier
 
TokenizerApplierPosition(int, int, boolean, boolean) - Constructor for class org.apache.sysds.runtime.transform.tokenize.applier.TokenizerApplierPosition
 
TokenizerBuilder - Class in org.apache.sysds.runtime.transform.tokenize.builder
 
TokenizerBuilder() - Constructor for class org.apache.sysds.runtime.transform.tokenize.builder.TokenizerBuilder
 
TokenizerBuilderNgram - Class in org.apache.sysds.runtime.transform.tokenize.builder
 
TokenizerBuilderNgram(int[], int, JSONObject) - Constructor for class org.apache.sysds.runtime.transform.tokenize.builder.TokenizerBuilderNgram
 
TokenizerBuilderWhitespaceSplit - Class in org.apache.sysds.runtime.transform.tokenize.builder
 
TokenizerBuilderWhitespaceSplit(int[], int, JSONObject) - Constructor for class org.apache.sysds.runtime.transform.tokenize.builder.TokenizerBuilderWhitespaceSplit
 
TokenizerFactory - Class in org.apache.sysds.runtime.transform.tokenize
 
TokenizerFactory() - Constructor for class org.apache.sysds.runtime.transform.tokenize.TokenizerFactory
 
tokenNames - Static variable in class org.apache.sysds.parser.dml.DmlLexer
Deprecated.
Use DmlLexer.VOCABULARY instead.
tokenNames - Static variable in class org.apache.sysds.parser.dml.DmlParser
Deprecated.
tokens - Variable in class org.apache.sysds.runtime.transform.tokenize.DocumentRepresentation
 
toLong(double) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
toLong(double[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
 
toMatrixBlock() - Method in class org.apache.sysds.api.mlcontext.Matrix
Obtain the matrix as a MatrixBlock
toMatrixBlock(int, int) - Method in class org.apache.sysds.runtime.matrix.data.CTableMap
 
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(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(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(RDDObject, int, int, long) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
 
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
 
TOMEKLINK - org.apache.sysds.common.Builtins
 
toMillis(String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
toMillis(String, 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
 
TOPK_CLEANING - org.apache.sysds.common.Builtins
 
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.CompressedMatrixBlock
 
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.frame.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.FederatedCost
 
toString() - Method in class org.apache.sysds.hops.cost.HopRel
 
toString() - Method in class org.apache.sysds.hops.cost.VarStats
 
toString() - Method in class org.apache.sysds.hops.fedplanner.MemoTable
 
toString() - Method in class org.apache.sysds.hops.FunctionOp
 
toString() - Method in class org.apache.sysds.hops.Hop
 
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.DeCompression
 
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.Local
 
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.FunctionDictionary
 
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.bitmap.ABitmap
 
toString() - Method in class org.apache.sysds.runtime.compress.cocode.Memorizer
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupValue
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.ArrayIndex
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex.SliceResult
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.RangeIndex
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.SingleIndex
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.TwoIndex
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AIterator
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset.OffsetSliceInfo
 
toString() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
 
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.cost.ACostEstimate
 
toString() - Method in class org.apache.sysds.runtime.compress.cost.ComputationCostEstimator
 
toString() - Method in class org.apache.sysds.runtime.compress.cost.CostEstimatorBuilder
 
toString() - Method in class org.apache.sysds.runtime.compress.cost.InstructionTypeCounter
 
toString() - Method in class org.apache.sysds.runtime.compress.estim.AComEst
 
toString() - Method in class org.apache.sysds.runtime.compress.estim.ComEstSample
 
toString() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfo
 
toString() - Method in class org.apache.sysds.runtime.compress.estim.CompressedSizeInfoColGroup
 
toString() - Method in class org.apache.sysds.runtime.compress.estim.encoding.ConstEncoding
 
toString() - Method in class org.apache.sysds.runtime.compress.estim.encoding.DenseEncoding
 
toString() - Method in class org.apache.sysds.runtime.compress.estim.encoding.EmptyEncoding
 
toString() - Method in class org.apache.sysds.runtime.compress.estim.encoding.SparseEncoding
 
toString() - Method in class org.apache.sysds.runtime.compress.estim.EstimationFactors
 
toString() - Method in class org.apache.sysds.runtime.compress.SingletonLookupHashMap
 
toString() - Method in class org.apache.sysds.runtime.compress.utils.DArrCounts
 
toString() - Method in class org.apache.sysds.runtime.compress.utils.DblArray
 
toString() - Method in class org.apache.sysds.runtime.compress.utils.DblArrayCountHashMap
 
toString() - Method in class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap.DArrayIListEntry
 
toString() - Method in class org.apache.sysds.runtime.compress.utils.DblArrayIntListHashMap
 
toString() - Method in class org.apache.sysds.runtime.compress.utils.DCounts
 
toString() - Method in class org.apache.sysds.runtime.compress.utils.DoubleCountHashMap
 
toString() - Method in class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap.DIListEntry
 
toString() - Method in class org.apache.sysds.runtime.compress.utils.DoubleIntListHashMap
 
toString() - Method in class org.apache.sysds.runtime.compress.utils.IntArrayList
 
toString() - Method in class org.apache.sysds.runtime.compress.workload.AWTreeNode
 
toString() - Method in class org.apache.sysds.runtime.compress.workload.Op
 
toString() - Method in class org.apache.sysds.runtime.compress.workload.OpSided
 
toString() - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheableData
 
toString() - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
 
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.ExecutionContextMap
 
toString() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedData
 
toString() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedLookupTable
 
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.federated.FederationMap
 
toString() - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.CoordinatorModel
 
toString() - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.DataObjectModel
 
toString() - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.EventModel
 
toString() - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.EventStageModel
 
toString() - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.HeavyHitterModel
 
toString() - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.RequestModel
 
toString() - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.StatisticsModel
 
toString() - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.TrafficModel
 
toString() - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.UtilizationModel
 
toString() - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.WorkerModel
 
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.frame.data.columns.Array
 
toString() - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
toString() - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
toString() - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
toString() - Method in class org.apache.sysds.runtime.frame.data.columns.ColumnMetadata
 
toString() - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
toString() - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
toString() - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
toString() - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
toString() - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
toString() - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
toString() - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
toString() - Method in class org.apache.sysds.runtime.functionobjects.Builtin
 
toString() - Method in class org.apache.sysds.runtime.functionobjects.IndexFunction
 
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 class org.apache.sysds.runtime.io.FileFormatPropertiesHDF5
 
toString() - Method in class org.apache.sysds.runtime.io.FileFormatPropertiesLIBSVM
 
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() - 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.Pair
 
toString() - Method in class org.apache.sysds.runtime.matrix.data.RandomMatrixGenerator
 
toString() - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox.SmallestPriorityQueue
 
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.AggregateOperator
 
toString() - Method in class org.apache.sysds.runtime.matrix.operators.AggregateUnaryOperator
 
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.MetaDataAll
 
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.privacy.PrivacyConstraint
 
toString() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
toString() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
toString() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
toString() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderFeatureHash
 
toString() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderPassThrough.PassThroughSparseApplyTask
 
toString() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderPassThrough
 
toString() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
toString() - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
toString() - Method in enum org.apache.sysds.runtime.transform.TfUtils.TfMethod
 
toString() - Method in class org.apache.sysds.runtime.transform.tokenize.Token.SubToken
 
toString() - Method in class org.apache.sysds.runtime.transform.tokenize.Token
 
toString() - Method in class org.apache.sysds.runtime.util.DependencyTask
 
toString() - Method in class org.apache.sysds.runtime.util.IndexRange
 
toString(double[]) - Static method in class org.apache.sysds.runtime.util.DataConverter
 
toString(InputStream) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
 
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(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 - org.apache.sysds.common.Builtins
 
TOSTRING - org.apache.sysds.common.Types.ParamBuiltinOp
 
toStringArray(Object[]) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
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
 
TRACE - org.apache.sysds.common.Builtins
 
TRACE - org.apache.sysds.common.Types.AggOp
 
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
 
traceFedUDF(ExecutionContext, FederatedUDF) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
 
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
 
trackRecompile(boolean) - Method in class org.apache.sysds.hops.recompile.RecompileStatus
 
traffic - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.StatisticsModel
 
traffic - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.StatisticsOptions
 
TrafficModel - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.models
 
TrafficModel() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.TrafficModel
 
TrafficModel(Long, Long, LocalDateTime, String, Long) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.TrafficModel
 
TrafficModel(Long, String, Long) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.TrafficModel
 
TrafficModel(LocalDateTime, String, Long) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.TrafficModel
 
TRANS - org.apache.sysds.common.Builtins
 
TRANS - org.apache.sysds.common.Types.ReOrgOp
 
TRANS - org.apache.sysds.hops.estim.SparsityEstimator.OpCode
 
TRANSFERRED_DATA_HEADER_SIZE - Static variable in interface org.apache.sysds.runtime.codegen.SpoofCUDAOperator
 
Transform - Class in org.apache.sysds.lops
 
Transform - org.apache.sysds.lops.Lop.Type
 
Transform(Lop[], Types.ReOrgOp, Types.DataType, Types.ValueType, boolean, Types.ExecType) - Constructor for class org.apache.sysds.lops.Transform
 
Transform(Lop[], Types.ReOrgOp, Types.DataType, Types.ValueType, Types.ExecType, boolean) - Constructor for class org.apache.sysds.lops.Transform
 
Transform(Lop[], Types.ReOrgOp, Types.DataType, Types.ValueType, Types.ExecType, boolean, int) - Constructor for class org.apache.sysds.lops.Transform
 
Transform(Lop[], Types.ReOrgOp, Types.DataType, Types.ValueType, Types.ExecType, int) - Constructor for class org.apache.sysds.lops.Transform
 
Transform(Lop, Types.ReOrgOp, Types.DataType, Types.ValueType, Types.ExecType) - Constructor for class org.apache.sysds.lops.Transform
 
Transform(Lop, Types.ReOrgOp, Types.DataType, Types.ValueType, Types.ExecType, boolean) - Constructor for class org.apache.sysds.lops.Transform
 
Transform(Lop, Types.ReOrgOp, Types.DataType, Types.ValueType, Types.ExecType, int) - Constructor for class org.apache.sysds.lops.Transform
 
TRANSFORMAPPLY - org.apache.sysds.common.Builtins
 
TRANSFORMAPPLY - org.apache.sysds.common.Types.ParamBuiltinOp
 
TRANSFORMAPPLY - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ParameterizedBuiltinCode
 
TRANSFORMCOLMAP - org.apache.sysds.common.Builtins
 
TRANSFORMCOLMAP - org.apache.sysds.common.Types.ParamBuiltinOp
 
TRANSFORMDECODE - org.apache.sysds.common.Builtins
 
TRANSFORMDECODE - org.apache.sysds.common.Types.ParamBuiltinOp
 
TRANSFORMDECODE - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ParameterizedBuiltinCode
 
TRANSFORMENCODE - org.apache.sysds.common.Builtins
 
TransformEncodeBuild2Function(EncoderMVImpute) - Constructor for class org.apache.sysds.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeBuild2Function
 
TransformEncodeBuildFunction(MultiColumnEncoder) - 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(MultiColumnEncoder, MultiReturnParameterizedBuiltinSPInstruction.MaxLongAccumulator) - Constructor for class org.apache.sysds.runtime.instructions.spark.MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeGroupFunction
 
TRANSFORMMETA - org.apache.sysds.common.Builtins
 
TRANSFORMMETA - org.apache.sysds.common.Types.ParamBuiltinOp
 
TransformStatistics - Class in org.apache.sysds.utils.stats
 
TransformStatistics() - Constructor for class org.apache.sysds.utils.stats.TransformStatistics
 
TRANSIENTREAD - org.apache.sysds.common.Types.OpOpData
 
TRANSIENTWRITE - org.apache.sysds.common.Types.OpOpData
 
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(ExecutionContext, GPUContext, String, MatrixObject, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
Transposes the input matrix using cublasDgeam
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(MatrixBlock) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
 
transpose(MatrixBlock, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
 
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
 
transpose(MatrixBlock, MatrixBlock, int, boolean) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
 
transposed - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
Transpose input matrix, to optimize access when extracting bitmaps.
transposeInPlace(MatrixBlock, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixReorg
 
transposeInput - Variable in class org.apache.sysds.runtime.compress.CompressionSettings
Boolean specifying which transpose setting is used, can be auto, true or false
transposeLeft - Variable in class org.apache.sysds.runtime.instructions.cp.AggregateBinaryCPInstruction
 
transposeRight - Variable in class org.apache.sysds.runtime.instructions.cp.AggregateBinaryCPInstruction
 
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.compress.CompressedMatrixBlock
 
transposeSelfMatrixMultOperations(MatrixBlock, MMTSJ.MMTSJType, int) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
TriggerBroadcastTask - Class in org.apache.sysds.runtime.instructions.cp
 
TriggerBroadcastTask(ExecutionContext, MatrixObject) - Constructor for class org.apache.sysds.runtime.instructions.cp.TriggerBroadcastTask
 
TriggerCheckpointTask - Class in org.apache.sysds.runtime.instructions.cp
 
TriggerCheckpointTask(MatrixObject) - Constructor for class org.apache.sysds.runtime.instructions.cp.TriggerCheckpointTask
 
TriggerPrefetchTask - Class in org.apache.sysds.runtime.instructions.cp
 
TriggerPrefetchTask(MatrixObject) - Constructor for class org.apache.sysds.runtime.instructions.cp.TriggerPrefetchTask
 
TriggerPrefetchTask(MatrixObject, LineageItem) - Constructor for class org.apache.sysds.runtime.instructions.cp.TriggerPrefetchTask
 
triggerRemoteOPsPool - Static variable in class org.apache.sysds.runtime.util.CommonThreadPool
 
TrigRemote - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
TRIGREMOTE - org.apache.sysds.common.Types.OpOp1
 
trim(String) - Static method in class org.apache.sysds.runtime.io.IOUtilFunctions
 
triple_exponential_smoothing(Double[], Double, Double, Double, Integer) - Static method in class org.apache.sysds.runtime.util.EMAUtils
 
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
 
TRUE - org.apache.sysds.lops.Compression.CompressConfig
 
TRUE - org.apache.sysds.lops.DeCompression.CompressConfig
 
trueStringLiteral() - Method in class org.apache.sysds.parser.dml.DmlSyntacticValidator
 
tsmm(double[], double[], int, int, boolean, int) - Static method in class org.apache.sysds.utils.NativeHelper
 
tsmm(double[], int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
tsmm(double[], int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
tsmm(MatrixBlock, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Do a transposed self matrix multiplication on the left side t(x) %*% x.
tsmm(MatrixBlock, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupCompressed
 
tsmm(MatrixBlock, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
tsmm(MatrixBlock, MatrixBlock, boolean, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixNative
 
Tsmm - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
TSMM - org.apache.sysds.hops.AggBinaryOp.MMultMethod
 
TSMM - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
TSMM2 - org.apache.sysds.hops.AggBinaryOp.MMultMethod
 
TSMM2 - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
Tsmm2SPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
tsmmAColGroup(AColGroup, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Matrix multiply with this other column group, but: 1.
tsmmAColGroup(AColGroup, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.colgroup.AMorphingMMColGroup
 
tsmmAColGroup(AColGroup, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.colgroup.APreAgg
 
tsmmAColGroup(AColGroup, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
tsmmAColGroup(AColGroup, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
tsmmAColGroup(AColGroup, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
tsmmAColGroup(AColGroup, MatrixBlock) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
TSMMDictionaryWithScaling(ADictionary, int[], IColIndex, IColIndex, MatrixBlock) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.DictLibMatrixMult
Perform the full tsmm with the dictionary (allocating into the entire output matrix.)
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
 
TsmmFEDInstruction(CPOperand, CPOperand, MMTSJ.MMTSJType, int, String, String, FEDInstruction.FederatedOutput) - Constructor for class org.apache.sysds.runtime.instructions.fed.TsmmFEDInstruction
 
TsmmSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
TSMMToUpperTriangle(ADictionary, ADictionary, IColIndex, IColIndex, MatrixBlock) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.DictLibMatrixMult
Does two matrix multiplications in one go but only add to the upper triangle.
TSMMToUpperTriangleScaling(ADictionary, ADictionary, IColIndex, IColIndex, int[], MatrixBlock) - Static method in class org.apache.sysds.runtime.compress.colgroup.dictionary.DictLibMatrixMult
Does two matrix multiplications in one go but only add to the upper triangle with scaling.
TSNE - org.apache.sysds.common.Builtins
 
TWO - org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex.ColIndexType
 
TWO_OFFSET - org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory.OFF_TYPE_SPECIALIZATIONS
 
TwoIndex - Class in org.apache.sysds.runtime.compress.colgroup.indexes
 
TwoIndex(int, int) - Constructor for class org.apache.sysds.runtime.compress.colgroup.indexes.TwoIndex
 
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
 
type - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.RequestModel
 
typedArgAssign - Variable in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
 
typedArgAssign() - Method in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
 
typedArgAssign() - Method in class org.apache.sysds.parser.dml.DmlParser
 
typedArgAssign(int) - Method in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
 
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 - Variable in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
 
typedArgNoAssign() - Method in class org.apache.sysds.parser.dml.DmlParser.ExternalFunctionDefExpressionContext
 
typedArgNoAssign() - Method in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
 
typedArgNoAssign() - Method in class org.apache.sysds.parser.dml.DmlParser
 
typedArgNoAssign(int) - Method in class org.apache.sysds.parser.dml.DmlParser.ExternalFunctionDefExpressionContext
 
typedArgNoAssign(int) - Method in class org.apache.sysds.parser.dml.DmlParser.InternalFunctionDefExpressionContext
 
TypedArgNoAssignContext(ParserRuleContext, int) - Constructor for class org.apache.sysds.parser.dml.DmlParser.TypedArgNoAssignContext
 
TYPEOF - org.apache.sysds.common.Builtins
 
TYPEOF - org.apache.sysds.common.Types.OpOp1
 
TYPEOF - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
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.

U

UaggOuterChain - org.apache.sysds.lops.Lop.Type
 
UaggOuterChain - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
UaggOuterChain - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
UAggOuterChain - Class in org.apache.sysds.lops
TODO Currently this lop only support the right hand side in distributed cache.
UAggOuterChain(Lop, Lop, Types.AggOp, Types.Direction, Types.OpOp2, Types.DataType, Types.ValueType, Types.ExecType) - Constructor for class org.apache.sysds.lops.UAggOuterChain
Constructor to setup a unaryagg outer chain
UaggOuterChainCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
uaggouterchainOperations(MatrixBlock, MatrixBlock, MatrixBlock, BinaryOperator, AggregateUnaryOperator) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
uaggouterchainOperations(MatrixBlock, MatrixBlock, MatrixBlock, BinaryOperator, AggregateUnaryOperator) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
UaggOuterChainSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
Two types of broadcast variables used -- 1.
UBYTE - org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory.MAP_TYPE
 
UDF - org.apache.sysds.runtime.transform.TfUtils.TfMethod
 
uIndex - Variable in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset.OffsetSliceInfo
 
UINT4 - org.apache.sysds.common.Types.ValueType
 
UInt8 - org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary.DictType
 
UINT8 - org.apache.sysds.common.Types.ValueType
 
ULTRA_SPARSE_BLOCK - org.apache.sysds.common.Types.BlockType
 
ULTRA_SPARSE_BLOCK_NNZ - Static variable in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
ULTRA_SPARSITY_TURN_POINT - Static variable in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
ULTRA_SPARSITY_TURN_POINT2 - Static variable in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
Unary - Class in org.apache.sysds.hops.codegen.cplan.cuda
 
Unary - Class in org.apache.sysds.hops.codegen.cplan.java
 
Unary - Class in org.apache.sysds.lops
Lop to perform following operations: with one operand -- NOT(A), ABS(A), SQRT(A), LOG(A) with two operands where one of them is a scalar -- H=H*i, H=H*5, EXP(A,2), LOG(A,2)
Unary - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
Unary - org.apache.sysds.runtime.instructions.fed.FEDInstruction.FEDType
 
Unary - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
Unary() - Constructor for class org.apache.sysds.hops.codegen.cplan.cuda.Unary
 
Unary() - Constructor for class org.apache.sysds.hops.codegen.cplan.java.Unary
 
Unary(Lop, Types.OpOp1, Types.DataType, Types.ValueType, Types.ExecType, int, boolean) - Constructor for class org.apache.sysds.lops.Unary
Constructor to perform a unary operation with 1 input.
Unary(Lop, Lop, Types.OpOp1, Types.DataType, Types.ValueType, Types.ExecType, int) - Constructor for class org.apache.sysds.lops.Unary
Constructor to perform a unary operation with 2 inputs
UNARY - org.apache.sysds.lops.Lop.Type
 
unaryAggregate(ExecutionContext, GPUContext, String, MatrixObject, String, AggregateUnaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
Entry point to perform Unary aggregate operations on the GPU.
unaryAggregateOperations(AggregateUnaryOperator, double[], int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Unary Aggregate operator, since aggregate operators require new object output, the output becomes an uncompressed matrix.
unaryAggregateOperations(AggregateUnaryOperator, double[], int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupCompressed
 
unaryAggregateOperations(AggregateUnaryOperator, double[], int, int, int) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
unaryAggregateOperations(AggregateUnaryOperator, double[], int, int, int, double[]) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupCompressed
 
UnaryCP - Class in org.apache.sysds.lops
 
UnaryCP - org.apache.sysds.lops.Lop.Type
 
UnaryCP(Lop, Types.OpOp1, Types.DataType, Types.ValueType) - Constructor for class org.apache.sysds.lops.UnaryCP
 
UnaryCP(Lop, Types.OpOp1, Types.DataType, Types.ValueType, int) - Constructor for class org.apache.sysds.lops.UnaryCP
 
UnaryCP(Lop, Types.OpOp1, Types.DataType, Types.ValueType, Types.ExecType) - Constructor for class org.apache.sysds.lops.UnaryCP
 
UnaryCP(Lop, Types.OpOp1, Types.DataType, Types.ValueType, Types.ExecType, int) - Constructor for class org.apache.sysds.lops.UnaryCP
Constructor to perform a scalar operation
UnaryCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
UnaryExpressionContext(DmlParser.ExpressionContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.UnaryExpressionContext
 
UnaryFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
UnaryFrameCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
UnaryFrameSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
UnaryMatrixCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
UnaryMatrixFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
UnaryMatrixSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
UnaryOp - Class in org.apache.sysds.hops
 
UnaryOp(String, Types.DataType, Types.ValueType, Types.OpOp1, Hop) - Constructor for class org.apache.sysds.hops.UnaryOp
 
unaryOperation(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
Perform unary operation on the column group and return a new column group
unaryOperation(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupConst
 
unaryOperation(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
unaryOperation(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
unaryOperation(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupEmpty
 
unaryOperation(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
unaryOperation(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupOLE
 
unaryOperation(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupRLE
 
unaryOperation(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
unaryOperation(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
unaryOperation(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
unaryOperation(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
unaryOperation(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
unaryOperation(UnaryOperator) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
unaryOperations(CompressedMatrixBlock, UnaryOperator, MatrixValue) - Static method in class org.apache.sysds.runtime.compress.lib.CLALibUnary
 
unaryOperations(MatrixBlock, String) - Static method in class org.apache.sysds.runtime.matrix.data.LibCommonsMath
 
unaryOperations(UnaryOperator, MatrixValue) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
unaryOperations(UnaryOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
 
unaryOperations(UnaryOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
unaryOperations(UnaryOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
unaryOperations(UnaryOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
 
unaryOperations(UnaryOperator, MatrixValue) - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
 
unaryOperator(UnaryOperator, double[]) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupUtils
 
UnaryOperator - Class in org.apache.sysds.runtime.matrix.operators
 
UnaryOperator(ValueFunction) - Constructor for class org.apache.sysds.runtime.matrix.operators.UnaryOperator
 
UnaryOperator(ValueFunction, int) - Constructor for class org.apache.sysds.runtime.matrix.operators.UnaryOperator
 
UnaryOperator(ValueFunction, int, boolean) - Constructor for class org.apache.sysds.runtime.matrix.operators.UnaryOperator
 
UnaryScalarCPInstruction - Class in org.apache.sysds.runtime.instructions.cp
 
UnarySketchOperator - Class in org.apache.sysds.runtime.matrix.operators
 
UnarySketchOperator(AggregateOperator, IndexFunction, Types.Direction) - Constructor for class org.apache.sysds.runtime.matrix.operators.UnarySketchOperator
 
UnarySketchOperator(AggregateOperator, IndexFunction, Types.Direction, int) - Constructor for class org.apache.sysds.runtime.matrix.operators.UnarySketchOperator
 
UnarySPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
uncellOp(MatrixBlock, MatrixBlock, UnaryOperator) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixBincell
 
UNCOMPRESSED - org.apache.sysds.runtime.compress.colgroup.AColGroup.CompressionType
 
UNDEFINED_ADDRESS - Static variable in class org.apache.sysds.runtime.io.hdf5.H5Constants
 
UNDER_SAMPLING - org.apache.sysds.common.Builtins
 
UNIFIED_MEMORY_MANAGER - org.apache.sysds.hops.OptimizerUtils.MemoryManager
 
UnifiedMemoryAllocator - Class in org.apache.sysds.runtime.instructions.gpu.context
 
UnifiedMemoryAllocator() - Constructor for class org.apache.sysds.runtime.instructions.gpu.context.UnifiedMemoryAllocator
 
UnifiedMemoryManager - Class in org.apache.sysds.runtime.controlprogram.caching
Unified Memory Manager - Initial Design Motivation: The Unified Memory Manager, henceforth UMM, will act as a central manager of in-memory matrix (uncompressed and compressed), frame, and tensor blocks within SystemDS control program.
UnifiedMemoryManager() - Constructor for class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
 
UNIFORM - org.apache.sysds.runtime.matrix.data.RandomMatrixGenerator.PDF
 
uniformityCriticalValue - Variable in class org.apache.sysds.runtime.compress.estim.sample.ShlosserJackknifeEstimator.CriticalValue
 
UniformPRNGenerator - Class in org.apache.sysds.runtime.util
 
UniformPRNGenerator() - Constructor for class org.apache.sysds.runtime.util.UniformPRNGenerator
 
UniformPRNGenerator(long) - Constructor for class org.apache.sysds.runtime.util.UniformPRNGenerator
 
union(VariableSet, VariableSet) - Static method in class org.apache.sysds.parser.VariableSet
 
union(CorrMatrixBlock, CorrMatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinct.CountDistinctFunctionSketch
 
union(CorrMatrixBlock, CorrMatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox.KMVSketch
 
union(CorrMatrixBlock, CorrMatrixBlock) - Method in interface org.apache.sysds.runtime.matrix.data.sketch.MatrixSketch
Union two sketches together to from a combined sketch.
UNION - org.apache.sysds.common.Builtins
 
unionAll(List<T>, List<T>) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
 
unionDistinct(List<T>, List<T>) - Static method in class org.apache.sysds.runtime.util.CollectionUtils
 
unionSketch(CountDistinctOperator, CorrMatrixBlock, CorrMatrixBlock) - Static method in interface org.apache.sysds.runtime.matrix.data.LibMatrixCountDistinct
 
unionSketchByIndex(CorrMatrixBlock, CorrMatrixBlock, int, CorrMatrixBlock) - Method in class org.apache.sysds.runtime.matrix.data.sketch.countdistinctapprox.KMVSketch
 
UNIQUE - org.apache.sysds.common.Builtins
 
UNIQUE - org.apache.sysds.common.Types.AggOp
 
UNIQUE - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
UNIQUE - org.apache.sysds.runtime.instructions.cp.AggregateUnaryCPInstruction.AUType
 
UNIVAR - org.apache.sysds.common.Builtins
 
UNKNOWN - org.apache.sysds.common.Types.DataType
 
UNKNOWN - org.apache.sysds.common.Types.ValueType
 
UNKNOWN - org.apache.sysds.hops.FunctionOp.FunctionType
 
UNKNOWN - org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex.ColIndexType
 
unloadNativeCodeGenerator() - Static method in class org.apache.sysds.hops.codegen.SpoofCompiler
 
unpin(CacheableData<?>) - Static method in class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
 
unpinVariables(List<String>, boolean[]) - Method in class org.apache.sysds.runtime.controlprogram.context.ExecutionContext
Unpin the a given list of variables by setting their "cleanup" status to the values specified by varsStats.
unquote(String) - Static method in class org.apache.sysds.runtime.util.UtilFunctions
 
unsetCurrentFileName() - Method in class org.apache.sysds.parser.dml.CustomErrorListener
 
unsetPartitioned() - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
 
UNSPECIFIED - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PDataPartitioner
 
UNSPECIFIED - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PExecMode
 
UNSPECIFIED - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PResultMerge
 
UNSPECIFIED - org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PTaskPartitioner
 
UNSPECIFIED_SEED - Static variable in class org.apache.sysds.hops.DataGenOp
 
UNSUPPORTED_EXPRESSION - Static variable in class org.apache.sysds.parser.LanguageException.LanguageErrorCodes
 
UNSUPPORTED_PARAMETERS - Static variable in class org.apache.sysds.parser.LanguageException.LanguageErrorCodes
 
update(CoordinatorModel) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.CoordinatorService
 
update(WorkerModel) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.WorkerService
 
update(Request, Long) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.CoordinatorController
 
update(Request, Long) - Method in interface org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.IController
 
update(Request, Long) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.StatisticsController
 
update(Request, Long) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.WorkerController
 
UPDATE_INPLACE_PREFIX - Static variable in class org.apache.sysds.lops.Lop
 
UPDATE_NESTEROV_X - org.apache.sysds.common.Types.OpOpDnn
 
updateAllDCEncoders() - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
updateAppendDataCharacteristics(DataCharacteristics, DataCharacteristics, DataCharacteristics, boolean) - Static method in class org.apache.sysds.runtime.meta.MetaDataUtils
 
updateCheckedConstraintsLog() - Method in class org.apache.sysds.runtime.controlprogram.federated.FederatedResponse
 
updateDataCharacteristics(DataCharacteristics) - Method in class org.apache.sysds.runtime.controlprogram.caching.MatrixObject
 
updateDataCharacteristics(DataCharacteristics) - Method in class org.apache.sysds.runtime.instructions.cp.Data
 
updateDomainSizes(List<ColumnEncoder>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
updateDomainSizes(List<ColumnEncoder>) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderUDF
 
updateEntity(T) - Method in class org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.DerbyRepository
 
updateEntity(T) - Method in interface org.apache.sysds.runtime.controlprogram.federated.monitoring.repositories.IRepository
 
updateExplain() - Method in class org.apache.sysds.hops.fedplanner.FederatedPlannerCostbased
Add hopRelMemo to Explain class to get explain info related to federated enumeration.
updateFunctionNames(ArrayList<Hop>, long) - Static method in class org.apache.sysds.hops.recompile.Recompiler
 
updateHopCharacteristics(Hop, int, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
updateHopCharacteristics(Hop, int, MemoTable, Hop) - Static method in class org.apache.sysds.hops.rewrite.HopRewriteUtils
 
updateIndexRanges(long[], long[]) - Method in class org.apache.sysds.runtime.transform.decode.Decoder
Update index-ranges to after decoding.
updateIndexRanges(long[], long[]) - Method in class org.apache.sysds.runtime.transform.decode.DecoderComposite
 
updateIndexRanges(long[], long[]) - Method in class org.apache.sysds.runtime.transform.decode.DecoderDummycode
 
updateIndexRanges(long[], long[]) - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
 
updateIndexRanges(long[], long[]) - Method in class org.apache.sysds.runtime.transform.encode.LegacyEncoder
Update index-ranges to after encoding.
updateIndexRanges(long[], long[], int) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
Update index-ranges to after encoding.
updateIndexRanges(long[], long[], int) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
updateIndexRanges(long[], long[], int) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
updateIndexRanges(long[], long[], int) - Method in interface org.apache.sysds.runtime.transform.encode.Encoder
Update index-ranges to after encoding.
updateIndexRanges(long[], long[], int) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
updateInstructionThreadID(String, String) - Method in class org.apache.sysds.runtime.instructions.cp.EvalNaryCPInstruction
 
updateInstructionThreadID(String, String) - Method in class org.apache.sysds.runtime.instructions.cp.VariableCPInstruction
 
updateInstructionThreadID(String, String) - Method in class org.apache.sysds.runtime.instructions.Instruction
All instructions that have thread-specific filenames or names encoded in it should overwrite this method in order to update (1) the in-memory instruction and (2) the instruction string
updateInstStringFunctionName(String, String) - Method in class org.apache.sysds.runtime.instructions.cp.FunctionCallCPInstruction
 
updateLabels(String, LocalVariableMap) - Static method in class org.apache.sysds.runtime.instructions.cp.CPInstruction
Takes a delimited string of instructions, and replaces ALL placeholder labels (such as ##mVar2## and ##Var5##) in ALL instructions.
updateLiveVariablesOut(VariableSet) - Method in class org.apache.sysds.parser.LiveVariableAnalysis
 
updateLopFedOut(Lop) - Method in class org.apache.sysds.hops.Hop
 
updateLopFedOut(Lop, Types.ExecType, FEDInstruction.FederatedOutput) - Method in class org.apache.sysds.hops.Hop
 
updateLopProperties() - Method in class org.apache.sysds.lops.DnnTransform
 
updatePredicateRecompilationFlag() - Method in class org.apache.sysds.parser.IfStatementBlock
 
updatePredicateRecompilationFlag() - Method in class org.apache.sysds.parser.WhileStatementBlock
 
updatePredicateRecompilationFlags() - Method in class org.apache.sysds.parser.ForStatementBlock
 
updateRecompilationFlag() - Method in class org.apache.sysds.parser.StatementBlock
 
updateRepetitionEstimates() - Method in class org.apache.sysds.parser.DMLProgram
 
updateRepetitionEstimates(double) - Method in class org.apache.sysds.hops.Hop
 
updateRepetitionEstimates(double) - Method in class org.apache.sysds.parser.ForStatementBlock
 
updateRepetitionEstimates(double) - Method in class org.apache.sysds.parser.FunctionStatementBlock
 
updateRepetitionEstimates(double) - Method in class org.apache.sysds.parser.IfStatementBlock
 
updateRepetitionEstimates(double) - Method in class org.apache.sysds.parser.StatementBlock
Updates the repetition estimate for this statement block and all contained hops.
updateRepetitionEstimates(double) - Method in class org.apache.sysds.parser.WhileStatementBlock
 
updateSeqIncr(double, double, double) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixDatagen
 
UPPER - Static variable in class org.apache.sysds.runtime.util.DMVUtils
 
UPPER_TRI - org.apache.sysds.common.Builtins
 
UPPER_TRI - org.apache.sysds.common.Types.ParamBuiltinOp
 
UPPER_TRI - org.apache.sysds.runtime.functionobjects.ParameterizedBuiltin.ParameterizedBuiltinCode
 
urlToMatrixObject(URL, MatrixMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
Convert a matrix at a URL to a MatrixObject.
USE_ACCELERATOR - Static variable in class org.apache.sysds.api.DMLScript
 
USE_BINARYBLOCK_SERIALIZATION - Static variable in class org.apache.sysds.runtime.util.HDFSTool
 
USE_LOCAL_SPARK_CONFIG - Static variable in class org.apache.sysds.api.DMLScript
 
USE_LOCAL_SPARK_CONFIG - Static variable in class org.apache.sysds.conf.DMLConfig
 
USE_PARALLEL_RESULT_MERGE - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
USE_PARALLEL_RESULT_MERGE_REMOTE - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
USE_PB_CACHE - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
USE_RANGE_TASKS_IF_USEFUL - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
USE_SSL_FEDERATED_COMMUNICATION - Static variable in class org.apache.sysds.conf.DMLConfig
 
USE_STREAMING_TASK_CREATION - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
usedSampleSize - Variable in class org.apache.sysds.runtime.compress.estim.sample.ShlosserJackknifeEstimator.CriticalValue
 
Util - Interface in org.apache.sysds.runtime.compress.utils
 
UtilFunctions - Class in org.apache.sysds.runtime.util
 
UtilFunctions() - Constructor for class org.apache.sysds.runtime.util.UtilFunctions
 
utilization - Variable in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics.FedStatsCollection
 
utilization - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.StatisticsModel
 
utilization - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.StatisticsOptions
 
UtilizationModel - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.models
 
UtilizationModel() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.UtilizationModel
 
UtilizationModel(double, double) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.UtilizationModel
 
UtilizationModel(Long, double, double) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.UtilizationModel
 
UtilizationModel(Long, Long, LocalDateTime, double, double) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.UtilizationModel
 
Utils - Class in org.apache.sysds.runtime.io.hdf5
 

V

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(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(HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.ExpressionList
 
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(HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.RelationalExpression
Validate parse tree : Process Relational Expression
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(MultiAssignmentStatement, HashMap<String, DataIdentifier>, HashMap<String, ConstIdentifier>, boolean) - Method in class org.apache.sysds.parser.BuiltinFunctionExpression
 
validateExpression(MultiAssignmentStatement, 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.ParameterizedBuiltinFunctionExpression
 
validateFunction(DMLProgram, FunctionStatementBlock) - Method in class org.apache.sysds.parser.DMLTranslator
 
validateFunction(DMLProgram, FunctionStatementBlock, boolean) - 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
 
VALIDATION_ERROR - org.apache.sysds.parser.dml.CustomErrorListener.ParseIssueType
 
VALIDATION_WARNING - org.apache.sysds.parser.dml.CustomErrorListener.ParseIssueType
 
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
 
value() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AIterator
Get the current index value, note this correspond to a row index in the original matrix.
value() - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffsetIterator
Get the current index value, note this correspond to a row index in the original matrix.
value(double) - Method in class org.apache.sysds.runtime.compress.estim.sample.HassAndStokes.MethodOfMomentsFunction
 
VALUE_SWAP - org.apache.sysds.common.Builtins
 
VALUE_SWAP - org.apache.sysds.common.Types.OpOp2
 
VALUE_SWAP - org.apache.sysds.runtime.functionobjects.Builtin.BuiltinCode
 
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(int) - Static method in enum org.apache.sysds.common.Types.AggOp
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.sysds.runtime.codegen.SpoofCellwise.CellType
Returns the enum constant of this type with the specified name.
valueOf(int) - 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.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.GeneratorAPI
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.fedplanner.FTypes.AlignType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sysds.hops.fedplanner.FTypes.FederatedPlanner
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sysds.hops.fedplanner.FTypes.FPartitioning
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sysds.hops.fedplanner.FTypes.FReplication
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sysds.hops.fedplanner.FTypes.FType
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.MemoryManager
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.compile.linearization.ILinearize.DagLinearization
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.DeCompression.CompressConfig
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.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.FederatedPSScheme
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.PSRuntimeBalancing
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.CoCoderFactory.PartitionerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sysds.runtime.compress.colgroup.AColGroup.CompressionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary.DictType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sysds.runtime.compress.colgroup.dictionary.DictionaryFactory.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex.ColIndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sysds.runtime.compress.colgroup.insertionsort.InsertionSorterFactory.SORT_TYPE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory.MAP_TYPE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory.OFF_TYPE_SPECIALIZATIONS
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sysds.runtime.compress.colgroup.offset.OffsetFactory.OFF_TYPE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sysds.runtime.compress.cost.CostEstimatorFactory.CostType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sysds.runtime.compress.estim.sample.SampleEstimatorFactory.EstimationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sysds.runtime.compress.workload.AWTreeNode.WTNodeType
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.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.frame.data.columns.ArrayFactory.FrameArrayType
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.FederatedOutput
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.data.RandomMatrixGenerator.PDF
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.CountDistinctOperatorTypes
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.decode.DecoderFactory.DecoderType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sysds.runtime.transform.encode.ColumnEncoder.EncoderType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sysds.runtime.transform.encode.ColumnEncoderBin.BinMethod
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.DMVUtils.LEVEL_ENUM
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
 
VALUEPICK - org.apache.sysds.lops.PickByCount.OperationTypes
 
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.GeneratorAPI
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.fedplanner.FTypes.AlignType
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.fedplanner.FTypes.FederatedPlanner
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.fedplanner.FTypes.FPartitioning
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.fedplanner.FTypes.FReplication
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.fedplanner.FTypes.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.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.MemoryManager
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.compile.linearization.ILinearize.DagLinearization
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.DeCompression.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.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.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.FederatedPSScheme
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.PSRuntimeBalancing
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() - 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.CoCoderFactory.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.AColGroup.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.colgroup.dictionary.ADictionary.DictType
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.dictionary.DictionaryFactory.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.compress.colgroup.indexes.IColIndex.ColIndexType
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.insertionsort.InsertionSorterFactory.SORT_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.compress.colgroup.mapping.MapToFactory.MAP_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.compress.colgroup.offset.OffsetFactory.OFF_TYPE_SPECIALIZATIONS
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.offset.OffsetFactory.OFF_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.compress.cost.CostEstimatorFactory.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.runtime.compress.estim.sample.SampleEstimatorFactory.EstimationType
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.workload.AWTreeNode.WTNodeType
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.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() - 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() - 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() - 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.frame.data.columns.ArrayFactory.FrameArrayType
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.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.FederatedOutput
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.data.RandomMatrixGenerator.PDF
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.CountDistinctOperatorTypes
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.decode.DecoderFactory.DecoderType
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.ColumnEncoder.EncoderType
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.ColumnEncoderBin.BinMethod
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.DMVUtils.LEVEL_ENUM
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.
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(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(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(int) - Method in class org.apache.sysds.runtime.data.SparseBlockCSR
 
values(int) - Method in class org.apache.sysds.runtime.data.SparseBlockMCSR
 
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
 
valueSwap(FrameBlock) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
ValueTrimFormat - Class in org.apache.sysds.runtime.iogen
 
ValueTrimFormat(int) - Constructor for class org.apache.sysds.runtime.iogen.ValueTrimFormat
 
ValueTrimFormat(int, Types.ValueType, Object) - Constructor for class org.apache.sysds.runtime.iogen.ValueTrimFormat
 
ValueTrimFormat(String) - Constructor for class org.apache.sysds.runtime.iogen.ValueTrimFormat
 
valueType - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.DataObjectModel
 
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
 
VAR - org.apache.sysds.common.Builtins
 
VAR - org.apache.sysds.common.Types.AggOp
 
Variable - org.apache.sysds.runtime.instructions.cp.CPInstruction.CPType
 
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
 
VariableFEDInstruction - Class in org.apache.sysds.runtime.instructions.fed
 
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
 
VARIANCE - org.apache.sysds.runtime.matrix.operators.CMOperator.AggregateOperationTypes
 
varName - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.DataObjectModel
 
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
 
VECT_ABS - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_ACOS - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_ASIN - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_ATAN - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_AVG_POOL - org.apache.sysds.hops.codegen.cplan.CNodeNary.NaryType
 
VECT_BIASADD - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_BIASMULT - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_BITWAND - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_BITWAND_SCALAR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_CBIND - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_CBIND - org.apache.sysds.hops.codegen.cplan.CNodeNary.NaryType
 
VECT_CBIND_ADD - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_CEIL - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_CONST2 - org.apache.sysds.hops.codegen.SpoofFusedOp.SpoofOutputDimsType
 
VECT_CONV2DMM - org.apache.sysds.hops.codegen.cplan.CNodeNary.NaryType
 
VECT_COS - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_COSH - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_CUMMAX - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_CUMMIN - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_CUMSUM - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_DIV - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_DIV_ADD - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_DIV_SCALAR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_EQUAL - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_EQUAL_ADD - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_EQUAL_SCALAR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_EXP - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_FLOOR - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_GREATER - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_GREATER_ADD - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_GREATER_SCALAR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_GREATEREQUAL - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_GREATEREQUAL_ADD - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_GREATEREQUAL_SCALAR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_IM2COL - org.apache.sysds.hops.codegen.cplan.CNodeNary.NaryType
 
VECT_LESS - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_LESS_ADD - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_LESS_SCALAR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_LESSEQUAL - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_LESSEQUAL_ADD - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_LESSEQUAL_SCALAR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_LOG - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_MATRIXMULT - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_MAX - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_MAX_ADD - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_MAX_POOL - org.apache.sysds.hops.codegen.cplan.CNodeNary.NaryType
 
VECT_MAX_SCALAR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_MIN - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_MIN_ADD - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_MIN_SCALAR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_MINUS - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_MINUS_ADD - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_MINUS_SCALAR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_MULT - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_MULT_ADD - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_MULT_SCALAR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_MULT2 - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_NOTEQUAL - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_NOTEQUAL_ADD - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_NOTEQUAL_SCALAR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_OUTERMULT_ADD - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_PLUS - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_PLUS_ADD - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_PLUS_SCALAR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_POW_ADD - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_POW_SCALAR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_POW2 - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_ROUND - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_SIGMOID - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_SIGN - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_SIN - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_SINH - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_SPROP - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_SQRT - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_TAN - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_TANH - org.apache.sysds.hops.codegen.cplan.CNodeUnary.UnaryType
 
VECT_XOR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_XOR_ADD - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
VECT_XOR_SCALAR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
vectAbsAdd(double[], double[], int[], int, int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
 
vectAbsAdd(double[], double[], int, 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
 
vectAbsWrite(double[], 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
 
vectAcosAdd(double[], double[], int, 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
 
vectAcosWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
 
vectAdd(double[], double[], int[], 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, double[], 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, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
 
vectAsinAdd(double[], double[], int, 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
 
vectAsinWrite(double[], 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
 
vectAtanAdd(double[], double[], int, 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
 
vectAtanWrite(double[], 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
 
vectAvgpoolWrite(double[], 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, 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
 
vectBiasmultWrite(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
 
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
 
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) - 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) - 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
 
vectCbindAdd(double[], double, double[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
 
vectCbindWrite(double[], double[], int[], int, int, int, 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
 
vectCbindWrite(double[], double, int[], int, int, int) - 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) - 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
 
vectCeilAdd(double[], double[], int, 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
 
vectCeilWrite(double[], 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, 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
 
vectCoshAdd(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
 
vectCoshWrite(double[], 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
 
vectCosWrite(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
 
vectCountnnz(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
 
vectCummaxAdd(double[], double[], int[], 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
 
vectCummaxWrite(double[], 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
 
vectCumminAdd(double[], double[], int[], 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
 
vectCumminWrite(double[], 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
 
vectCumsumAdd(double[], double[], int[], 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
 
vectCumsumWrite(double[], 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
 
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) - 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) - 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
 
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) - 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) - 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) - 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) - 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
 
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) - 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) - 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
 
vectExpAdd(double[], double[], int, 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
 
vectExpWrite(double[], 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
 
vectFloorAdd(double[], double[], int, 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
 
vectFloorWrite(double[], 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) - 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) - 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) - 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) - 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
 
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) - 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) - 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
 
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) - 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) - 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
 
vectIm2colWrite(double[], 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, 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) - 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) - 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) - 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
 
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) - 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) - 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
 
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) - 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) - 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
 
vectLogAdd(double[], double[], int, 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
 
vectLogWrite(double[], 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
 
vectMatrixMult(double[], double[], int, 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
 
vectMax(double[], 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) - 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) - 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
 
vectMaxpoolWrite(double[], 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, 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) - 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) - 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) - 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
 
vectMean(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
 
vectMin(double[], 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) - 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) - 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) - 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) - 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
 
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) - 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) - 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
 
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) - 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) - 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
 
vectMult2Add(double[], double[], int, 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
 
vectMult2Write(double[], 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) - 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, int) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
 
vectMultiplyAdd(double, double[], double[], 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, 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) - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixMult
 
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
 
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) - 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) - 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) - 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) - 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
 
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) - 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) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
 
VECTOR_TO_CSV - org.apache.sysds.common.Builtins
 
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
 
vectOuterMultAdd(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
 
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) - 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
 
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) - 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) - 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
 
vectPow2Add(double[], double[], int, 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
 
vectPow2Write(double[], 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) - 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) - 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) - 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) - 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
 
vectRoundAdd(double[], double[], int, 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
 
vectRoundWrite(double[], 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
 
vectSigmoidAdd(double[], double[], int, 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
 
vectSigmoidWrite(double[], 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
 
vectSignAdd(double[], double[], int, 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
 
vectSignWrite(double[], 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
 
vectSinAdd(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
 
vectSinhAdd(double[], double[], int, 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
 
vectSinhWrite(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
 
vectSinWrite(double[], 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
 
vectSpropAdd(double[], double[], int, 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
 
vectSpropWrite(double[], 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
 
vectSqrtAdd(double[], double[], int, 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
 
vectSqrtWrite(double[], int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
 
vectSum(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.
vectSumsq(double[], int[], int, int, int) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
 
vectSumsq(double[], 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
 
vectTanAdd(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
 
vectTanhAdd(double[], double[], int, 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
 
vectTanhWrite(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
 
vectTanWrite(double[], 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
 
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
 
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) - Static method in class org.apache.sysds.runtime.codegen.LibSpoofPrimitives
Computes c = xor(A,B)
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) - 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
 
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) - 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) - 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.
versionNumberOfTheFileFreeSpaceInformation - Variable in class org.apache.sysds.runtime.io.hdf5.H5Superblock
 
versionOfRootGroupSymbolTableEntry - Variable in class org.apache.sysds.runtime.io.hdf5.H5Superblock
 
versionOfSharedHeaderMessageFormat - Variable in class org.apache.sysds.runtime.io.hdf5.H5Superblock
 
versionOfSuperblock - Variable in class org.apache.sysds.runtime.io.hdf5.H5Superblock
 
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
 

W

w - Variable in class org.apache.sysds.runtime.instructions.cp.CM_COV_Object
 
W - Variable in class org.apache.sysds.runtime.matrix.data.DnnParameters
 
W_TREE - org.apache.sysds.runtime.compress.cost.CostEstimatorFactory.CostType
 
waitFor(List<Future<FederatedResponse>>) - Static method in class org.apache.sysds.runtime.controlprogram.federated.FederationUtils
 
warnFullFP64Conversion(long) - Static method in class org.apache.sysds.common.Warnings
 
Warnings - Class in org.apache.sysds.common
 
Warnings() - Constructor for class org.apache.sysds.common.Warnings
 
warnInvalidBooleanIncrement(double) - Static method in class org.apache.sysds.common.Warnings
 
WCEMM - org.apache.sysds.common.Types.OpOp4
 
WDIVMM - org.apache.sysds.common.Types.OpOp4
 
WeightedCell - Class in org.apache.sysds.runtime.matrix.data
 
WeightedCell() - Constructor for class org.apache.sysds.runtime.matrix.data.WeightedCell
 
WeightedCeMM - org.apache.sysds.lops.Lop.Type
 
WeightedCrossEntropy - Class in org.apache.sysds.lops
 
WeightedCrossEntropy(Lop, Lop, Lop, Lop, Types.DataType, Types.ValueType, WeightedCrossEntropy.WCeMMType, Types.ExecType) - Constructor for class org.apache.sysds.lops.WeightedCrossEntropy
 
WeightedCrossEntropy.WCeMMType - Enum in org.apache.sysds.lops
 
WeightedCrossEntropyR - Class in org.apache.sysds.lops
 
WeightedCrossEntropyR(Lop, Lop, Lop, Lop, Types.DataType, Types.ValueType, WeightedCrossEntropy.WCeMMType, boolean, boolean, Types.ExecType) - Constructor for class org.apache.sysds.lops.WeightedCrossEntropyR
 
WeightedDivMM - Class in org.apache.sysds.lops
 
WeightedDivMM - org.apache.sysds.lops.Lop.Type
 
WeightedDivMM(Lop, Lop, Lop, Lop, Types.DataType, Types.ValueType, WeightedDivMM.WDivMMType, Types.ExecType) - Constructor for class org.apache.sysds.lops.WeightedDivMM
 
WeightedDivMM.WDivMMType - Enum in org.apache.sysds.lops
 
WeightedDivMMR - Class in org.apache.sysds.lops
 
WeightedDivMMR(Lop, Lop, Lop, Lop, Types.DataType, Types.ValueType, WeightedDivMM.WDivMMType, boolean, boolean, Types.ExecType) - Constructor for class org.apache.sysds.lops.WeightedDivMMR
 
WeightedPair - Class in org.apache.sysds.runtime.matrix.data
 
WeightedPair() - Constructor for class org.apache.sysds.runtime.matrix.data.WeightedPair
 
WeightedSigmoid - Class in org.apache.sysds.lops
 
WeightedSigmoid - org.apache.sysds.lops.Lop.Type
 
WeightedSigmoid(Lop, Lop, Lop, Types.DataType, Types.ValueType, WeightedSigmoid.WSigmoidType, Types.ExecType) - Constructor for class org.apache.sysds.lops.WeightedSigmoid
 
WeightedSigmoid.WSigmoidType - Enum in org.apache.sysds.lops
 
WeightedSigmoidR - Class in org.apache.sysds.lops
 
WeightedSigmoidR(Lop, Lop, Lop, Types.DataType, Types.ValueType, WeightedSigmoid.WSigmoidType, boolean, boolean, Types.ExecType) - Constructor for class org.apache.sysds.lops.WeightedSigmoidR
 
WeightedSquaredLoss - Class in org.apache.sysds.lops
 
WeightedSquaredLoss - org.apache.sysds.lops.Lop.Type
 
WeightedSquaredLoss(Lop, Lop, Lop, Lop, Types.DataType, Types.ValueType, WeightedSquaredLoss.WeightsType, Types.ExecType) - Constructor for class org.apache.sysds.lops.WeightedSquaredLoss
 
WeightedSquaredLoss.WeightsType - Enum in org.apache.sysds.lops
 
WeightedSquaredLossR - Class in org.apache.sysds.lops
 
WeightedSquaredLossR(Lop, Lop, Lop, Lop, Types.DataType, Types.ValueType, WeightedSquaredLoss.WeightsType, boolean, boolean, Types.ExecType) - Constructor for class org.apache.sysds.lops.WeightedSquaredLossR
 
WeightedUMM - org.apache.sysds.lops.Lop.Type
 
WeightedUnaryMM - Class in org.apache.sysds.lops
 
WeightedUnaryMM(Lop, Lop, Lop, Types.DataType, Types.ValueType, WeightedUnaryMM.WUMMType, Types.OpOp1, Types.ExecType) - Constructor for class org.apache.sysds.lops.WeightedUnaryMM
 
WeightedUnaryMM.WUMMType - Enum in org.apache.sysds.lops
 
WeightedUnaryMMR - Class in org.apache.sysds.lops
 
WeightedUnaryMMR(Lop, Lop, Lop, Types.DataType, Types.ValueType, WeightedUnaryMM.WUMMType, Types.OpOp1, boolean, boolean, Types.ExecType) - Constructor for class org.apache.sysds.lops.WeightedUnaryMMR
 
welcomeMessage() - Static method in class org.apache.sysds.api.mlcontext.MLContextUtil
The SystemDS welcome message
WHILE - org.apache.sysds.runtime.compress.workload.AWTreeNode.WTNodeType
 
WHILE - org.apache.sysds.runtime.controlprogram.parfor.opt.OptNode.NodeType
 
WhileProgramBlock - Class in org.apache.sysds.runtime.controlprogram
 
WhileProgramBlock(Program, ArrayList<Instruction>) - Constructor for class org.apache.sysds.runtime.controlprogram.WhileProgramBlock
 
WhileStatement - Class in org.apache.sysds.parser
 
WhileStatement() - Constructor for class org.apache.sysds.parser.WhileStatement
 
WhileStatementBlock - Class in org.apache.sysds.parser
 
WhileStatementBlock() - Constructor for class org.apache.sysds.parser.WhileStatementBlock
 
WhileStatementContext(DmlParser.StatementContext) - Constructor for class org.apache.sysds.parser.dml.DmlParser.WhileStatementContext
 
WHITESPACE - Static variable in class org.apache.sysds.parser.dml.DmlLexer
 
WHITESPACE - Static variable in class org.apache.sysds.parser.dml.DmlParser
 
WINSORIZE - org.apache.sysds.common.Builtins
 
WINSORIZEAPPLY - org.apache.sysds.common.Builtins
 
WithoutWeights - org.apache.sysds.lops.SortKeys.OperationTypes
 
WithWeights - org.apache.sysds.lops.SortKeys.OperationTypes
 
WOE - org.apache.sysds.common.Builtins
 
WOEAPPLY - org.apache.sysds.common.Builtins
 
WORKER_COMPUTE_BANDWIDTH_FLOPS - Static variable in class org.apache.sysds.hops.cost.FederatedCostEstimator
 
WORKER_DEGREE_OF_PARALLELISM - Static variable in class org.apache.sysds.hops.cost.FederatedCostEstimator
 
WORKER_NETWORK_BANDWIDTH_BYTES_PS - Static variable in class org.apache.sysds.hops.cost.FederatedCostEstimator
 
WORKER_READ_BANDWIDTH_BYTES_PS - Static variable in class org.apache.sysds.hops.cost.FederatedCostEstimator
 
WorkerController - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers
 
WorkerController() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.controllers.WorkerController
 
workerDataObjects - Variable in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics.FedStatsCollection
 
workerEvents - Variable in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics.FedStatsCollection
 
workerId - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.DataObjectModel
 
workerId - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.EventModel
 
workerId - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.HeavyHitterModel
 
workerId - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.RequestModel
 
workerId - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.TrafficModel
 
workerId - Variable in class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.UtilizationModel
 
WorkerModel - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.models
 
WorkerModel() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.WorkerModel
 
WorkerModel(Long) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.WorkerModel
 
WorkerModel(Long, String, String) - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.models.WorkerModel
 
workerRequests - Variable in class org.apache.sysds.runtime.controlprogram.federated.FederatedStatistics.FedStatsCollection
 
WorkerService - Class in org.apache.sysds.runtime.controlprogram.federated.monitoring.services
 
WorkerService() - Constructor for class org.apache.sysds.runtime.controlprogram.federated.monitoring.services.WorkerService
 
WORKLOAD - org.apache.sysds.lops.Compression.CompressConfig
 
WorkloadAnalyzer - Class in org.apache.sysds.runtime.compress.workload
 
workSpace - Variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNConvolutionAlgorithm
 
wrap(String, int) - Static method in class org.apache.sysds.utils.Statistics
 
wrapLookupIfNecessary(CNode, Hop) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
wrapLookupIfNecessary(CNode, Hop, boolean) - Static method in class org.apache.sysds.hops.codegen.template.TemplateUtils
 
write(byte[]) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
 
write(byte[], int, int) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
 
write(byte[], int, int) - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
 
write(int) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
 
write(int) - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
 
write(long, int) - Method in class org.apache.sysds.runtime.io.hdf5.H5BufferBuilder
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupOffset
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.ADictBasedColGroup
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDC
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupDDCFOR
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupLinearFunctional
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDC
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCFOR
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingle
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCSingleZeros
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupSDCZeros
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.ColGroupUncompressed
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.ADictionary
Write the dictionary to a DataOutput.
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.Dictionary
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionary
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.IdentityDictionarySlice
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.MatrixBlockDictionary
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.dictionary.QDictionary
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.ArrayIndex
 
write(DataOutput) - Method in interface org.apache.sysds.runtime.compress.colgroup.indexes.IColIndex
Write out the IO representation of this column index
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.RangeIndex
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.SingleIndex
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.indexes.TwoIndex
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.AMapToData
Serialize this object to the DataOutput given.
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToBit
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToByte
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToChar
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToCharPByte
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToInt
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToUByte
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.mapping.MapToZero
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.AOffset
Write the offsets to disk.
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetByte
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetChar
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetEmpty
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetSingle
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.colgroup.offset.OffsetTwo
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
write(DataOutput) - Method in class org.apache.sysds.runtime.compress.io.CompressedWriteBlock
 
write(DataOutput) - Method in class org.apache.sysds.runtime.controlprogram.parfor.ResultMergeTaggedMatrixIndexes
 
write(DataOutput) - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.PairWritableBlock
 
write(DataOutput) - Method in class org.apache.sysds.runtime.controlprogram.parfor.util.PairWritableCell
 
write(DataOutput) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
write(DataOutput) - Method in class org.apache.sysds.runtime.data.TensorIndexes
 
write(DataOutput) - Method in class org.apache.sysds.runtime.frame.data.columns.BitSetArray
 
write(DataOutput) - Method in class org.apache.sysds.runtime.frame.data.columns.BooleanArray
 
write(DataOutput) - Method in class org.apache.sysds.runtime.frame.data.columns.CharArray
 
write(DataOutput) - Method in class org.apache.sysds.runtime.frame.data.columns.ColumnMetadata
 
write(DataOutput) - Method in class org.apache.sysds.runtime.frame.data.columns.DoubleArray
 
write(DataOutput) - Method in class org.apache.sysds.runtime.frame.data.columns.FloatArray
 
write(DataOutput) - Method in class org.apache.sysds.runtime.frame.data.columns.IntegerArray
 
write(DataOutput) - Method in class org.apache.sysds.runtime.frame.data.columns.LongArray
 
write(DataOutput) - Method in class org.apache.sysds.runtime.frame.data.columns.OptionalArray
 
write(DataOutput) - Method in class org.apache.sysds.runtime.frame.data.columns.StringArray
 
write(DataOutput) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
write(DataOutput) - Method in class org.apache.sysds.runtime.instructions.cp.KahanObject
 
write(DataOutput) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
 
write(DataOutput) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
write(DataOutput) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
write(DataOutput) - Method in class org.apache.sysds.runtime.matrix.data.MatrixIndexes
 
write(DataOutput) - Method in class org.apache.sysds.runtime.matrix.data.TripleIndexes
 
write(DataOutput) - Method in class org.apache.sysds.runtime.matrix.data.WeightedCell
 
write(DataOutput) - Method in class org.apache.sysds.runtime.matrix.data.WeightedPair
 
write(String, FederationMap) - Static method in class org.apache.sysds.runtime.io.ReaderWriterFederated
TODO add writing to each of the federated locations so that they also save their matrices.
Write - org.apache.sysds.runtime.instructions.cp.VariableCPInstruction.VariableOperationCode
 
Write - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
WRITE - org.apache.sysds.parser.Expression.DataOp
 
WRITE_REPLICATION_FACTOR - Static variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock
 
WRITE_VALID_PARAM_NAMES - Static variable in class org.apache.sysds.parser.OutputStatement
 
writeBinaryBlockSequenceFileToHDFS(JobConf, String, String, boolean) - Method in class org.apache.sysds.runtime.controlprogram.parfor.DataPartitionerLocal
 
writeBinaryCellSequenceFileToHDFS(JobConf, String, String) - Method in class org.apache.sysds.runtime.controlprogram.parfor.DataPartitionerLocal
 
writeBitSet(BitSet, int) - Method in class org.apache.sysds.runtime.io.hdf5.H5BufferBuilder
 
writeBlock(String, CacheBlock<?>) - Static method in class org.apache.sysds.runtime.controlprogram.caching.LazyWriteBuffer
 
writeBlock(String, CacheBlock<?>) - Static method in class org.apache.sysds.runtime.controlprogram.caching.UnifiedMemoryManager
 
writeBlockData(DataOutput, BasicTensorBlock) - Method in class org.apache.sysds.runtime.data.TensorBlock
Write a BasicTensorBlock.
writeBlockSequenceToLocal(String, Pair<MatrixIndexes, MatrixValue>[], int) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
 
writeBoolean(boolean) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
 
writeBoolean(boolean) - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
 
writeBooleanToHDFS(boolean, String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
writeByte(int) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
 
writeByte(int) - Method in class org.apache.sysds.runtime.io.hdf5.H5BufferBuilder
 
writeByte(int) - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
 
writeByteArrayToLocal(String, byte[]) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
 
writeBytes(byte[]) - Method in class org.apache.sysds.runtime.io.hdf5.H5BufferBuilder
 
writeBytes(String) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
 
writeBytes(String) - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
 
writeCacheBlockToLocal(String, CacheBlock<?>) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
Writes a matrix/frame block to local file system.
writeCellListToLocal(String, LinkedList<Cell>) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.util.StagingFileUtils
 
writeChar(int) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
 
writeChar(int) - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
 
writeChars(String) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
 
writeChars(String) - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
 
writeCompressedMatrixToHDFS(MatrixBlock, String) - Static method in class org.apache.sysds.runtime.compress.io.WriterCompressed
 
writeCompressedMatrixToHDFS(MatrixBlock, String, int) - Static method in class org.apache.sysds.runtime.compress.io.WriterCompressed
 
writeCompressedMatrixToHDFS(MatrixBlock, String, long, long, int, long, boolean) - Static method in class org.apache.sysds.runtime.compress.io.WriterCompressed
 
writeDouble(double) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
 
writeDouble(double) - Method in class org.apache.sysds.runtime.io.hdf5.H5BufferBuilder
 
writeDouble(double) - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
 
writeDoubleArray(int, double[]) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
 
writeDoubleArray(int, double[]) - Method in interface org.apache.sysds.runtime.matrix.data.MatrixBlockDataOutput
Writes the double array of a dense block to the data output.
writeDoubleArray(int, double[]) - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
 
writeDoubleToHDFS(double, String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
writeEmptyMatrixToHDFS(String, long, long, int) - Method in class org.apache.sysds.runtime.compress.io.WriterCompressed
 
writeEmptyMatrixToHDFS(String, long, long, int) - Method in class org.apache.sysds.runtime.io.MatrixWriter
Writes a minimal entry to represent an empty matrix on hdfs.
writeEmptyMatrixToHDFS(String, long, long, int) - Method in class org.apache.sysds.runtime.io.WriterBinaryBlock
 
writeEmptyMatrixToHDFS(String, long, long, int) - Method in class org.apache.sysds.runtime.io.WriterHDF5
 
writeEmptyMatrixToHDFS(String, long, long, int) - Method in class org.apache.sysds.runtime.io.WriterMatrixMarket
 
writeEmptyMatrixToHDFS(String, long, long, int) - Method in class org.apache.sysds.runtime.io.WriterTextCell
 
writeEmptyMatrixToHDFS(String, long, long, int) - Method in class org.apache.sysds.runtime.io.WriterTextCSV
 
writeEmptyMatrixToHDFS(String, long, long, int) - Method in class org.apache.sysds.runtime.io.WriterTextLIBSVM
 
writeExternal(ObjectOutput) - 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 serialization.
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.data.TensorBlock
 
writeExternal(ObjectOutput) - 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.
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
 
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.instructions.cp.ListObject
Redirects the default java serialization via externalizable to our default hadoop writable serialization for efficient broadcast/rdd serialization.
writeExternal(ObjectOutput) - 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 serialization.
writeExternal(ObjectOutput) - 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 serialization.
writeExternal(ObjectOutput) - 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 serialization.
writeExternal(ObjectOutput) - 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 serialization.
writeExternal(ObjectOutput) - 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.
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.privacy.PrivacyConstraint
 
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.transform.decode.Decoder
Redirects the default java serialization via externalizable to our default hadoop writable serialization for efficient broadcast/rdd serialization.
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.transform.decode.DecoderComposite
 
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.transform.decode.DecoderDummycode
 
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.transform.decode.DecoderPassThrough
 
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.transform.decode.DecoderRecode
 
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoder
Redirects the default java serialization via externalizable to our default hadoop writable serialization for efficient broadcast/rdd serialization.
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderBin
 
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderComposite
 
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderFeatureHash
 
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.transform.encode.ColumnEncoderRecode
 
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.transform.encode.EncoderMVImpute
 
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.transform.encode.EncoderOmit
 
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.transform.encode.LegacyEncoder
Redirects the default java serialization via externalizable to our default hadoop writable serialization for efficient broadcast/rdd serialization.
writeExternal(ObjectOutput) - Method in class org.apache.sysds.runtime.transform.encode.MultiColumnEncoder
 
WriteFileTask(Path, JobConf, FileSystem, TensorBlock, long, long, int) - Constructor for class org.apache.sysds.runtime.io.TensorWriterBinaryBlockParallel.WriteFileTask
 
writeFloat(float) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
 
writeFloat(float) - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
 
writeFrameBlockToLocal(String, FrameBlock) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
Writes a frame block to local file system.
writeFrameRDDtoHDFS(RDDObject, String, Types.FileFormat) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
 
writeFrameToHDFS(FrameBlock, String, long, long) - Method in class org.apache.sysds.runtime.io.FrameWriter
 
writeFrameToHDFS(FrameBlock, String, long, long) - Method in class org.apache.sysds.runtime.io.FrameWriterBinaryBlock
 
writeFrameToHDFS(FrameBlock, String, long, long) - Method in class org.apache.sysds.runtime.io.FrameWriterProto
 
writeFrameToHDFS(FrameBlock, String, long, long) - Method in class org.apache.sysds.runtime.io.FrameWriterTextCell
 
writeFrameToHDFS(FrameBlock, String, long, long) - Method in class org.apache.sysds.runtime.io.FrameWriterTextCSV
 
writeFrameToHDFS(FrameBlock, String, Map<String, Integer>, long, long) - Method in class org.apache.sysds.runtime.io.FrameWriterJSONL
 
writeGroups(DataOutput, Collection<AColGroup>) - Static method in interface org.apache.sysds.runtime.compress.colgroup.ColGroupIO
Writes the ColGroups out to the DataOutput.
writeHDF5MatrixToHDFS(Path, JobConf, FileSystem, MatrixBlock) - Method in class org.apache.sysds.runtime.io.WriterHDF5Parallel
 
writeInt(int) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
 
writeInt(int) - Method in class org.apache.sysds.runtime.io.hdf5.H5BufferBuilder
 
writeInt(int) - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
 
writeIntToHDFS(long, String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
writeKeyMappingToLocal(String, long[][]) - Static method in class org.apache.sysds.runtime.controlprogram.parfor.util.StagingFileUtils
 
writeListToHDFS(ListObject, String, String, FileFormatProperties) - Static method in class org.apache.sysds.runtime.io.ListWriter
Writes a list object and all contained objects to a folder with related meta data.
writeLong(long) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
 
writeLong(long) - Method in class org.apache.sysds.runtime.io.hdf5.H5BufferBuilder
 
writeLong(long) - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
 
writeMatrixBlockToLocal(String, MatrixBlock) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
Writes a matrix block to local file system.
writeMatrixDescriptorToBuffer(ByteBuffer, int, int, long, long, long, long) - Method in interface org.apache.sysds.runtime.codegen.SpoofCUDAOperator
 
writeMatrixRDDtoHDFS(RDDObject, String, Types.FileFormat) - Static method in class org.apache.sysds.runtime.controlprogram.context.SparkExecutionContext
 
writeMatrixToHDFS(MatrixBlock, String, long, long, int, long) - Method in class org.apache.sysds.runtime.io.MatrixWriter
 
writeMatrixToHDFS(MatrixBlock, String, long, long, int, long, boolean) - Method in class org.apache.sysds.runtime.compress.io.WriterCompressed
 
writeMatrixToHDFS(MatrixBlock, String, long, long, int, long, boolean) - Method in class org.apache.sysds.runtime.io.MatrixWriter
 
writeMatrixToHDFS(MatrixBlock, String, long, long, int, long, boolean) - Method in class org.apache.sysds.runtime.io.WriterBinaryBlock
 
writeMatrixToHDFS(MatrixBlock, String, long, long, int, long, boolean) - Method in class org.apache.sysds.runtime.io.WriterHDF5
 
writeMatrixToHDFS(MatrixBlock, String, long, long, int, long, boolean) - Method in class org.apache.sysds.runtime.io.WriterMatrixMarket
 
writeMatrixToHDFS(MatrixBlock, String, long, long, int, long, boolean) - Method in class org.apache.sysds.runtime.io.WriterTextCell
 
writeMatrixToHDFS(MatrixBlock, String, long, long, int, long, boolean) - Method in class org.apache.sysds.runtime.io.WriterTextCSV
 
writeMatrixToHDFS(MatrixBlock, String, long, long, int, long, boolean) - Method in class org.apache.sysds.runtime.io.WriterTextLIBSVM
 
writeMatrixToHDFS(MatrixBlock, String, Types.FileFormat, DataCharacteristics) - Static method in class org.apache.sysds.runtime.util.DataConverter
 
writeMatrixToHDFS(MatrixBlock, String, Types.FileFormat, DataCharacteristics, int, FileFormatProperties) - Static method in class org.apache.sysds.runtime.util.DataConverter
 
writeMatrixToHDFS(MatrixBlock, String, Types.FileFormat, DataCharacteristics, int, FileFormatProperties, boolean) - Static method in class org.apache.sysds.runtime.util.DataConverter
 
writeMetaDataFile(String, Types.ValueType, Types.ValueType[], Types.DataType, DataCharacteristics, Types.FileFormat) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
writeMetaDataFile(String, Types.ValueType, Types.ValueType[], Types.DataType, DataCharacteristics, Types.FileFormat, FileFormatProperties) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
writeMetaDataFile(String, Types.ValueType, Types.ValueType[], Types.DataType, DataCharacteristics, Types.FileFormat, FileFormatProperties, PrivacyConstraint) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
writeMetaDataFile(String, Types.ValueType, Types.ValueType[], Types.DataType, DataCharacteristics, Types.FileFormat, PrivacyConstraint) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
writeMetaDataFile(String, Types.ValueType, DataCharacteristics, Types.FileFormat) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
writeMetaDataFile(String, Types.ValueType, DataCharacteristics, Types.FileFormat, FileFormatProperties) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
writeMetaDataFile(String, Types.ValueType, DataCharacteristics, Types.FileFormat, FileFormatProperties, PrivacyConstraint) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
writeMetaDataFile(String, Types.ValueType, DataCharacteristics, Types.FileFormat, PrivacyConstraint) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
writeMetaDataFileFrame(String, Types.ValueType[], DataCharacteristics, Types.FileFormat) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
writeObjectToHDFS(Object, String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
WriterBinaryBlock - Class in org.apache.sysds.runtime.io
 
WriterBinaryBlock(int) - Constructor for class org.apache.sysds.runtime.io.WriterBinaryBlock
 
WriterBinaryBlockParallel - Class in org.apache.sysds.runtime.io
 
WriterBinaryBlockParallel(int) - Constructor for class org.apache.sysds.runtime.io.WriterBinaryBlockParallel
 
WriterCompressed - Class in org.apache.sysds.runtime.compress.io
 
WriterCompressed() - Constructor for class org.apache.sysds.runtime.compress.io.WriterCompressed
 
writeRDDToHDFS(JavaPairRDD<MatrixIndexes, MatrixBlock>, String) - Static method in class org.apache.sysds.runtime.compress.io.WriterCompressed
 
writeRDDToHDFS(JavaPairRDD<MatrixIndexes, MatrixBlock>, String, int, DataCharacteristics) - Static method in class org.apache.sysds.runtime.compress.io.WriterCompressed
 
WriterHDF5 - Class in org.apache.sysds.runtime.io
 
WriterHDF5(FileFormatPropertiesHDF5) - Constructor for class org.apache.sysds.runtime.io.WriterHDF5
 
WriterHDF5Parallel - Class in org.apache.sysds.runtime.io
 
WriterHDF5Parallel(FileFormatPropertiesHDF5) - Constructor for class org.apache.sysds.runtime.io.WriterHDF5Parallel
 
WriterMatrixMarket - Class in org.apache.sysds.runtime.io
 
WriterMatrixMarket() - Constructor for class org.apache.sysds.runtime.io.WriterMatrixMarket
 
WriterMatrixMarketParallel - Class in org.apache.sysds.runtime.io
 
WriterMatrixMarketParallel() - Constructor for class org.apache.sysds.runtime.io.WriterMatrixMarketParallel
 
WriterTextCell - Class in org.apache.sysds.runtime.io
 
WriterTextCell() - Constructor for class org.apache.sysds.runtime.io.WriterTextCell
 
WriterTextCellParallel - Class in org.apache.sysds.runtime.io
 
WriterTextCellParallel() - Constructor for class org.apache.sysds.runtime.io.WriterTextCellParallel
 
WriterTextCSV - Class in org.apache.sysds.runtime.io
 
WriterTextCSV(FileFormatPropertiesCSV) - Constructor for class org.apache.sysds.runtime.io.WriterTextCSV
 
WriterTextCSVParallel - Class in org.apache.sysds.runtime.io
 
WriterTextCSVParallel(FileFormatPropertiesCSV) - Constructor for class org.apache.sysds.runtime.io.WriterTextCSVParallel
 
WriterTextLIBSVM - Class in org.apache.sysds.runtime.io
 
WriterTextLIBSVM(FileFormatPropertiesLIBSVM) - Constructor for class org.apache.sysds.runtime.io.WriterTextLIBSVM
 
WriterTextLIBSVMParallel - Class in org.apache.sysds.runtime.io
 
WriterTextLIBSVMParallel(FileFormatPropertiesLIBSVM) - Constructor for class org.apache.sysds.runtime.io.WriterTextLIBSVMParallel
 
writeScalarMetaDataFile(String, Types.ValueType) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
writeScalarMetaDataFile(String, Types.ValueType, PrivacyConstraint) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
writeScalarToHDFS(ScalarObject, String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
Helper function to write scalars to HDFS, including writing its meta data and removing CRC files in local file system
writeShort(int) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
 
writeShort(int) - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
 
writeShort(short) - Method in class org.apache.sysds.runtime.io.hdf5.H5BufferBuilder
 
writeSparseRows(int, SparseBlock) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
 
writeSparseRows(int, SparseBlock) - Method in interface org.apache.sysds.runtime.matrix.data.MatrixBlockDataOutput
Writes the sparse rows array of a sparse block to the data output.
writeSparseRows(int, SparseBlock) - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
 
WriteSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 
writeStringToHDFS(String, String) - Static method in class org.apache.sysds.runtime.util.HDFSTool
 
writeTensorToHDFS(TensorBlock, String, int) - Method in class org.apache.sysds.runtime.io.TensorWriter
 
writeTensorToHDFS(TensorBlock, String, int) - Method in class org.apache.sysds.runtime.io.TensorWriterBinaryBlock
 
writeTensorToHDFS(TensorBlock, String, int) - Method in class org.apache.sysds.runtime.io.TensorWriterTextCell
 
writeTensorToHDFS(TensorBlock, String, Types.FileFormat, DataCharacteristics) - Static method in class org.apache.sysds.runtime.util.DataConverter
 
writeTextCellFileToHDFS(JobConf, String, String) - Method in class org.apache.sysds.runtime.controlprogram.parfor.DataPartitionerLocal
 
writeTextFile(File, String) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
Writes a simple text file to local file system.
writeTraceToHDFS(String, String) - Static method in class org.apache.sysds.runtime.lineage.LineageItemUtils
 
writeUTF(String) - Method in class org.apache.sysds.runtime.controlprogram.caching.CacheDataOutput
 
writeUTF(String) - Method in class org.apache.sysds.runtime.util.FastBufferedDataOutputStream
 
writeWritableToLocal(String, Writable) - Static method in class org.apache.sysds.runtime.util.LocalFileUtils
Writes an arbitrary writable to local file system, using a fused buffered writer with special support for matrix blocks.
WSIGMOID - org.apache.sysds.common.Types.OpOp4
 
WSLOSS - org.apache.sysds.common.Types.OpOp4
 
WTreeNode - Class in org.apache.sysds.runtime.compress.workload
A Node in the WTree, this is used for any nodes that are not the root.
WTreeNode(AWTreeNode.WTNodeType, int) - Constructor for class org.apache.sysds.runtime.compress.workload.WTreeNode
 
WTreeRoot - Class in org.apache.sysds.runtime.compress.workload
The root node of the tree, located at the top of the tree.
WTreeRoot(Hop) - Constructor for class org.apache.sysds.runtime.compress.workload.WTreeRoot
 
wtype1 - Variable in class org.apache.sysds.runtime.matrix.operators.QuaternaryOperator
 
wtype2 - Variable in class org.apache.sysds.runtime.matrix.operators.QuaternaryOperator
 
wtype3 - Variable in class org.apache.sysds.runtime.matrix.operators.QuaternaryOperator
 
wtype4 - Variable in class org.apache.sysds.runtime.matrix.operators.QuaternaryOperator
 
wtype5 - Variable in class org.apache.sysds.runtime.matrix.operators.QuaternaryOperator
 
WUMM - org.apache.sysds.common.Types.OpOp4
 

X

xDesc - Variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNPoolingDescriptors
 
XDUMMY1 - org.apache.sysds.common.Builtins
 
XDUMMY2 - org.apache.sysds.common.Builtins
 
XGBOOST - org.apache.sysds.common.Builtins
 
XGBOOSTPREDICT - org.apache.sysds.common.Builtins
 
XGBOOSTPREDICT_CLASS - org.apache.sysds.common.Builtins
 
XGBOOSTPREDICT_REG - org.apache.sysds.common.Builtins
 
Xor - Class in org.apache.sysds.runtime.functionobjects
 
XOR - org.apache.sysds.common.Builtins
 
XOR - org.apache.sysds.common.Types.OpOp2
 
XOR - org.apache.sysds.hops.codegen.cplan.CNodeBinary.BinType
 
XtwXv - org.apache.sysds.lops.MapMultChain.ChainType
 
XtXv - org.apache.sysds.lops.MapMultChain.ChainType
 
XtXvy - org.apache.sysds.lops.MapMultChain.ChainType
 

Y

yDesc - Variable in class org.apache.sysds.runtime.matrix.data.LibMatrixCuDNNPoolingDescriptors
 

Z

zero() - Static method in class org.apache.sysds.runtime.matrix.data.LibMatrixCUDA
Convenience method to get a pointer to value '0.0f' on device.
ZERO - org.apache.sysds.runtime.compress.colgroup.mapping.MapToFactory.MAP_TYPE
 
ZeroOut - org.apache.sysds.lops.Lop.Type
 
zeroOutOperations(FrameBlock, IndexRange, boolean, int, int, int, int) - Method in class org.apache.sysds.runtime.frame.data.FrameBlock
This function ZERO OUT the data in the slicing window applicable for this block.
zeroOutOperations(MatrixValue, IndexRange, boolean) - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
 
zeroOutOperations(MatrixValue, IndexRange, boolean) - Method in class org.apache.sysds.runtime.matrix.data.CM_N_COVCell
 
zeroOutOperations(MatrixValue, IndexRange, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixBlock
 
zeroOutOperations(MatrixValue, IndexRange, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixCell
 
zeroOutOperations(MatrixValue, IndexRange, boolean) - Method in class org.apache.sysds.runtime.matrix.data.MatrixValue
 
ZIPMM - org.apache.sysds.hops.AggBinaryOp.MMultMethod
 
ZIPMM - org.apache.sysds.runtime.instructions.spark.SPInstruction.SPType
 
ZipmmSPInstruction - Class in org.apache.sysds.runtime.instructions.spark
 

_

_activeAM - Static variable in class org.apache.sysds.api.DMLScript
 
_ATN - Static variable in class org.apache.sysds.parser.dml.DmlLexer
 
_ATN - Static variable in class org.apache.sysds.parser.dml.DmlParser
 
_avgRows - Variable in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionFederatedScheme.BalanceMetrics
 
_balanceMetrics - Variable in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionFederatedScheme.Result
 
_beginColumn - Variable in class org.apache.sysds.hops.Hop
 
_beginColumn - Variable in class org.apache.sysds.lops.Lop
 
_beginColumn - Variable in class org.apache.sysds.runtime.controlprogram.ProgramBlock
 
_beginLine - Variable in class org.apache.sysds.hops.Hop
 
_beginLine - Variable in class org.apache.sysds.lops.Lop
 
_beginLine - Variable in class org.apache.sysds.runtime.controlprogram.ProgramBlock
 
_correction - Variable in class org.apache.sysds.runtime.instructions.cp.KahanObject
 
_dependencyTasks - Variable in class org.apache.sysds.runtime.util.DependencyTask
 
_domainSize - Variable in class org.apache.sysds.runtime.transform.encode.ColumnEncoderDummycode
 
_domainSize - Variable in class org.apache.sysds.runtime.transform.encode.ColumnEncoderUDF
 
_dpf - Variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
 
_endColumn - Variable in class org.apache.sysds.hops.Hop
 
_endColumn - Variable in class org.apache.sysds.lops.Lop
 
_endColumn - Variable in class org.apache.sysds.runtime.controlprogram.ProgramBlock
 
_endLine - Variable in class org.apache.sysds.hops.Hop
 
_endLine - Variable in class org.apache.sysds.lops.Lop
 
_endLine - Variable in class org.apache.sysds.runtime.controlprogram.ProgramBlock
 
_filename - Variable in class org.apache.sysds.hops.Hop
 
_filename - Variable in class org.apache.sysds.lops.Lop
 
_filename - Variable in class org.apache.sysds.runtime.controlprogram.ProgramBlock
 
_fromHopID - Variable in class org.apache.sysds.hops.codegen.opt.InterestingPoint
 
_functionName - Variable in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
 
_input1 - Variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
 
_input2 - Variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
 
_isAccum - Variable in class org.apache.sysds.parser.ParForStatementBlock.ResultVar
 
_mainClassLoader - Static variable in class org.apache.sysds.runtime.codegen.CodegenUtils
 
_maxRows - Variable in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionFederatedScheme.BalanceMetrics
 
_minRows - Variable in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionFederatedScheme.BalanceMetrics
 
_N - Variable in class org.apache.sysds.runtime.controlprogram.ParForProgramBlock.PartitionFormat
 
_name - Variable in class org.apache.sysds.parser.ParForStatementBlock.ResultVar
 
_namespace - Variable in class org.apache.sysds.runtime.controlprogram.FunctionProgramBlock
 
_out - Variable in class org.apache.sysds.runtime.instructions.gpu.SpoofCUDAInstruction
 
_output - Variable in class org.apache.sysds.runtime.instructions.gpu.GPUInstruction
 
_pFeatures - Variable in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionFederatedScheme.Result
 
_pLabels - Variable in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionFederatedScheme.Result
 
_rl - Variable in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNRelu.ReluBackward
 
_ru - Variable in class org.apache.sysds.runtime.matrix.data.LibMatrixDNNRelu.ReluBackward
 
_serializedATN - Static variable in class org.apache.sysds.parser.dml.DmlLexer
 
_serializedATN - Static variable in class org.apache.sysds.parser.dml.DmlParser
 
_sum - Variable in class org.apache.sysds.runtime.instructions.cp.KahanObject
 
_suppressPrint2Stdout - Static variable in class org.apache.sysds.api.DMLScript
 
_text - Variable in class org.apache.sysds.hops.Hop
 
_text - Variable in class org.apache.sysds.runtime.controlprogram.ProgramBlock
 
_toHopID - Variable in class org.apache.sysds.hops.codegen.opt.InterestingPoint
 
_uuid - Static variable in class org.apache.sysds.api.DMLScript
 
_weightingFactors - Variable in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionFederatedScheme.Result
 
_workerNum - Variable in class org.apache.sysds.runtime.controlprogram.paramserv.dp.DataPartitionFederatedScheme.Result
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
All Classes All Packages