Uses of Class
org.apache.sysds.runtime.matrix.data.FrameBlock
- 
- 
Uses of FrameBlock in org.apache.sysds.api.jmlcMethods in org.apache.sysds.api.jmlc that return FrameBlock Modifier and Type Method Description FrameBlockConnection. convertToFrame(InputStream input, int rows, int cols)Converts an input stream of a string frame in textcell format into a frame block.FrameBlockConnection. convertToFrame(InputStream input, int rows, int cols, String format)Converts an input stream of a frame in csv or textcell format into a frame block.FrameBlockConnection. convertToFrame(InputStream input, String meta)Converts an input stream of a string frame in csv or textcell format into a frame block.FrameBlockConnection. convertToFrame(String input, int rows, int cols)Converts an input string representation of a frame in textcell format into a frame block.FrameBlockConnection. convertToFrame(String input, String meta)Converts an input string representation of a frame in csv or textcell format into a frame block.FrameBlockResultVariables. getFrameBlock(String varname)Obtain the frame represented by the given output variable.FrameBlockConnection. readTransformMetaDataFromFile(String metapath)Reads transform meta data from an HDFS file path and converts it into an in-memory FrameBlock object.FrameBlockConnection. readTransformMetaDataFromFile(String spec, String metapath)Reads transform meta data from an HDFS file path and converts it into an in-memory FrameBlock object.FrameBlockConnection. readTransformMetaDataFromFile(String spec, String metapath, String colDelim)Reads transform meta data from an HDFS file path and converts it into an in-memory FrameBlock object.FrameBlockConnection. readTransformMetaDataFromPath(String metapath)Reads transform meta data from the class path and converts it into an in-memory FrameBlock object.FrameBlockConnection. readTransformMetaDataFromPath(String spec, String metapath)Reads transform meta data from the class path and converts it into an in-memory FrameBlock object.FrameBlockConnection. readTransformMetaDataFromPath(String spec, String metapath, String colDelim)Reads transform meta data from the class path and converts it into an in-memory FrameBlock object.Methods in org.apache.sysds.api.jmlc with parameters of type FrameBlock Modifier and Type Method Description voidPreparedScript. setFrame(String varname, FrameBlock frame, boolean reuse)Binds a frame object to a registered input variable.
- 
Uses of FrameBlock in org.apache.sysds.api.mlcontextMethods in org.apache.sysds.api.mlcontext that return types with arguments of type FrameBlock Modifier and Type Method Description static org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock>MLContextConversionUtil. dataFrameToFrameBinaryBlocks(org.apache.spark.sql.Dataset<org.apache.spark.sql.Row> dataFrame, FrameMetadata frameMetadata)Convert aDataFrameto aJavaPairRDD<Long, FrameBlock>binary-block frame.static org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock>MLContextConversionUtil. frameObjectToBinaryBlocks(FrameObject frameObject, SparkExecutionContext sparkExecutionContext)Convert aFrameObjectto aJavaPairRDD<Long, FrameBlock>.org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock>Frame. toBinaryBlocks()Obtain the frame as aJavaPairRDD<Long, FrameBlock>Methods in org.apache.sysds.api.mlcontext with parameters of type FrameBlock Modifier and Type Method Description static FrameObjectMLContextConversionUtil. frameBlockToFrameObject(String variableName, FrameBlock frameBlock, FrameMetadata frameMetadata)Convert aFrameBlockto aFrameObject.Method parameters in org.apache.sysds.api.mlcontext with type arguments of type FrameBlock Modifier and Type Method Description static FrameObjectMLContextConversionUtil. binaryBlocksToFrameObject(org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> binaryBlocks)Convert aJavaPairRDD<Long, FrameBlock>to aFrameObject.static FrameObjectMLContextConversionUtil. binaryBlocksToFrameObject(org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> binaryBlocks, FrameMetadata frameMetadata)Convert aJavaPairRDD<Long, FrameBlock>to aFrameObject.Constructor parameters in org.apache.sysds.api.mlcontext with type arguments of type FrameBlock Constructor Description Frame(org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> binaryBlocks, FrameMetadata frameMetadata)Create a Frame, specifying the SystemDS binary-block frame and its metadata.
- 
Uses of FrameBlock in org.apache.sysds.runtime.controlprogram.contextMethods in org.apache.sysds.runtime.controlprogram.context that return FrameBlock Modifier and Type Method Description FrameBlockExecutionContext. getFrameInput(String varName)Pins a frame variable into memory and returns the internal frame block.static FrameBlockSparkExecutionContext. toFrameBlock(org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> rdd, Types.ValueType[] schema, int rlen, int clen)static FrameBlockSparkExecutionContext. toFrameBlock(RDDObject rdd, Types.ValueType[] schema, int rlen, int clen)Methods in org.apache.sysds.runtime.controlprogram.context that return types with arguments of type FrameBlock Modifier and Type Method Description PartitionedBroadcast<FrameBlock>SparkExecutionContext. getBroadcastForFrameVariable(String varname)org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock>SparkExecutionContext. getFrameBinaryBlockRDDHandleForVariable(String varname)Spark instructions should call this for all frame inputs except broadcast variables.static org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock>SparkExecutionContext. toFrameJavaPairRDD(org.apache.spark.api.java.JavaSparkContext sc, FrameBlock src)Methods in org.apache.sysds.runtime.controlprogram.context with parameters of type FrameBlock Modifier and Type Method Description static FrameObjectExecutionContext. createFrameObject(FrameBlock fb)voidExecutionContext. setFrameOutput(String varName, FrameBlock outputData)static org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock>SparkExecutionContext. toFrameJavaPairRDD(org.apache.spark.api.java.JavaSparkContext sc, FrameBlock src)Method parameters in org.apache.sysds.runtime.controlprogram.context with type arguments of type FrameBlock Modifier and Type Method Description static FrameBlockSparkExecutionContext. toFrameBlock(org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> rdd, Types.ValueType[] schema, int rlen, int clen)
- 
Uses of FrameBlock in org.apache.sysds.runtime.instructions.fedConstructors in org.apache.sysds.runtime.instructions.fed with parameters of type FrameBlock Constructor Description DecodeMatrix(long input, long outputID, FrameBlock meta, Decoder decoder)
- 
Uses of FrameBlock in org.apache.sysds.runtime.instructions.sparkMethods in org.apache.sysds.runtime.instructions.spark that return FrameBlock Modifier and Type Method Description FrameBlockParameterizedBuiltinSPInstruction.RDDFrameReplaceFunction. call(FrameBlock arg0)Methods in org.apache.sysds.runtime.instructions.spark that return types with arguments of type FrameBlock Modifier and Type Method Description scala.Tuple2<Long,FrameBlock>ParameterizedBuiltinSPInstruction.RDDTokenizeFunction. call(scala.Tuple2<Long,FrameBlock> in)scala.Tuple2<Long,FrameBlock>ParameterizedBuiltinSPInstruction.RDDTransformApplyFunction. call(scala.Tuple2<Long,FrameBlock> in)scala.Tuple2<Long,FrameBlock>ParameterizedBuiltinSPInstruction.RDDTransformDecodeFunction. call(scala.Tuple2<MatrixIndexes,MatrixBlock> in)Methods in org.apache.sysds.runtime.instructions.spark with parameters of type FrameBlock Modifier and Type Method Description FrameBlockParameterizedBuiltinSPInstruction.RDDFrameReplaceFunction. call(FrameBlock arg0)Method parameters in org.apache.sysds.runtime.instructions.spark with type arguments of type FrameBlock Modifier and Type Method Description Iterator<scala.Tuple2<Integer,FrameBlock.ColumnMetadata>>MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeBuild2Function. call(Iterator<scala.Tuple2<Long,FrameBlock>> iter)Iterator<scala.Tuple2<Integer,Object>>MultiReturnParameterizedBuiltinSPInstruction.TransformEncodeBuildFunction. call(Iterator<scala.Tuple2<Long,FrameBlock>> iter)scala.Tuple2<Long,FrameBlock>ParameterizedBuiltinSPInstruction.RDDTokenizeFunction. call(scala.Tuple2<Long,FrameBlock> in)scala.Tuple2<Long,FrameBlock>ParameterizedBuiltinSPInstruction.RDDTransformApplyFunction. call(scala.Tuple2<Long,FrameBlock> in)scala.Tuple2<Long,Long>ParameterizedBuiltinSPInstruction.RDDTransformApplyOffsetFunction. call(scala.Tuple2<Long,FrameBlock> in)
- 
Uses of FrameBlock in org.apache.sysds.runtime.instructions.spark.dataMethod parameters in org.apache.sysds.runtime.instructions.spark.data with type arguments of type FrameBlock Modifier and Type Method Description voidFrameReblockBuffer. flushBufferToBinaryBlocks(ArrayList<Pair<Long,FrameBlock>> outList)
- 
Uses of FrameBlock in org.apache.sysds.runtime.instructions.spark.functionsMethods in org.apache.sysds.runtime.instructions.spark.functions that return FrameBlock Modifier and Type Method Description FrameBlockCopyFrameBlockFunction. call(FrameBlock arg0)Methods in org.apache.sysds.runtime.instructions.spark.functions that return types with arguments of type FrameBlock Modifier and Type Method Description scala.Tuple2<Long,FrameBlock>CopyFrameBlockPairFunction. call(scala.Tuple2<org.apache.hadoop.io.LongWritable,FrameBlock> arg0)Methods in org.apache.sysds.runtime.instructions.spark.functions with parameters of type FrameBlock Modifier and Type Method Description FrameBlockCopyFrameBlockFunction. call(FrameBlock arg0)Method parameters in org.apache.sysds.runtime.instructions.spark.functions with type arguments of type FrameBlock Modifier and Type Method Description Iterator<String>ConvertFrameBlockToIJVLines. call(scala.Tuple2<Long,FrameBlock> kv)scala.Tuple2<Long,FrameBlock>CopyFrameBlockPairFunction. call(scala.Tuple2<org.apache.hadoop.io.LongWritable,FrameBlock> arg0)BooleanIsFrameBlockInRange. call(scala.Tuple2<Long,FrameBlock> kv)
- 
Uses of FrameBlock in org.apache.sysds.runtime.instructions.spark.utilsMethods in org.apache.sysds.runtime.instructions.spark.utils that return types with arguments of type FrameBlock Modifier and Type Method Description scala.Tuple2<org.apache.hadoop.io.LongWritable,FrameBlock>FrameRDDConverterUtils.LongFrameToLongWritableFrameFunction. call(scala.Tuple2<Long,FrameBlock> arg0)scala.Tuple2<Long,FrameBlock>FrameRDDConverterUtils.LongWritableFrameToLongFrameFunction. call(scala.Tuple2<org.apache.hadoop.io.LongWritable,FrameBlock> arg0)scala.Tuple2<org.apache.hadoop.io.LongWritable,FrameBlock>FrameRDDConverterUtils.LongWritableToSerFunction. call(scala.Tuple2<org.apache.hadoop.io.LongWritable,FrameBlock> arg0)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, DataCharacteristics mc, Types.ValueType[] schema, boolean hasHeader, String delim, boolean fill, double fillValue, Set<String> naStrings)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, DataCharacteristics mcOut, Types.ValueType[] schema, boolean hasHeader, String delim, boolean fill, double fillValue, Set<String> naStrings)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, DataCharacteristics mc, boolean containsID)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, DataCharacteristics mc, boolean containsID, Pair<String[],Types.ValueType[]> out)static List<scala.Tuple2<Long,FrameBlock>>SparkUtils. fromIndexedFrameBlock(List<Pair<Long,FrameBlock>> in)static scala.Tuple2<Long,FrameBlock>SparkUtils. fromIndexedFrameBlock(Pair<Long,FrameBlock> in)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, DataCharacteristics 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, DataCharacteristics dcIn)static org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock>FrameRDDAggregateUtils. mergeByKey(org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> in)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, DataCharacteristics mcOut, Types.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, DataCharacteristics mc, Types.ValueType[] schema)static Pair<Long,FrameBlock>SparkUtils. toIndexedFrameBlock(scala.Tuple2<Long,FrameBlock> in)Method parameters in org.apache.sysds.runtime.instructions.spark.utils with type arguments of type FrameBlock Modifier and Type Method Description static org.apache.spark.api.java.JavaRDD<String>FrameRDDConverterUtils. binaryBlockToCsv(org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> in, DataCharacteristics mcIn, 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, DataCharacteristics mc, Types.ValueType[] schema)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, DataCharacteristics mc, Types.ValueType[] schema)Deprecated.static org.apache.spark.api.java.JavaPairRDD<MatrixIndexes,MatrixBlock>FrameRDDConverterUtils. binaryBlockToMatrixBlock(org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> input, DataCharacteristics mcIn, DataCharacteristics mcOut)static org.apache.spark.api.java.JavaRDD<String>FrameRDDConverterUtils. binaryBlockToTextCell(org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> input, DataCharacteristics mcIn)scala.Tuple2<org.apache.hadoop.io.LongWritable,FrameBlock>FrameRDDConverterUtils.LongFrameToLongWritableFrameFunction. call(scala.Tuple2<Long,FrameBlock> arg0)scala.Tuple2<Long,FrameBlock>FrameRDDConverterUtils.LongWritableFrameToLongFrameFunction. call(scala.Tuple2<org.apache.hadoop.io.LongWritable,FrameBlock> arg0)scala.Tuple2<org.apache.hadoop.io.LongWritable,FrameBlock>FrameRDDConverterUtils.LongWritableToSerFunction. call(scala.Tuple2<org.apache.hadoop.io.LongWritable,FrameBlock> arg0)static List<scala.Tuple2<Long,FrameBlock>>SparkUtils. fromIndexedFrameBlock(List<Pair<Long,FrameBlock>> in)static scala.Tuple2<Long,FrameBlock>SparkUtils. fromIndexedFrameBlock(Pair<Long,FrameBlock> in)static org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock>FrameRDDAggregateUtils. mergeByKey(org.apache.spark.api.java.JavaPairRDD<Long,FrameBlock> in)static Pair<Long,FrameBlock>SparkUtils. toIndexedFrameBlock(scala.Tuple2<Long,FrameBlock> in)
- 
Uses of FrameBlock in org.apache.sysds.runtime.ioMethods in org.apache.sysds.runtime.io that return FrameBlock Modifier and Type Method Description static FrameBlock[]FrameWriter. createFrameBlocksForReuse(Types.ValueType[] schema, String[] names, long rlen)static FrameBlockFrameWriter. getFrameBlockForReuse(FrameBlock[] blocks)FrameBlockFrameReaderBinaryBlock. readFirstBlock(String fname)Specific functionality of FrameReaderBinaryBlock, mostly used for testing.FrameBlockFrameReader. readFrameFromHDFS(String fname, long rlen, long clen)FrameBlockFrameReader. readFrameFromHDFS(String fname, Types.ValueType[] schema, long rlen, long clen)abstract FrameBlockFrameReader. readFrameFromHDFS(String fname, Types.ValueType[] schema, String[] names, long rlen, long clen)FrameBlockFrameReaderBinaryBlock. readFrameFromHDFS(String fname, Types.ValueType[] schema, String[] names, long rlen, long clen)FrameBlockFrameReaderJSONL. readFrameFromHDFS(String fname, Types.ValueType[] schema, Map<String,Integer> schemaMap, long rlen, long clen)FrameBlockFrameReaderProto. readFrameFromHDFS(String fname, Types.ValueType[] schema, String[] names, long rlen, long clen)FrameBlockFrameReaderTextCell. readFrameFromHDFS(String fname, Types.ValueType[] schema, String[] names, long rlen, long clen)FrameBlockFrameReaderTextCSV. readFrameFromHDFS(String fname, Types.ValueType[] schema, String[] names, long rlen, long clen)FrameBlockFrameReader. readFrameFromInputStream(InputStream is, long rlen, long clen)FrameBlockFrameReader. readFrameFromInputStream(InputStream is, Types.ValueType[] schema, long rlen, long clen)abstract FrameBlockFrameReader. readFrameFromInputStream(InputStream is, Types.ValueType[] schema, String[] names, long rlen, long clen)FrameBlockFrameReaderBinaryBlock. readFrameFromInputStream(InputStream is, Types.ValueType[] schema, String[] names, long rlen, long clen)FrameBlockFrameReaderProto. readFrameFromInputStream(InputStream is, Types.ValueType[] schema, String[] names, long rlen, long clen)FrameBlockFrameReaderTextCell. readFrameFromInputStream(InputStream is, Types.ValueType[] schema, String[] names, long rlen, long clen)FrameBlockFrameReaderTextCSV. readFrameFromInputStream(InputStream is, Types.ValueType[] schema, String[] names, long rlen, long clen)Methods in org.apache.sysds.runtime.io with parameters of type FrameBlock Modifier and Type Method Description static FrameBlockFrameWriter. getFrameBlockForReuse(FrameBlock[] blocks)abstract voidFrameWriter. writeFrameToHDFS(FrameBlock src, String fname, long rlen, long clen)voidFrameWriterBinaryBlock. writeFrameToHDFS(FrameBlock src, String fname, long rlen, long clen)voidFrameWriterJSONL. writeFrameToHDFS(FrameBlock src, String fname, Map<String,Integer> schemaMap, long rlen, long clen)voidFrameWriterProto. writeFrameToHDFS(FrameBlock src, String fname, long rlen, long clen)voidFrameWriterTextCell. writeFrameToHDFS(FrameBlock src, String fname, long rlen, long clen)voidFrameWriterTextCSV. writeFrameToHDFS(FrameBlock src, String fname, long rlen, long clen)Constructors in org.apache.sysds.runtime.io with parameters of type FrameBlock Constructor Description ReadTask(org.apache.hadoop.mapred.InputSplit split, org.apache.hadoop.mapred.TextInputFormat informat, org.apache.hadoop.mapred.JobConf job, FrameBlock dest)
- 
Uses of FrameBlock in org.apache.sysds.runtime.iogenMethods in org.apache.sysds.runtime.iogen that return FrameBlock Modifier and Type Method Description FrameBlockSampleProperties. getSampleFrame()FrameBlockFrameGenerateReader. readFrameFromHDFS(String fname, Types.ValueType[] schema, String[] names, long rlen, long clen)FrameBlockFrameGenerateReader. readFrameFromInputStream(InputStream is, Types.ValueType[] schema, String[] names, long rlen, long clen)Methods in org.apache.sysds.runtime.iogen with parameters of type FrameBlock Modifier and Type Method Description voidSampleProperties. setSampleFrame(FrameBlock sampleFrame)Constructors in org.apache.sysds.runtime.iogen with parameters of type FrameBlock Constructor Description FrameReaderMapping(String raw, FrameBlock frame)GenerateReaderFrame(String sampleRaw, FrameBlock sampleFrame)SampleProperties(String sampleRaw, FrameBlock sampleFrame)
- 
Uses of FrameBlock in org.apache.sysds.runtime.matrix.dataMethods in org.apache.sysds.runtime.matrix.data that return FrameBlock Modifier and Type Method Description FrameBlockFrameBlock. append(FrameBlock that, FrameBlock ret, boolean cbind)Appends the given argument frameblock 'that' to this frameblock by creating a deep copy to prevent side effects.FrameBlockFrameBlock. binaryOperations(BinaryOperator bop, FrameBlock that, FrameBlock out)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 comparisonFrameBlockFrameBlock. detectSchemaFromRow(double sampleFraction)FrameBlockFrameBlock. dropInvalidType(FrameBlock schema)Drop the cell value which does not confirms to the data type of its columnFrameBlockFrameBlock. frameRowReplication(FrameBlock rowToreplicate)FrameBlockFrameBlock. getColumnNamesAsFrame()FrameBlockFrameBlock. getSchemaTypeOf()FrameBlockFrameBlock. invalidByLength(MatrixBlock feaLen)This method validates the frame data against an attribute length constrain if data value in any cell is greater than the specified threshold of that attribute the output frame will store a null on that cell position, thus removing the length-violating values.FrameBlockFrameBlock. leftIndexingOperations(FrameBlock rhsFrame, int rl, int ru, int cl, int cu, FrameBlock ret)FrameBlockFrameBlock. leftIndexingOperations(FrameBlock rhsFrame, IndexRange ixrange, FrameBlock ret)FrameBlockFrameBlock. map(String lambdaExpr, long margin)FrameBlockFrameBlock. map(FrameBlock.FrameMapFunction lambdaExpr, long margin)FrameBlockFrameBlock. mapDist(FrameBlock.FrameMapFunction lambdaExpr)static FrameBlockFrameBlock. mergeSchema(FrameBlock temp1, FrameBlock temp2)FrameBlockFrameBlock. removeEmptyOperations(boolean rows, boolean emptyReturn, MatrixBlock select)<T> FrameBlockFrameBlock. replaceOperations(String pattern, String replacement)FrameBlockFrameBlock. slice(int rl, int ru, int cl, int cu, boolean deep, CacheBlock retCache)Right indexing operations to slice a subframe out of this frame block.FrameBlockFrameBlock. slice(int rl, int ru, int cl, int cu, CacheBlock retCache)FrameBlockFrameBlock. slice(IndexRange ixrange, FrameBlock ret)FrameBlockFrameBlock. valueSwap(FrameBlock schema)FrameBlockFrameBlock. zeroOutOperations(FrameBlock result, IndexRange range, boolean complementary, int iRowStartSrc, int iRowStartDest, int blen, int iMaxRowsToCopy)This function ZERO OUT the data in the slicing window applicable for this block.Methods in org.apache.sysds.runtime.matrix.data that return types with arguments of type FrameBlock Modifier and Type Method Description static ArrayList<Pair<Long,FrameBlock>>OperationsOnMatrixValues. performSlice(Pair<Long,FrameBlock> in, IndexRange ixrange, int blen)This function will get slice of the input frame block overlapping in overall slice(Range), slice has requested for.Methods in org.apache.sysds.runtime.matrix.data with parameters of type FrameBlock Modifier and Type Method Description FrameBlockFrameBlock. append(FrameBlock that, FrameBlock ret, boolean cbind)Appends the given argument frameblock 'that' to this frameblock by creating a deep copy to prevent side effects.FrameBlockFrameBlock. binaryOperations(BinaryOperator bop, FrameBlock that, FrameBlock out)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 comparisonvoidFrameBlock. copy(int rl, int ru, int cl, int cu, FrameBlock src)voidFrameBlock. copy(FrameBlock src)FrameBlockFrameBlock. dropInvalidType(FrameBlock schema)Drop the cell value which does not confirms to the data type of its columnFrameBlockFrameBlock. frameRowReplication(FrameBlock rowToreplicate)FrameBlockFrameBlock. leftIndexingOperations(FrameBlock rhsFrame, int rl, int ru, int cl, int cu, FrameBlock ret)FrameBlockFrameBlock. leftIndexingOperations(FrameBlock rhsFrame, IndexRange ixrange, FrameBlock ret)voidFrameBlock. merge(FrameBlock that)static FrameBlockFrameBlock. mergeSchema(FrameBlock temp1, FrameBlock temp2)static ArrayListOperationsOnMatrixValues. performSlice(IndexRange ixrange, int blen, int iix, int jix, FrameBlock in)FrameBlockFrameBlock. slice(IndexRange ixrange, FrameBlock ret)FrameBlockFrameBlock. valueSwap(FrameBlock schema)FrameBlockFrameBlock. zeroOutOperations(FrameBlock result, IndexRange range, boolean complementary, int iRowStartSrc, int iRowStartDest, int blen, int iMaxRowsToCopy)This function ZERO OUT the data in the slicing window applicable for this block.Method parameters in org.apache.sysds.runtime.matrix.data with type arguments of type FrameBlock Modifier and Type Method Description static voidOperationsOnMatrixValues. performShift(Pair<Long,FrameBlock> in, IndexRange ixrange, int blenLeft, long rlen, long clen, ArrayList<Pair<Long,FrameBlock>> outlist)static voidOperationsOnMatrixValues. performShift(Pair<Long,FrameBlock> in, IndexRange ixrange, int blenLeft, long rlen, long clen, ArrayList<Pair<Long,FrameBlock>> outlist)static ArrayList<Pair<Long,FrameBlock>>OperationsOnMatrixValues. performSlice(Pair<Long,FrameBlock> in, IndexRange ixrange, int blen)This function will get slice of the input frame block overlapping in overall slice(Range), slice has requested for.voidFrameBlock. slice(ArrayList<Pair<Long,FrameBlock>> outlist, IndexRange range, int rowCut)Constructors in org.apache.sysds.runtime.matrix.data with parameters of type FrameBlock Constructor Description FrameBlock(FrameBlock that)Copy constructor for frame blocks, which uses a shallow copy for the schema (column types and names) but a deep copy for meta data and actual column data.
- 
Uses of FrameBlock in org.apache.sysds.runtime.transform.decodeMethods in org.apache.sysds.runtime.transform.decode that return FrameBlock Modifier and Type Method Description abstract FrameBlockDecoder. decode(MatrixBlock in, FrameBlock out)Block decode API converting a matrix block into a frame block.FrameBlockDecoderComposite. decode(MatrixBlock in, FrameBlock out)FrameBlockDecoderDummycode. decode(MatrixBlock in, FrameBlock out)FrameBlockDecoderPassThrough. decode(MatrixBlock in, FrameBlock out)FrameBlockDecoderRecode. decode(MatrixBlock in, FrameBlock out)Methods in org.apache.sysds.runtime.transform.decode with parameters of type FrameBlock Modifier and Type Method Description static DecoderDecoderFactory. createDecoder(String spec, String[] colnames, Types.ValueType[] schema, FrameBlock meta)static DecoderDecoderFactory. createDecoder(String spec, String[] colnames, Types.ValueType[] schema, FrameBlock meta, int clen)static DecoderDecoderFactory. createDecoder(String spec, String[] colnames, Types.ValueType[] schema, FrameBlock meta, int minCol, int maxCol)static DecoderDecoderFactory. createDecoder(String spec, String[] colnames, Types.ValueType[] schema, FrameBlock meta, int clen, int minCol, int maxCol)abstract FrameBlockDecoder. decode(MatrixBlock in, FrameBlock out)Block decode API converting a matrix block into a frame block.FrameBlockDecoderComposite. decode(MatrixBlock in, FrameBlock out)FrameBlockDecoderDummycode. decode(MatrixBlock in, FrameBlock out)FrameBlockDecoderPassThrough. decode(MatrixBlock in, FrameBlock out)FrameBlockDecoderRecode. decode(MatrixBlock in, FrameBlock out)abstract voidDecoder. initMetaData(FrameBlock meta)voidDecoderComposite. initMetaData(FrameBlock meta)voidDecoderDummycode. initMetaData(FrameBlock meta)voidDecoderPassThrough. initMetaData(FrameBlock meta)voidDecoderRecode. initMetaData(FrameBlock meta)
- 
Uses of FrameBlock in org.apache.sysds.runtime.transform.encodeMethods in org.apache.sysds.runtime.transform.encode that return FrameBlock Modifier and Type Method Description FrameBlockColumnEncoderBin. getMetaData(FrameBlock meta)FrameBlockColumnEncoderComposite. getMetaData(FrameBlock out)FrameBlockColumnEncoderDummycode. getMetaData(FrameBlock meta)FrameBlockColumnEncoderFeatureHash. getMetaData(FrameBlock meta)FrameBlockColumnEncoderPassThrough. getMetaData(FrameBlock meta)FrameBlockColumnEncoderRecode. getMetaData(FrameBlock meta)FrameBlockColumnEncoderUDF. getMetaData(FrameBlock meta)FrameBlockEncoder. getMetaData(FrameBlock out)Construct a frame block out of the transform meta data.FrameBlockEncoderMVImpute. getMetaData(FrameBlock out)FrameBlockEncoderOmit. getMetaData(FrameBlock out)abstract FrameBlockLegacyEncoder. getMetaData(FrameBlock out)Construct a frame block out of the transform meta data.FrameBlockMultiColumnEncoder. getMetaData(FrameBlock meta)FrameBlockMultiColumnEncoder. getMetaData(FrameBlock meta, int k)Methods in org.apache.sysds.runtime.transform.encode with parameters of type FrameBlock Modifier and Type Method Description voidColumnEncoderBin. allocateMetaData(FrameBlock meta)voidColumnEncoderComposite. allocateMetaData(FrameBlock meta)voidColumnEncoderDummycode. allocateMetaData(FrameBlock meta)voidColumnEncoderFeatureHash. allocateMetaData(FrameBlock meta)voidColumnEncoderPassThrough. allocateMetaData(FrameBlock meta)voidColumnEncoderRecode. allocateMetaData(FrameBlock meta)voidColumnEncoderUDF. allocateMetaData(FrameBlock meta)voidEncoder. allocateMetaData(FrameBlock meta)Pre-allocate a FrameBlock for metadata collection.voidMultiColumnEncoder. allocateMetaData(FrameBlock meta)MatrixBlockEncoderMVImpute. apply(FrameBlock in, MatrixBlock out)MatrixBlockEncoderOmit. apply(FrameBlock in, MatrixBlock out)abstract MatrixBlockLegacyEncoder. apply(FrameBlock in, MatrixBlock out)Encode input data blockwise according to existing transform meta data (transform apply).voidEncoderMVImpute. build(FrameBlock in)voidEncoderOmit. build(FrameBlock in)abstract voidLegacyEncoder. build(FrameBlock in)Build the transform meta data for the given block input.voidColumnEncoder. buildPartial(FrameBlock in)Partial build of internal data structures (e.g., in distributed spark operations).voidColumnEncoderBin. buildPartial(FrameBlock in)voidColumnEncoderComposite. buildPartial(FrameBlock in)voidColumnEncoderRecode. buildPartial(FrameBlock in)voidEncoder. buildPartial(FrameBlock in)Partial build of internal data structures (e.g., in distributed spark operations).voidLegacyEncoder. buildPartial(FrameBlock in)Partial build of internal data structures (e.g., in distributed spark operations).voidMultiColumnEncoder. buildPartial(FrameBlock in)static MultiColumnEncoderEncoderFactory. createEncoder(String spec, String[] colnames, int clen, FrameBlock meta)static MultiColumnEncoderEncoderFactory. createEncoder(String spec, String[] colnames, int clen, FrameBlock meta, int minCol, int maxCol)static MultiColumnEncoderEncoderFactory. createEncoder(String spec, String[] colnames, Types.ValueType[] schema, int clen, FrameBlock meta)static MultiColumnEncoderEncoderFactory. createEncoder(String spec, String[] colnames, Types.ValueType[] schema, FrameBlock meta)static MultiColumnEncoderEncoderFactory. createEncoder(String spec, String[] colnames, Types.ValueType[] schema, FrameBlock meta, int minCol, int maxCol)MatrixBlockEncoderMVImpute. encode(FrameBlock in, MatrixBlock out)MatrixBlockEncoderOmit. encode(FrameBlock in, MatrixBlock out)abstract MatrixBlockLegacyEncoder. encode(FrameBlock in, MatrixBlock out)Block encode: build and apply (transform encode).MatrixBlockColumnEncoder. getColMapping(FrameBlock meta)Obtain the column mapping of encoded frames based on the passed meta data frame.MatrixBlockLegacyEncoder. getColMapping(FrameBlock meta, MatrixBlock out)Obtain the column mapping of encoded frames based on the passed meta data frame.MatrixBlockMultiColumnEncoder. getColMapping(FrameBlock meta)Obtain the column mapping of encoded frames based on the passed meta data frame.FrameBlockColumnEncoderBin. getMetaData(FrameBlock meta)FrameBlockColumnEncoderComposite. getMetaData(FrameBlock out)FrameBlockColumnEncoderDummycode. getMetaData(FrameBlock meta)FrameBlockColumnEncoderFeatureHash. getMetaData(FrameBlock meta)FrameBlockColumnEncoderPassThrough. getMetaData(FrameBlock meta)FrameBlockColumnEncoderRecode. getMetaData(FrameBlock meta)FrameBlockColumnEncoderUDF. getMetaData(FrameBlock meta)FrameBlockEncoder. getMetaData(FrameBlock out)Construct a frame block out of the transform meta data.FrameBlockEncoderMVImpute. getMetaData(FrameBlock out)FrameBlockEncoderOmit. getMetaData(FrameBlock out)abstract FrameBlockLegacyEncoder. getMetaData(FrameBlock out)Construct a frame block out of the transform meta data.FrameBlockMultiColumnEncoder. getMetaData(FrameBlock meta)FrameBlockMultiColumnEncoder. getMetaData(FrameBlock meta, int k)voidColumnEncoderBin. initMetaData(FrameBlock meta)voidColumnEncoderComposite. initMetaData(FrameBlock out)voidColumnEncoderDummycode. initMetaData(FrameBlock meta)voidColumnEncoderFeatureHash. initMetaData(FrameBlock meta)voidColumnEncoderPassThrough. initMetaData(FrameBlock meta)voidColumnEncoderRecode. initMetaData(FrameBlock meta)Construct the recodemaps from the given input frame for all columns registered for recode.voidColumnEncoderUDF. initMetaData(FrameBlock meta)voidEncoder. initMetaData(FrameBlock meta)Sets up the required meta data for a subsequent call to apply.voidEncoderMVImpute. initMetaData(FrameBlock meta)voidEncoderOmit. initMetaData(FrameBlock meta)abstract voidLegacyEncoder. initMetaData(FrameBlock meta)Sets up the required meta data for a subsequent call to apply.voidMultiColumnEncoder. initMetaData(FrameBlock meta)voidMultiColumnEncoder. legacyBuild(FrameBlock in)Constructors in org.apache.sysds.runtime.transform.encode with parameters of type FrameBlock Constructor Description ColumnEncoderComposite(List<ColumnEncoder> columnEncoders, FrameBlock meta)
- 
Uses of FrameBlock in org.apache.sysds.runtime.transform.metaMethods in org.apache.sysds.runtime.transform.meta that return FrameBlock Modifier and Type Method Description static FrameBlockTfMetaUtils. readTransformMetaDataFromFile(String spec, String metapath, String colDelim)Reads transform meta data from an HDFS file path and converts it into an in-memory FrameBlock object.static FrameBlockTfMetaUtils. readTransformMetaDataFromPath(String spec, String metapath, String colDelim)Reads transform meta data from the class path and converts it into an in-memory FrameBlock object.
- 
Uses of FrameBlock in org.apache.sysds.runtime.transform.tokenizeMethods in org.apache.sysds.runtime.transform.tokenize that return FrameBlock Modifier and Type Method Description FrameBlockTokenizer. tokenize(FrameBlock in, FrameBlock out)FrameBlockTokenizerPost. tokenizePost(List<org.apache.sysds.runtime.transform.tokenize.Tokenizer.DocumentToTokens> tl, FrameBlock out)FrameBlockTokenizerPostCount. tokenizePost(List<org.apache.sysds.runtime.transform.tokenize.Tokenizer.DocumentToTokens> tl, FrameBlock out)FrameBlockTokenizerPostHash. tokenizePost(List<org.apache.sysds.runtime.transform.tokenize.Tokenizer.DocumentToTokens> tl, FrameBlock out)FrameBlockTokenizerPostPosition. tokenizePost(List<org.apache.sysds.runtime.transform.tokenize.Tokenizer.DocumentToTokens> tl, FrameBlock out)Methods in org.apache.sysds.runtime.transform.tokenize with parameters of type FrameBlock Modifier and Type Method Description voidTokenizerPostPosition. appendTokensLong(List<Object> keys, List<org.apache.sysds.runtime.transform.tokenize.Tokenizer.Token> tokenList, FrameBlock out)voidTokenizerPostPosition. appendTokensWide(List<Object> keys, List<org.apache.sysds.runtime.transform.tokenize.Tokenizer.Token> tokenList, FrameBlock out)FrameBlockTokenizer. tokenize(FrameBlock in, FrameBlock out)FrameBlockTokenizerPost. tokenizePost(List<org.apache.sysds.runtime.transform.tokenize.Tokenizer.DocumentToTokens> tl, FrameBlock out)FrameBlockTokenizerPostCount. tokenizePost(List<org.apache.sysds.runtime.transform.tokenize.Tokenizer.DocumentToTokens> tl, FrameBlock out)FrameBlockTokenizerPostHash. tokenizePost(List<org.apache.sysds.runtime.transform.tokenize.Tokenizer.DocumentToTokens> tl, FrameBlock out)FrameBlockTokenizerPostPosition. tokenizePost(List<org.apache.sysds.runtime.transform.tokenize.Tokenizer.DocumentToTokens> tl, FrameBlock out)List<org.apache.sysds.runtime.transform.tokenize.Tokenizer.DocumentToTokens>TokenizerPre. tokenizePre(FrameBlock in)List<org.apache.sysds.runtime.transform.tokenize.Tokenizer.DocumentToTokens>TokenizerPreNgram. tokenizePre(FrameBlock in)List<org.apache.sysds.runtime.transform.tokenize.Tokenizer.DocumentToTokens>TokenizerPreWhitespaceSplit. tokenizePre(FrameBlock in)
- 
Uses of FrameBlock in org.apache.sysds.runtime.utilMethods in org.apache.sysds.runtime.util that return FrameBlock Modifier and Type Method Description static FrameBlockDataConverter. convertToFrameBlock(String[][] data)Converts a two dimensions string array into a frame block of value type string.static FrameBlockDataConverter. convertToFrameBlock(String[][] data, Types.ValueType[] schema)static FrameBlockDataConverter. convertToFrameBlock(String[][] data, Types.ValueType[] schema, String[] colnames)static FrameBlockDataConverter. convertToFrameBlock(MatrixBlock mb)Converts a matrix block into a frame block of value type double.static FrameBlockDataConverter. convertToFrameBlock(MatrixBlock mb, Types.ValueType vt)Converts a matrix block into a frame block of a given value type.static FrameBlockDataConverter. convertToFrameBlock(MatrixBlock mb, Types.ValueType[] schema)static FrameBlockEMAUtils. exponentialMovingAverageImputation(FrameBlock block, int search_iterations, String mode, int freq, Double alpha, Double beta, Double gamma)static FrameBlockUtilFunctions. generateRandomFrameBlock(int rows, int cols, Types.ValueType[] schema, Random random)Generates a random FrameBlock with given parameters.static FrameBlockLocalFileUtils. readFrameBlockFromLocal(String fname)Reads a frame block from local file system.static FrameBlockLocalFileUtils. readFrameBlockFromStream(InputStream is)Reads a frame block from an input stream, using a fused buffered reader with special support for matrix blocks.static FrameBlockDMVUtils. syntacticalPatternDiscovery(FrameBlock frame, double threshold, String disguised_value)Methods in org.apache.sysds.runtime.util with parameters of type FrameBlock Modifier and Type Method Description static MatrixBlockDataConverter. convertToMatrixBlock(FrameBlock frame)Converts a frame block with arbitrary schema into a matrix block.static String[][]DataConverter. convertToStringFrame(FrameBlock frame)Converts a frame block with arbitrary schema into a two dimensional string array.static FrameBlockEMAUtils. exponentialMovingAverageImputation(FrameBlock block, int search_iterations, String mode, int freq, Double alpha, Double beta, Double gamma)static FrameBlockDMVUtils. syntacticalPatternDiscovery(FrameBlock frame, double threshold, String disguised_value)static StringDataConverter. toString(FrameBlock fb)static StringDataConverter. toString(FrameBlock fb, boolean sparse, String separator, String lineseparator, int rowsToPrint, int colsToPrint, int decimal)static voidLocalFileUtils. writeFrameBlockToLocal(String fname, FrameBlock fb)Writes a frame block to local file system.Method parameters in org.apache.sysds.runtime.util with type arguments of type FrameBlock Modifier and Type Method Description static IndexRangeUtilFunctions. getSelectedRangeForZeroOut(Pair<Long,FrameBlock> in, int blen, IndexRange indexRange, long lSrcRowIndex, long lDestRowIndex)
- 
Uses of FrameBlock in org.apache.sysds.utilsMethods in org.apache.sysds.utils that return FrameBlock Modifier and Type Method Description static FrameBlockDataAugmentation. dataCorruption(FrameBlock input, double pTypo, double pMiss, double pDrop, double pOut, double pSwap)This function returns a new frame block with error introduced in the data: Typos in string values, null values, outliers in numeric data and swapped elements.static FrameBlockDataAugmentation. miss(FrameBlock frame, double pMiss, double pDrop)This function modifies the given, preprocessed frame block to add missing values to some of the rows, marking them with the label missing.static FrameBlockDataAugmentation. outlier(FrameBlock frame, List<Integer> numerics, double pOut, double pPos, int times)This function modifies the given, preprocessed frame block to add outliers to some of the numeric data of the frame, adding or several times the standard deviation, and marking them with the label outlier.static FrameBlockDataAugmentation. preprocessing(FrameBlock frame, List<Integer> numerics, List<Integer> strings, List<Integer> swappable)This function returns a new frame block with a labels column added, and build the lists with column index of the different types of data.static FrameBlockDataAugmentation. swap(FrameBlock frame, List<Integer> swappable, double pSwap)This function modifies the given, preprocessed frame block to add swapped fields of the same ValueType that are consecutive, marking them with the label swap.static FrameBlockDataAugmentation. typos(FrameBlock frame, List<Integer> strings, double pTypo)This function modifies the given, preprocessed frame block to add typos to the string values, marking them with the label typos.Methods in org.apache.sysds.utils with parameters of type FrameBlock Modifier and Type Method Description static FrameBlockDataAugmentation. dataCorruption(FrameBlock input, double pTypo, double pMiss, double pDrop, double pOut, double pSwap)This function returns a new frame block with error introduced in the data: Typos in string values, null values, outliers in numeric data and swapped elements.static FrameBlockDataAugmentation. miss(FrameBlock frame, double pMiss, double pDrop)This function modifies the given, preprocessed frame block to add missing values to some of the rows, marking them with the label missing.static FrameBlockDataAugmentation. outlier(FrameBlock frame, List<Integer> numerics, double pOut, double pPos, int times)This function modifies the given, preprocessed frame block to add outliers to some of the numeric data of the frame, adding or several times the standard deviation, and marking them with the label outlier.static FrameBlockDataAugmentation. preprocessing(FrameBlock frame, List<Integer> numerics, List<Integer> strings, List<Integer> swappable)This function returns a new frame block with a labels column added, and build the lists with column index of the different types of data.static FrameBlockDataAugmentation. swap(FrameBlock frame, List<Integer> swappable, double pSwap)This function modifies the given, preprocessed frame block to add swapped fields of the same ValueType that are consecutive, marking them with the label swap.static FrameBlockDataAugmentation. typos(FrameBlock frame, List<Integer> strings, double pTypo)This function modifies the given, preprocessed frame block to add typos to the string values, marking them with the label typos.
 
-