Modifier and Type | Method and Description |
---|---|
MatrixCharacteristics |
Metadata.asMatrixCharacteristics()
Convert the metadata to a MatrixCharacteristics object.
|
Modifier and Type | Method and Description |
---|---|
void |
Metadata.setMatrixCharacteristics(MatrixCharacteristics matrixCharacteristics)
Set the metadata fields based on a MatrixCharacteristics object.
|
void |
FrameMetadata.setMatrixCharacteristics(MatrixCharacteristics matrixCharacteristics)
Set the FrameMetadata fields based on a MatrixCharacteristics object.
|
Constructor and Description |
---|
FrameMetadata(FrameSchema frameSchema,
MatrixCharacteristics matrixCharacteristics)
Constructor to create a FrameMetadata object based on the frame schema
and a MatrixCharacteristics object.
|
FrameMetadata(MatrixCharacteristics matrixCharacteristics)
Constructor to create a FrameMetadata object based on a
MatrixCharacteristics object.
|
MatrixMetadata(MatrixCharacteristics matrixCharacteristics)
Constructor to create a MatrixMetadata object based on a
MatrixCharacteristics object.
|
Modifier and Type | Method and Description |
---|---|
void |
MRJobInstruction.printCompleteMRJobInstruction(MatrixCharacteristics[] resultStats) |
Modifier and Type | Method and Description |
---|---|
protected MatrixCharacteristics |
BinarySPInstruction.updateBinaryMMOutputMatrixCharacteristics(org.apache.sysml.runtime.controlprogram.context.SparkExecutionContext sec,
boolean checkCommonDim) |
Modifier and Type | Method and Description |
---|---|
protected long |
BinarySPInstruction.getNumReplicas(MatrixCharacteristics mc1,
MatrixCharacteristics mc2,
boolean left) |
static MatrixBlock |
MatrixIndexingSPInstruction.inmemoryIndexing(org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock> in1,
MatrixCharacteristics mcIn,
MatrixCharacteristics mcOut,
org.apache.sysml.runtime.util.IndexRange ixrange) |
static boolean |
MatrixIndexingSPInstruction.isMultiBlockLookup(org.apache.spark.api.java.JavaPairRDD<?,?> in,
MatrixCharacteristics mcIn,
MatrixCharacteristics mcOut,
org.apache.sysml.runtime.util.IndexRange ixrange)
Indicates if the given index range and input matrix exhibit the following properties:
(1) existing hash partitioner, (2) out-of-core input matrix (larger than aggregated memory),
(3) aligned indexing range (which does not required aggregation), and (4) the output fits
twice in memory (in order to collect the result).
|
static boolean |
MatrixIndexingSPInstruction.isSingleBlockLookup(MatrixCharacteristics mcIn,
org.apache.sysml.runtime.util.IndexRange ixrange)
Indicates if the given index range only covers a single blocks of the inputs matrix.
|
protected static boolean |
UaggOuterChainSPInstruction.preservesPartitioning(MatrixCharacteristics mcIn,
org.apache.sysml.runtime.functionobjects.IndexFunction ixfun) |
protected org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> |
CSVReblockSPInstruction.processFrameCSVReblockInstruction(org.apache.sysml.runtime.controlprogram.context.SparkExecutionContext sec,
MatrixCharacteristics mcOut,
org.apache.sysml.parser.Expression.ValueType[] schema) |
protected org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock> |
CSVReblockSPInstruction.processMatrixCSVReblockInstruction(org.apache.sysml.runtime.controlprogram.context.SparkExecutionContext sec,
MatrixCharacteristics mcOut) |
void |
ParameterizedBuiltinSPInstruction.setOutputCharacteristicsForGroupedAgg(MatrixCharacteristics mc1,
MatrixCharacteristics mcOut,
org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixCell> out) |
Constructor and Description |
---|
MergeWithShiftedBlocks(MatrixCharacteristics mc1,
MatrixCharacteristics mc2,
boolean cbind) |
PadBlocksFunction(MatrixCharacteristics mcOut) |
ShiftMatrix(MatrixCharacteristics mc1,
MatrixCharacteristics mc2,
boolean cbind) |
Modifier and Type | Method and Description |
---|---|
static MatrixCharacteristics |
SparkUtils.computeMatrixCharacteristics(org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixCell> input)
Utility to compute dimensions and non-zeros in a given RDD of binary cells.
|
Modifier and Type | Method and Description |
---|---|
static org.apache.spark.api.java.JavaRDD<String> |
FrameRDDConverterUtils.binaryBlockToCsv(org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> in,
MatrixCharacteristics mcIn,
org.apache.sysml.runtime.io.FileFormatPropertiesCSV props,
boolean strict) |
static org.apache.spark.api.java.JavaRDD<String> |
RDDConverterUtils.binaryBlockToCsv(org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock> in,
MatrixCharacteristics mcIn,
org.apache.sysml.runtime.io.FileFormatPropertiesCSV props,
boolean strict) |
static org.apache.spark.sql.Dataset<org.apache.spark.sql.Row> |
FrameRDDConverterUtils.binaryBlockToDataFrame(org.apache.spark.sql.SparkSession sparkSession,
org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> in,
MatrixCharacteristics mc,
org.apache.sysml.parser.Expression.ValueType[] schema) |
static org.apache.spark.sql.Dataset<org.apache.spark.sql.Row> |
RDDConverterUtils.binaryBlockToDataFrame(org.apache.spark.sql.SparkSession sparkSession,
org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock> in,
MatrixCharacteristics mc,
boolean toVector) |
static org.apache.spark.sql.Dataset<org.apache.spark.sql.Row> |
FrameRDDConverterUtils.binaryBlockToDataFrame(org.apache.spark.sql.SQLContext sqlContext,
org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> in,
MatrixCharacteristics mc,
org.apache.sysml.parser.Expression.ValueType[] schema)
Deprecated.
|
static org.apache.spark.sql.Dataset<org.apache.spark.sql.Row> |
RDDConverterUtils.binaryBlockToDataFrame(org.apache.spark.sql.SQLContext sqlContext,
org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock> in,
MatrixCharacteristics mc,
boolean toVector)
Deprecated.
|
static org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock> |
FrameRDDConverterUtils.binaryBlockToMatrixBlock(org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> input,
MatrixCharacteristics mcIn,
MatrixCharacteristics mcOut) |
static org.apache.spark.api.java.JavaRDD<String> |
FrameRDDConverterUtils.binaryBlockToTextCell(org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> input,
MatrixCharacteristics mcIn) |
static org.apache.spark.api.java.JavaRDD<String> |
RDDConverterUtils.binaryBlockToTextCell(org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock> in,
MatrixCharacteristics mc) |
static org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock> |
RDDConverterUtils.binaryCellToBinaryBlock(org.apache.spark.api.java.JavaSparkContext sc,
org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixCell> input,
MatrixCharacteristics mcOut,
boolean outputEmptyBlocks) |
static org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock> |
RDDConverterUtilsExt.coordinateMatrixToBinaryBlock(org.apache.spark.api.java.JavaSparkContext sc,
org.apache.spark.mllib.linalg.distributed.CoordinateMatrix input,
MatrixCharacteristics mcIn,
boolean outputEmptyBlocks)
Example usage:
|
static org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock> |
RDDConverterUtilsExt.coordinateMatrixToBinaryBlock(org.apache.spark.SparkContext sc,
org.apache.spark.mllib.linalg.distributed.CoordinateMatrix input,
MatrixCharacteristics mcIn,
boolean outputEmptyBlocks) |
static org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock> |
RDDConverterUtils.csvToBinaryBlock(org.apache.spark.api.java.JavaSparkContext sc,
org.apache.spark.api.java.JavaPairRDD<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.Text> input,
MatrixCharacteristics mc,
boolean hasHeader,
String delim,
boolean fill,
double fillValue) |
static org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> |
FrameRDDConverterUtils.csvToBinaryBlock(org.apache.spark.api.java.JavaSparkContext sc,
org.apache.spark.api.java.JavaPairRDD<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.Text> input,
MatrixCharacteristics mc,
org.apache.sysml.parser.Expression.ValueType[] schema,
boolean hasHeader,
String delim,
boolean fill,
double fillValue) |
static org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock> |
RDDConverterUtils.csvToBinaryBlock(org.apache.spark.api.java.JavaSparkContext sc,
org.apache.spark.api.java.JavaRDD<String> input,
MatrixCharacteristics mcOut,
boolean hasHeader,
String delim,
boolean fill,
double fillValue)
Example usage:
|
static org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> |
FrameRDDConverterUtils.csvToBinaryBlock(org.apache.spark.api.java.JavaSparkContext sc,
org.apache.spark.api.java.JavaRDD<String> input,
MatrixCharacteristics mcOut,
org.apache.sysml.parser.Expression.ValueType[] schema,
boolean hasHeader,
String delim,
boolean fill,
double fillValue) |
static org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> |
FrameRDDConverterUtils.dataFrameToBinaryBlock(org.apache.spark.api.java.JavaSparkContext sc,
org.apache.spark.sql.Dataset<org.apache.spark.sql.Row> df,
MatrixCharacteristics mc,
boolean containsID) |
static org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock> |
RDDConverterUtils.dataFrameToBinaryBlock(org.apache.spark.api.java.JavaSparkContext sc,
org.apache.spark.sql.Dataset<org.apache.spark.sql.Row> df,
MatrixCharacteristics mc,
boolean containsID,
boolean isVector) |
static org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> |
FrameRDDConverterUtils.dataFrameToBinaryBlock(org.apache.spark.api.java.JavaSparkContext sc,
org.apache.spark.sql.Dataset<org.apache.spark.sql.Row> df,
MatrixCharacteristics mc,
boolean containsID,
Pair<String[],org.apache.sysml.parser.Expression.ValueType[]> out) |
static org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock> |
SparkUtils.getEmptyBlockRDD(org.apache.spark.api.java.JavaSparkContext sc,
MatrixCharacteristics mc)
Creates an RDD of empty blocks according to the given matrix characteristics.
|
static int |
SparkUtils.getNumPreferredPartitions(MatrixCharacteristics mc) |
static int |
SparkUtils.getNumPreferredPartitions(MatrixCharacteristics mc,
org.apache.spark.api.java.JavaPairRDD<?,?> in) |
static void |
RDDConverterUtils.libsvmToBinaryBlock(org.apache.spark.api.java.JavaSparkContext sc,
String pathIn,
String pathX,
String pathY,
MatrixCharacteristics mcOutX)
Converts a libsvm text input file into two binary block matrices for features
and labels, and saves these to the specified output files.
|
static org.apache.spark.api.java.JavaPairRDD<org.apache.hadoop.io.LongWritable,FrameBlock> |
FrameRDDConverterUtils.matrixBlockToBinaryBlock(org.apache.spark.api.java.JavaSparkContext sc,
org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock> input,
MatrixCharacteristics mcIn) |
static org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> |
FrameRDDConverterUtils.matrixBlockToBinaryBlockLongIndex(org.apache.spark.api.java.JavaSparkContext sc,
org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock> input,
MatrixCharacteristics mcIn) |
static org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock> |
RDDConverterUtils.textCellToBinaryBlock(org.apache.spark.api.java.JavaSparkContext sc,
org.apache.spark.api.java.JavaPairRDD<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.Text> input,
MatrixCharacteristics mcOut,
boolean outputEmptyBlocks,
org.apache.sysml.runtime.io.FileFormatPropertiesMM mmProps) |
static org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> |
FrameRDDConverterUtils.textCellToBinaryBlock(org.apache.spark.api.java.JavaSparkContext sc,
org.apache.spark.api.java.JavaPairRDD<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.Text> in,
MatrixCharacteristics mcOut,
org.apache.sysml.parser.Expression.ValueType[] schema) |
static org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> |
FrameRDDConverterUtils.textCellToBinaryBlockLongIndex(org.apache.spark.api.java.JavaSparkContext sc,
org.apache.spark.api.java.JavaPairRDD<Long,org.apache.hadoop.io.Text> input,
MatrixCharacteristics mc,
org.apache.sysml.parser.Expression.ValueType[] schema) |
Constructor and Description |
---|
BinaryCellToBinaryBlockFunction(MatrixCharacteristics mc) |
Modifier and Type | Field and Description |
---|---|
protected MatrixCharacteristics |
MetaData._mc |
Modifier and Type | Method and Description |
---|---|
MatrixCharacteristics |
MetaData.getMatrixCharacteristics() |
MatrixCharacteristics |
MatrixCharacteristics.set(long nr,
long nc,
int bnr,
int bnc) |
MatrixCharacteristics |
MatrixCharacteristics.set(long nr,
long nc,
int bnr,
int bnc,
long nnz) |
MatrixCharacteristics |
MatrixCharacteristics.set(MatrixCharacteristics that) |
MatrixCharacteristics |
MatrixCharacteristics.setBlockSize(int blen) |
MatrixCharacteristics |
MatrixCharacteristics.setBlockSize(int bnr,
int bnc) |
Modifier and Type | Method and Description |
---|---|
static void |
MatrixCharacteristics.aggregateBinary(MatrixCharacteristics dim1,
MatrixCharacteristics dim2,
org.apache.sysml.runtime.matrix.operators.AggregateBinaryOperator op,
MatrixCharacteristics dimOut) |
static void |
MatrixCharacteristics.aggregateUnary(MatrixCharacteristics dim,
org.apache.sysml.runtime.matrix.operators.AggregateUnaryOperator op,
MatrixCharacteristics dimOut) |
static void |
MatrixCharacteristics.reorg(MatrixCharacteristics dim,
org.apache.sysml.runtime.matrix.operators.ReorgOperator op,
MatrixCharacteristics dimOut) |
MatrixCharacteristics |
MatrixCharacteristics.set(MatrixCharacteristics that) |
Modifier and Type | Method and Description |
---|---|
static void |
MatrixCharacteristics.computeDimension(HashMap<Byte,MatrixCharacteristics> dims,
org.apache.sysml.runtime.instructions.mr.MRInstruction ins) |
Constructor and Description |
---|
JobReturn(MatrixCharacteristics[] sts,
boolean success) |
JobReturn(MatrixCharacteristics[] sts,
OutputInfo[] infos,
boolean success) |
JobReturn(MatrixCharacteristics mc,
long[] items,
int partition0,
long number0s,
boolean success) |
JobReturn(MatrixCharacteristics sts,
OutputInfo info,
boolean success) |
MatrixCharacteristics(MatrixCharacteristics that) |
MetaData(MatrixCharacteristics mc) |
MetaDataFormat(MatrixCharacteristics mc,
OutputInfo oinfo,
InputInfo iinfo) |
MetaDataNumItemsByEachReducer(MatrixCharacteristics mc,
long[] nums,
int part0,
long num0) |
Modifier and Type | Method and Description |
---|---|
MatrixCharacteristics |
MatrixBlock.getMatrixCharacteristics() |
Modifier and Type | Method and Description |
---|---|
static List<org.apache.sysml.runtime.matrix.mapred.IndexedMatrixValue> |
LibMatrixReorg.reshape(org.apache.sysml.runtime.matrix.mapred.IndexedMatrixValue in,
MatrixCharacteristics mcIn,
MatrixCharacteristics mcOut,
boolean rowwise,
boolean outputEmptyBlocks)
MR/SPARK reshape interface - for reshape we cannot view blocks independently, and hence,
there are different CP and MR interfaces.
|
Copyright © 2018 The Apache Software Foundation. All rights reserved.