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
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
- ACLAScheme - Class in org.apache.sysds.runtime.compress.colgroup.scheme
- 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.
- ACount - Class in org.apache.sysds.runtime.compress.utils
- ACount() - Constructor for class org.apache.sysds.runtime.compress.utils.ACount
- ACount.DArrCounts - Class in org.apache.sysds.runtime.compress.utils
- ACount.DCounts - Class in org.apache.sysds.runtime.compress.utils
- 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
- 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
SPInstruction
s 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_BINARY_UPDATE_IN_PLACE - Static variable in class org.apache.sysds.hops.OptimizerUtils
-
Enables update-in-place for binary operators if the first input has no consumers.
- 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
SPInstruction
s 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.decode.DecoderFactory.DecoderType
- 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(Lop, Lop, Types.OpOp2, Types.DataType, Types.ValueType, Types.ExecType, int, boolean) - 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 aFrameObject
. - binaryBlocksToFrameObject(JavaPairRDD<Long, FrameBlock>, FrameMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a
JavaPairRDD<Long, FrameBlock>
to aFrameObject
. - binaryBlocksToMatrixBlock(JavaPairRDD<MatrixIndexes, MatrixBlock>, MatrixMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a
JavaPairRDD<MatrixIndexes, MatrixBlock>
to aMatrixBlock
- binaryBlocksToMatrixObject(JavaPairRDD<MatrixIndexes, MatrixBlock>) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a
JavaPairRDD<MatrixIndexes, MatrixBlock>
to aMatrixObject
. - binaryBlocksToMatrixObject(JavaPairRDD<MatrixIndexes, MatrixBlock>, MatrixMetadata) - Static method in class org.apache.sysds.api.mlcontext.MLContextConversionUtil
-
Convert a
JavaPairRDD<MatrixIndexes, MatrixBlock>
to aMatrixObject
. - 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
-
Binary (cell operations): aij + bij Properties: Symbol: *, -, +, ...
- 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 class for operations that have two inputs.
- 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.compress.utils.CompressRDDClean
- 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() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroup
-
Clear variables that can be recomputed from the allocation of this columngroup.
- clear() - Method in class org.apache.sysds.runtime.compress.colgroup.AColGroupValue
- 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
- clearCounts() - Method in class org.apache.sysds.runtime.compress.CompressedMatrixBlock
- 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>, HashSet<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 the map of index matrix blocks into a single MatrixBlock.
- 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
- CompressionPlanFactory - Class in org.apache.sysds.runtime.compress.plan
- CompressionPlanFactory() - Constructor for class org.apache.sysds.runtime.compress.plan.CompressionPlanFactory
- 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
- CompressRDDClean - Class in org.apache.sysds.runtime.compress.utils
- CompressRDDClean() - Constructor for class org.apache.sysds.runtime.compress.utils.CompressRDDClean
- 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