public class CompressedMatrixBlock extends MatrixBlock implements Externalizable
Modifier and Type | Class and Description |
---|---|
static class |
CompressedMatrixBlock.CompressionStatistics |
MatrixBlock.BlockType, MatrixBlock.SparsityEstimate
MatrixValue.CellIndex
Modifier and Type | Field and Description |
---|---|
protected ArrayList<ColGroup> |
_colGroups |
protected boolean |
_sharedDDC1Dict |
protected CompressedMatrixBlock.CompressionStatistics |
_stats |
static boolean |
ALLOW_DDC_ENCODING |
static boolean |
ALLOW_SHARED_DDC1_DICTIONARY |
static boolean |
INVESTIGATE_ESTIMATES |
static boolean |
MATERIALIZE_ZEROS |
static long |
MIN_PAR_AGG_THRESHOLD |
static boolean |
TRANSPOSE_INPUT |
clen, CONVERT_MCSR_TO_CSR_ON_DEEP_SERIALIZE, DEFAULT_INPLACE_SPARSEBLOCK, DEFAULT_SPARSEBLOCK, denseBlock, estimatedNNzsPerRow, HEADER_SIZE, MAX_SHALLOW_SERIALIZE_OVERHEAD, nonZeros, rlen, sparse, sparseBlock, SPARSITY_TURN_POINT, ULTRA_SPARSE_BLOCK_NNZ, ULTRA_SPARSITY_TURN_POINT, ULTRA_SPARSITY_TURN_POINT2
Constructor and Description |
---|
CompressedMatrixBlock() |
CompressedMatrixBlock(int rl,
int cl,
boolean sparse)
Main constructor for building a block from scratch.
|
CompressedMatrixBlock(MatrixBlock mb)
"Copy" constructor to populate this compressed block with the
uncompressed contents of a conventional block.
|
Modifier and Type | Method and Description |
---|---|
MatrixBlock |
aggregateBinaryOperations(MatrixBlock m1,
MatrixBlock m2,
MatrixBlock ret,
org.apache.sysml.runtime.matrix.operators.AggregateBinaryOperator op) |
MatrixBlock |
aggregateBinaryOperations(MatrixIndexes m1Index,
MatrixBlock m1Value,
MatrixIndexes m2Index,
MatrixBlock m2Value,
MatrixBlock result,
org.apache.sysml.runtime.matrix.operators.AggregateBinaryOperator op) |
MatrixBlock |
aggregateTernaryOperations(MatrixBlock m1,
MatrixBlock m2,
MatrixBlock m3,
MatrixBlock ret,
org.apache.sysml.runtime.matrix.operators.AggregateTernaryOperator op,
boolean inCP) |
MatrixValue |
aggregateUnaryOperations(org.apache.sysml.runtime.matrix.operators.AggregateUnaryOperator op,
MatrixValue result,
int blockingFactorRow,
int blockingFactorCol,
MatrixIndexes indexesIn) |
MatrixValue |
aggregateUnaryOperations(org.apache.sysml.runtime.matrix.operators.AggregateUnaryOperator op,
MatrixValue result,
int blockingFactorRow,
int blockingFactorCol,
MatrixIndexes indexesIn,
boolean inCP) |
MatrixBlock |
append(MatrixBlock that,
MatrixBlock ret) |
MatrixBlock |
append(MatrixBlock that,
MatrixBlock ret,
boolean cbind) |
void |
append(MatrixValue v2,
ArrayList<org.apache.sysml.runtime.matrix.mapred.IndexedMatrixValue> outlist,
int blockRowFactor,
int blockColFactor,
boolean cbind,
boolean m2IsLast,
int nextNCol) |
MatrixValue |
binaryOperations(org.apache.sysml.runtime.matrix.operators.BinaryOperator op,
MatrixValue thatValue,
MatrixValue result) |
void |
binaryOperationsInPlace(org.apache.sysml.runtime.matrix.operators.BinaryOperator op,
MatrixValue thatValue) |
MatrixBlock |
chainMatrixMultOperations(MatrixBlock v,
MatrixBlock w,
MatrixBlock out,
org.apache.sysml.lops.MapMultChain.ChainType ctype) |
MatrixBlock |
chainMatrixMultOperations(MatrixBlock v,
MatrixBlock w,
MatrixBlock out,
org.apache.sysml.lops.MapMultChain.ChainType ctype,
int k) |
org.apache.sysml.runtime.instructions.cp.CM_COV_Object |
cmOperations(org.apache.sysml.runtime.matrix.operators.CMOperator op) |
org.apache.sysml.runtime.instructions.cp.CM_COV_Object |
cmOperations(org.apache.sysml.runtime.matrix.operators.CMOperator op,
MatrixBlock weights) |
MatrixBlock |
compress()
Compress the contents of this matrix block.
|
MatrixBlock |
compress(int k)
Compress block.
|
int[] |
countNonZerosPerRow(int rl,
int ru) |
org.apache.sysml.runtime.instructions.cp.CM_COV_Object |
covOperations(org.apache.sysml.runtime.matrix.operators.COVOperator op,
MatrixBlock that) |
org.apache.sysml.runtime.instructions.cp.CM_COV_Object |
covOperations(org.apache.sysml.runtime.matrix.operators.COVOperator op,
MatrixBlock that,
MatrixBlock weights) |
void |
ctableOperations(org.apache.sysml.runtime.matrix.operators.Operator op,
double scalar,
double scalar2,
CTableMap resultMap,
MatrixBlock resultBlock)
D = ctable(A,v2,w)
this <- A; scalar_that <- v2; scalar_that2 <- w; result <- D
(i1,j1,v1) from input1 (this)
(v2) from sclar_input2 (scalarThat)
(w) from scalar_input3 (scalarThat2)
|
void |
ctableOperations(org.apache.sysml.runtime.matrix.operators.Operator op,
double scalar,
MatrixValue that,
CTableMap resultMap,
MatrixBlock resultBlock)
D = ctable(A,v2,W)
this <- A; scalarThat <- v2; that2 <- W; result <- D
(i1,j1,v1) from input1 (this)
(v2) from sclar_input2 (scalarThat)
(i3,j3,w) from input3 (that2)
|
void |
ctableOperations(org.apache.sysml.runtime.matrix.operators.Operator op,
MatrixIndexes ix1,
double scalar,
boolean left,
int brlen,
CTableMap resultMap,
MatrixBlock resultBlock)
Specific ctable case of ctable(seq(...),X), where X is the only
matrix input.
|
void |
ctableOperations(org.apache.sysml.runtime.matrix.operators.Operator op,
MatrixValue that,
double scalar,
boolean ignoreZeros,
CTableMap resultMap,
MatrixBlock resultBlock)
D = ctable(A,B,w)
this <- A; that <- B; scalar_that2 <- w; result <- D
(i1,j1,v1) from input1 (this)
(i1,j1,v2) from input2 (that)
(w) from scalar_input3 (scalarThat2)
NOTE: This method supports both vectors and matrices.
|
void |
ctableOperations(org.apache.sysml.runtime.matrix.operators.Operator op,
MatrixValue that,
MatrixValue that2,
CTableMap resultMap)
D = ctable(A,B,W)
this <- A; that <- B; that2 <- W; result <- D
(i1,j1,v1) from input1 (this)
(i1,j1,v2) from input2 (that)
(i1,j1,w) from input3 (that2)
|
void |
ctableOperations(org.apache.sysml.runtime.matrix.operators.Operator op,
MatrixValue that,
MatrixValue that2,
CTableMap resultMap,
MatrixBlock resultBlock) |
MatrixBlock |
ctableSeqOperations(MatrixValue that,
double scalar,
MatrixBlock resultBlock)
D = ctable(seq,A,w)
this <- seq; thatMatrix <- A; thatScalar <- w; result <- D
(i1,j1,v1) from input1 (this)
(i1,j1,v2) from input2 (that)
(w) from scalar_input3 (scalarThat2)
|
MatrixBlock |
decompress()
Decompress block.
|
MatrixBlock |
decompress(int k)
Decompress block.
|
long |
estimateCompressedSizeInMemory()
Obtain an upper bound on the memory used to store the compressed block.
|
ArrayList<ColGroup> |
getColGroups()
Obtain the column groups.
|
CompressedMatrixBlock.CompressionStatistics |
getCompressionStatistics() |
Iterator<double[]> |
getDenseRowIterator(int rl,
int ru) |
long |
getExactSizeOnDisk()
NOTE: The used estimates must be kept consistent with the respective write functions.
|
Iterator<IJV> |
getIterator(int rl,
int ru,
boolean inclZeros) |
Iterator<IJV> |
getIterator(int rl,
int ru,
int cgl,
int cgu,
boolean inclZeros) |
int |
getNumColGroups() |
Iterator<SparseRow> |
getSparseRowIterator(int rl,
int ru) |
MatrixBlock |
groupedAggOperations(MatrixValue tgt,
MatrixValue wghts,
MatrixValue ret,
int ngroups,
org.apache.sysml.runtime.matrix.operators.Operator op)
Invocation from CP instructions.
|
MatrixBlock |
groupedAggOperations(MatrixValue tgt,
MatrixValue wghts,
MatrixValue ret,
int ngroups,
org.apache.sysml.runtime.matrix.operators.Operator op,
int k) |
boolean |
hasUncompressedColGroup() |
void |
incrementalAggregate(org.apache.sysml.runtime.matrix.operators.AggregateOperator aggOp,
MatrixValue newWithCorrection) |
void |
incrementalAggregate(org.apache.sysml.runtime.matrix.operators.AggregateOperator aggOp,
MatrixValue correction,
MatrixValue newWithCorrection,
boolean deep) |
boolean |
isCompressed()
Obtain whether this block is in compressed form or not.
|
boolean |
isEmptyBlock(boolean safe) |
boolean |
isShallowSerialize()
Indicates if the cache block is subject to shallow serialized,
which is generally true if in-memory size and serialized size
are almost identical allowing to avoid unnecessary deep serialize.
|
boolean |
isShallowSerialize(boolean inclConvert)
Indicates if the cache block is subject to shallow serialized,
which is generally true if in-memory size and serialized size
are almost identical allowing to avoid unnecessary deep serialize.
|
boolean |
isSingleUncompressedGroup() |
MatrixBlock |
leftIndexingOperations(MatrixBlock rhsMatrix,
int rl,
int ru,
int cl,
int cu,
MatrixBlock ret,
org.apache.sysml.runtime.controlprogram.caching.MatrixObject.UpdateType update) |
MatrixBlock |
leftIndexingOperations(org.apache.sysml.runtime.instructions.cp.ScalarObject scalar,
int rl,
int cl,
MatrixBlock ret,
org.apache.sysml.runtime.controlprogram.caching.MatrixObject.UpdateType update)
Explicitly allow left indexing for scalars.
|
void |
permutationMatrixMultOperations(MatrixValue m2Val,
MatrixValue out1Val,
MatrixValue out2Val) |
void |
permutationMatrixMultOperations(MatrixValue m2Val,
MatrixValue out1Val,
MatrixValue out2Val,
int k) |
MatrixBlock |
quaternaryOperations(org.apache.sysml.runtime.matrix.operators.QuaternaryOperator qop,
MatrixBlock um,
MatrixBlock vm,
MatrixBlock wm,
MatrixBlock out) |
MatrixBlock |
quaternaryOperations(org.apache.sysml.runtime.matrix.operators.QuaternaryOperator qop,
MatrixBlock um,
MatrixBlock vm,
MatrixBlock wm,
MatrixBlock out,
int k) |
double |
quickGetValue(int r,
int c) |
MatrixBlock |
randOperationsInPlace(RandomMatrixGenerator rgen,
org.apache.commons.math3.random.Well1024a bigrand,
long bSeed)
Function to generate a matrix of random numbers.
|
MatrixBlock |
randOperationsInPlace(RandomMatrixGenerator rgen,
org.apache.commons.math3.random.Well1024a bigrand,
long bSeed,
int k)
Function to generate a matrix of random numbers.
|
void |
readExternal(ObjectInput is)
Redirects the default java serialization via externalizable to our default
hadoop writable serialization for efficient broadcast/rdd deserialization.
|
void |
readFields(DataInput in) |
MatrixBlock |
removeEmptyOperations(MatrixBlock ret,
boolean rows,
boolean emptyReturn) |
MatrixBlock |
removeEmptyOperations(MatrixBlock ret,
boolean rows,
boolean emptyReturn,
MatrixBlock select) |
MatrixValue |
reorgOperations(org.apache.sysml.runtime.matrix.operators.ReorgOperator op,
MatrixValue ret,
int startRow,
int startColumn,
int length) |
MatrixValue |
replaceOperations(MatrixValue result,
double pattern,
double replacement) |
MatrixBlock |
rexpandOperations(MatrixBlock ret,
double max,
boolean rows,
boolean cast,
boolean ignore,
int k) |
MatrixValue |
scalarOperations(org.apache.sysml.runtime.matrix.operators.ScalarOperator sop,
MatrixValue result) |
MatrixBlock |
seqOperationsInPlace(double from,
double to,
double incr) |
void |
slice(ArrayList<org.apache.sysml.runtime.matrix.mapred.IndexedMatrixValue> outlist,
org.apache.sysml.runtime.util.IndexRange range,
int rowCut,
int colCut,
int normalBlockRowFactor,
int normalBlockColFactor,
int boundaryRlen,
int boundaryClen) |
MatrixBlock |
slice(int rl,
int ru,
int cl,
int cu,
org.apache.sysml.runtime.controlprogram.caching.CacheBlock ret)
Slice a sub block out of the current block and write into the given output block.
|
MatrixValue |
sortOperations(MatrixValue weights,
MatrixValue result) |
MatrixBlock |
ternaryOperations(org.apache.sysml.runtime.matrix.operators.TernaryOperator op,
MatrixBlock m2,
MatrixBlock m3,
MatrixBlock ret) |
void |
toShallowSerializeBlock()
Converts a cache block that is not shallow serializable into
a form that is shallow serializable.
|
MatrixBlock |
transposeSelfMatrixMultOperations(MatrixBlock out,
org.apache.sysml.lops.MMTSJ.MMTSJType tstype) |
MatrixBlock |
transposeSelfMatrixMultOperations(MatrixBlock out,
org.apache.sysml.lops.MMTSJ.MMTSJType tstype,
int k) |
MatrixBlock |
uaggouterchainOperations(MatrixBlock mbLeft,
MatrixBlock mbRight,
MatrixBlock mbOut,
org.apache.sysml.runtime.matrix.operators.BinaryOperator bOp,
org.apache.sysml.runtime.matrix.operators.AggregateUnaryOperator uaggOp) |
MatrixValue |
unaryOperations(org.apache.sysml.runtime.matrix.operators.UnaryOperator op,
MatrixValue result) |
void |
write(DataOutput out) |
void |
writeExternal(ObjectOutput os)
Redirects the default java serialization via externalizable to our default
hadoop writable serialization for efficient broadcast/rdd serialization.
|
MatrixValue |
zeroOutOperations(MatrixValue result,
org.apache.sysml.runtime.util.IndexRange range,
boolean complementary) |
allocateAndResetSparseBlock, allocateBlock, allocateDenseBlock, allocateDenseBlock, allocateDenseBlockUnsafe, allocateSparseRowsBlock, allocateSparseRowsBlock, append, appendRow, appendRow, appendRowToSparse, appendToSparse, appendToSparse, appendValue, checkNaN, checkNonZeros, checkSparseRows, checkSparseRows, cleanupBlock, compactEmptyBlock, compareTo, computeIQMCorrection, copy, copy, copy, copyShallow, dropLastRowsOrColumns, equals, estimateSizeDenseInMemory, estimateSizeInMemory, estimateSizeInMemory, estimateSizeOnDisk, estimateSizeOnDisk, estimateSizeSparseInMemory, estimateSizeSparseInMemory, estimateSparsityOnAggBinary, evalSparseFormatInMemory, evalSparseFormatInMemory, evalSparseFormatOnDisk, evalSparseFormatOnDisk, examSparsity, examSparsity, extractTriangular, getDenseBlock, getDenseBlockValues, getExactSerializedSize, getInMemorySize, getLength, getMatrixCharacteristics, getNonZeros, getNumColumns, getNumRows, getSparseBlock, getSparseBlockIterator, getSparseBlockIterator, getSparsity, getValue, getValueDenseUnsafe, hashCode, init, init, interQuartileMean, isAllocated, isEmpty, isEmptyBlock, isInSparseFormat, isThreadSafe, isThreadSafe, isUltraSparse, isUltraSparse, isUltraSparsePermutationMatrix, isVector, leftIndexingOperations, max, mean, median, merge, merge, merge, min, minNonZero, naryOperations, pickValue, pickValue, pickValues, prod, quickSetValue, randOperations, randOperations, randOperations, randOperations, recomputeNonZeros, recomputeNonZeros, recomputeNonZeros, reset, reset, reset, reset, reset, reset, sampleOperations, seqOperations, setNonZeros, setNumColumns, setNumRows, setSparseBlock, setValue, slice, slice, slice, sortSparseRows, sortSparseRows, sparseToDense, sum, sumSq, sumWeightForQuantile, toString
public static final boolean TRANSPOSE_INPUT
public static final boolean MATERIALIZE_ZEROS
public static final long MIN_PAR_AGG_THRESHOLD
public static final boolean INVESTIGATE_ESTIMATES
public static boolean ALLOW_DDC_ENCODING
public static final boolean ALLOW_SHARED_DDC1_DICTIONARY
protected CompressedMatrixBlock.CompressionStatistics _stats
protected boolean _sharedDDC1Dict
public CompressedMatrixBlock()
public CompressedMatrixBlock(int rl, int cl, boolean sparse)
rl
- number of rows in the blockcl
- number of columnssparse
- true if the UNCOMPRESSED representation of the block should be
sparsepublic CompressedMatrixBlock(MatrixBlock mb)
mb
- matrix blockpublic ArrayList<ColGroup> getColGroups()
public int getNumColGroups()
public boolean isCompressed()
public boolean isSingleUncompressedGroup()
public boolean isEmptyBlock(boolean safe)
isEmptyBlock
in class MatrixBlock
public MatrixBlock compress()
public MatrixBlock compress(int k)
k
- number of threadspublic CompressedMatrixBlock.CompressionStatistics getCompressionStatistics()
public MatrixBlock decompress()
public MatrixBlock decompress(int k)
k
- degree of parallelismpublic long estimateCompressedSizeInMemory()
public double quickGetValue(int r, int c)
quickGetValue
in class MatrixBlock
public long getExactSizeOnDisk()
MatrixBlock
getExactSizeOnDisk
in class MatrixBlock
public boolean isShallowSerialize()
org.apache.sysml.runtime.controlprogram.caching.CacheBlock
isShallowSerialize
in interface org.apache.sysml.runtime.controlprogram.caching.CacheBlock
isShallowSerialize
in class MatrixBlock
public boolean isShallowSerialize(boolean inclConvert)
org.apache.sysml.runtime.controlprogram.caching.CacheBlock
isShallowSerialize
in interface org.apache.sysml.runtime.controlprogram.caching.CacheBlock
isShallowSerialize
in class MatrixBlock
inclConvert
- if true report blocks as shallow serialize that are
currently not amenable but can be brought into an amenable form
via toShallowSerializeBlock
.public void toShallowSerializeBlock()
org.apache.sysml.runtime.controlprogram.caching.CacheBlock
toShallowSerializeBlock
in interface org.apache.sysml.runtime.controlprogram.caching.CacheBlock
toShallowSerializeBlock
in class MatrixBlock
public void readFields(DataInput in) throws IOException
readFields
in interface org.apache.hadoop.io.Writable
readFields
in class MatrixBlock
IOException
public void write(DataOutput out) throws IOException
write
in interface org.apache.hadoop.io.Writable
write
in class MatrixBlock
IOException
public void readExternal(ObjectInput is) throws IOException
readExternal
in interface Externalizable
readExternal
in class MatrixBlock
is
- object inputIOException
- if IOException occurspublic void writeExternal(ObjectOutput os) throws IOException
writeExternal
in interface Externalizable
writeExternal
in class MatrixBlock
os
- object outputIOException
- if IOException occurspublic Iterator<double[]> getDenseRowIterator(int rl, int ru)
public int[] countNonZerosPerRow(int rl, int ru)
public MatrixValue scalarOperations(org.apache.sysml.runtime.matrix.operators.ScalarOperator sop, MatrixValue result)
scalarOperations
in class MatrixBlock
public MatrixBlock append(MatrixBlock that, MatrixBlock ret)
append
in class MatrixBlock
public MatrixBlock chainMatrixMultOperations(MatrixBlock v, MatrixBlock w, MatrixBlock out, org.apache.sysml.lops.MapMultChain.ChainType ctype)
chainMatrixMultOperations
in class MatrixBlock
public MatrixBlock chainMatrixMultOperations(MatrixBlock v, MatrixBlock w, MatrixBlock out, org.apache.sysml.lops.MapMultChain.ChainType ctype, int k)
chainMatrixMultOperations
in class MatrixBlock
public MatrixBlock aggregateBinaryOperations(MatrixBlock m1, MatrixBlock m2, MatrixBlock ret, org.apache.sysml.runtime.matrix.operators.AggregateBinaryOperator op)
aggregateBinaryOperations
in class MatrixBlock
public MatrixValue aggregateUnaryOperations(org.apache.sysml.runtime.matrix.operators.AggregateUnaryOperator op, MatrixValue result, int blockingFactorRow, int blockingFactorCol, MatrixIndexes indexesIn, boolean inCP)
aggregateUnaryOperations
in class MatrixBlock
public MatrixValue aggregateUnaryOperations(org.apache.sysml.runtime.matrix.operators.AggregateUnaryOperator op, MatrixValue result, int blockingFactorRow, int blockingFactorCol, MatrixIndexes indexesIn)
aggregateUnaryOperations
in class MatrixBlock
public MatrixBlock transposeSelfMatrixMultOperations(MatrixBlock out, org.apache.sysml.lops.MMTSJ.MMTSJType tstype)
transposeSelfMatrixMultOperations
in class MatrixBlock
public MatrixBlock transposeSelfMatrixMultOperations(MatrixBlock out, org.apache.sysml.lops.MMTSJ.MMTSJType tstype, int k)
transposeSelfMatrixMultOperations
in class MatrixBlock
public boolean hasUncompressedColGroup()
public MatrixValue unaryOperations(org.apache.sysml.runtime.matrix.operators.UnaryOperator op, MatrixValue result)
unaryOperations
in class MatrixBlock
public MatrixValue binaryOperations(org.apache.sysml.runtime.matrix.operators.BinaryOperator op, MatrixValue thatValue, MatrixValue result)
binaryOperations
in class MatrixBlock
public void binaryOperationsInPlace(org.apache.sysml.runtime.matrix.operators.BinaryOperator op, MatrixValue thatValue)
binaryOperationsInPlace
in class MatrixBlock
public void incrementalAggregate(org.apache.sysml.runtime.matrix.operators.AggregateOperator aggOp, MatrixValue correction, MatrixValue newWithCorrection, boolean deep)
incrementalAggregate
in class MatrixBlock
public void incrementalAggregate(org.apache.sysml.runtime.matrix.operators.AggregateOperator aggOp, MatrixValue newWithCorrection)
incrementalAggregate
in class MatrixBlock
public MatrixValue reorgOperations(org.apache.sysml.runtime.matrix.operators.ReorgOperator op, MatrixValue ret, int startRow, int startColumn, int length)
reorgOperations
in class MatrixBlock
public MatrixBlock append(MatrixBlock that, MatrixBlock ret, boolean cbind)
append
in class MatrixBlock
public void append(MatrixValue v2, ArrayList<org.apache.sysml.runtime.matrix.mapred.IndexedMatrixValue> outlist, int blockRowFactor, int blockColFactor, boolean cbind, boolean m2IsLast, int nextNCol)
append
in class MatrixBlock
public void permutationMatrixMultOperations(MatrixValue m2Val, MatrixValue out1Val, MatrixValue out2Val)
permutationMatrixMultOperations
in class MatrixBlock
public void permutationMatrixMultOperations(MatrixValue m2Val, MatrixValue out1Val, MatrixValue out2Val, int k)
permutationMatrixMultOperations
in class MatrixBlock
public MatrixBlock leftIndexingOperations(MatrixBlock rhsMatrix, int rl, int ru, int cl, int cu, MatrixBlock ret, org.apache.sysml.runtime.controlprogram.caching.MatrixObject.UpdateType update)
leftIndexingOperations
in class MatrixBlock
public MatrixBlock leftIndexingOperations(org.apache.sysml.runtime.instructions.cp.ScalarObject scalar, int rl, int cl, MatrixBlock ret, org.apache.sysml.runtime.controlprogram.caching.MatrixObject.UpdateType update)
MatrixBlock
leftIndexingOperations
in class MatrixBlock
scalar
- scalar objectrl
- row lowercl
- column lowerret
- ?update
- ?public MatrixBlock slice(int rl, int ru, int cl, int cu, org.apache.sysml.runtime.controlprogram.caching.CacheBlock ret)
org.apache.sysml.runtime.controlprogram.caching.CacheBlock
slice
in interface org.apache.sysml.runtime.controlprogram.caching.CacheBlock
slice
in class MatrixBlock
rl
- row lowerru
- row uppercl
- column lowercu
- column upperret
- cache blockpublic void slice(ArrayList<org.apache.sysml.runtime.matrix.mapred.IndexedMatrixValue> outlist, org.apache.sysml.runtime.util.IndexRange range, int rowCut, int colCut, int normalBlockRowFactor, int normalBlockColFactor, int boundaryRlen, int boundaryClen)
slice
in class MatrixBlock
public MatrixValue zeroOutOperations(MatrixValue result, org.apache.sysml.runtime.util.IndexRange range, boolean complementary)
zeroOutOperations
in class MatrixBlock
public org.apache.sysml.runtime.instructions.cp.CM_COV_Object cmOperations(org.apache.sysml.runtime.matrix.operators.CMOperator op)
cmOperations
in class MatrixBlock
public org.apache.sysml.runtime.instructions.cp.CM_COV_Object cmOperations(org.apache.sysml.runtime.matrix.operators.CMOperator op, MatrixBlock weights)
cmOperations
in class MatrixBlock
public org.apache.sysml.runtime.instructions.cp.CM_COV_Object covOperations(org.apache.sysml.runtime.matrix.operators.COVOperator op, MatrixBlock that)
covOperations
in class MatrixBlock
public org.apache.sysml.runtime.instructions.cp.CM_COV_Object covOperations(org.apache.sysml.runtime.matrix.operators.COVOperator op, MatrixBlock that, MatrixBlock weights)
covOperations
in class MatrixBlock
public MatrixValue sortOperations(MatrixValue weights, MatrixValue result)
sortOperations
in class MatrixBlock
public MatrixBlock aggregateBinaryOperations(MatrixIndexes m1Index, MatrixBlock m1Value, MatrixIndexes m2Index, MatrixBlock m2Value, MatrixBlock result, org.apache.sysml.runtime.matrix.operators.AggregateBinaryOperator op)
aggregateBinaryOperations
in class MatrixBlock
public MatrixBlock aggregateTernaryOperations(MatrixBlock m1, MatrixBlock m2, MatrixBlock m3, MatrixBlock ret, org.apache.sysml.runtime.matrix.operators.AggregateTernaryOperator op, boolean inCP)
aggregateTernaryOperations
in class MatrixBlock
public MatrixBlock uaggouterchainOperations(MatrixBlock mbLeft, MatrixBlock mbRight, MatrixBlock mbOut, org.apache.sysml.runtime.matrix.operators.BinaryOperator bOp, org.apache.sysml.runtime.matrix.operators.AggregateUnaryOperator uaggOp)
uaggouterchainOperations
in class MatrixBlock
public MatrixBlock groupedAggOperations(MatrixValue tgt, MatrixValue wghts, MatrixValue ret, int ngroups, org.apache.sysml.runtime.matrix.operators.Operator op)
MatrixBlock
groupedAggOperations
in class MatrixBlock
tgt
- ?wghts
- ?ret
- ?ngroups
- ?op
- operatorpublic MatrixBlock groupedAggOperations(MatrixValue tgt, MatrixValue wghts, MatrixValue ret, int ngroups, org.apache.sysml.runtime.matrix.operators.Operator op, int k)
groupedAggOperations
in class MatrixBlock
public MatrixBlock removeEmptyOperations(MatrixBlock ret, boolean rows, boolean emptyReturn, MatrixBlock select)
removeEmptyOperations
in class MatrixBlock
public MatrixBlock removeEmptyOperations(MatrixBlock ret, boolean rows, boolean emptyReturn)
removeEmptyOperations
in class MatrixBlock
public MatrixBlock rexpandOperations(MatrixBlock ret, double max, boolean rows, boolean cast, boolean ignore, int k)
rexpandOperations
in class MatrixBlock
public MatrixValue replaceOperations(MatrixValue result, double pattern, double replacement)
replaceOperations
in class MatrixBlock
public void ctableOperations(org.apache.sysml.runtime.matrix.operators.Operator op, double scalar, MatrixValue that, CTableMap resultMap, MatrixBlock resultBlock)
MatrixBlock
ctableOperations
in class MatrixBlock
public void ctableOperations(org.apache.sysml.runtime.matrix.operators.Operator op, double scalar, double scalar2, CTableMap resultMap, MatrixBlock resultBlock)
MatrixBlock
ctableOperations
in class MatrixBlock
public void ctableOperations(org.apache.sysml.runtime.matrix.operators.Operator op, MatrixIndexes ix1, double scalar, boolean left, int brlen, CTableMap resultMap, MatrixBlock resultBlock)
MatrixBlock
ctableOperations
in class MatrixBlock
public void ctableOperations(org.apache.sysml.runtime.matrix.operators.Operator op, MatrixValue that, double scalar, boolean ignoreZeros, CTableMap resultMap, MatrixBlock resultBlock)
MatrixBlock
ctableOperations
in class MatrixBlock
public MatrixBlock ctableSeqOperations(MatrixValue that, double scalar, MatrixBlock resultBlock)
MatrixBlock
ctableSeqOperations
in class MatrixBlock
that
- matrix valuescalar
- scalar doubleresultBlock
- result matrix blockpublic void ctableOperations(org.apache.sysml.runtime.matrix.operators.Operator op, MatrixValue that, MatrixValue that2, CTableMap resultMap)
MatrixBlock
ctableOperations
in class MatrixBlock
op
- operatorthat
- matrix value 1that2
- matrix value 2resultMap
- table mappublic void ctableOperations(org.apache.sysml.runtime.matrix.operators.Operator op, MatrixValue that, MatrixValue that2, CTableMap resultMap, MatrixBlock resultBlock)
ctableOperations
in class MatrixBlock
public MatrixBlock ternaryOperations(org.apache.sysml.runtime.matrix.operators.TernaryOperator op, MatrixBlock m2, MatrixBlock m3, MatrixBlock ret)
ternaryOperations
in class MatrixBlock
public MatrixBlock quaternaryOperations(org.apache.sysml.runtime.matrix.operators.QuaternaryOperator qop, MatrixBlock um, MatrixBlock vm, MatrixBlock wm, MatrixBlock out)
quaternaryOperations
in class MatrixBlock
public MatrixBlock quaternaryOperations(org.apache.sysml.runtime.matrix.operators.QuaternaryOperator qop, MatrixBlock um, MatrixBlock vm, MatrixBlock wm, MatrixBlock out, int k)
quaternaryOperations
in class MatrixBlock
public MatrixBlock randOperationsInPlace(RandomMatrixGenerator rgen, org.apache.commons.math3.random.Well1024a bigrand, long bSeed)
MatrixBlock
bigrand
is passed so that block-level
seeds are generated internally. In case of MR, it generates a single
block for given block-level seed bSeed
.
When pdf="uniform", cell values are drawn from uniform distribution in
range [min,max]
.
When pdf="normal", cell values are drawn from standard normal
distribution N(0,1). The range of generated values will always be
(-Inf,+Inf).randOperationsInPlace
in class MatrixBlock
rgen
- random matrix generatorbigrand
- ?bSeed
- seed valuepublic MatrixBlock randOperationsInPlace(RandomMatrixGenerator rgen, org.apache.commons.math3.random.Well1024a bigrand, long bSeed, int k)
MatrixBlock
bigrand
is passed so that block-level
seeds are generated internally. In case of MR, it generates a single
block for given block-level seed bSeed
.
When pdf="uniform", cell values are drawn from uniform distribution in
range [min,max]
.
When pdf="normal", cell values are drawn from standard normal
distribution N(0,1). The range of generated values will always be
(-Inf,+Inf).randOperationsInPlace
in class MatrixBlock
rgen
- random matrix generatorbigrand
- ?bSeed
- seed valuek
- ?public MatrixBlock seqOperationsInPlace(double from, double to, double incr)
seqOperationsInPlace
in class MatrixBlock
Copyright © 2018 The Apache Software Foundation. All rights reserved.