Package org.apache.flink.orc
Class OrcColumnarRowSplitReader<BATCH>
- java.lang.Object
-
- org.apache.flink.orc.OrcSplitReader<org.apache.flink.table.data.RowData,BATCH>
-
- org.apache.flink.orc.OrcColumnarRowSplitReader<BATCH>
-
- All Implemented Interfaces:
Closeable,AutoCloseable
public class OrcColumnarRowSplitReader<BATCH> extends OrcSplitReader<org.apache.flink.table.data.RowData,BATCH>
OrcSplitReaderto read ORC files intoRowData.
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static interfaceOrcColumnarRowSplitReader.ColumnBatchGenerator<BATCH>Interface to genVectorizedColumnBatch.
-
Field Summary
-
Fields inherited from class org.apache.flink.orc.OrcSplitReader
nextRow, rowBatchWrapper
-
-
Constructor Summary
Constructors Constructor Description OrcColumnarRowSplitReader(OrcShim<BATCH> shim, org.apache.hadoop.conf.Configuration conf, org.apache.orc.TypeDescription schema, int[] selectedFields, OrcColumnarRowSplitReader.ColumnBatchGenerator<BATCH> batchGenerator, List<OrcFilters.Predicate> conjunctPredicates, int batchSize, org.apache.flink.core.fs.Path path, long splitStart, long splitLength)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected intfillRows()Fills an ORC batch into an array of Row.org.apache.flink.table.data.RowDatanextRecord(org.apache.flink.table.data.RowData reuse)Reads the next record from the input.-
Methods inherited from class org.apache.flink.orc.OrcSplitReader
close, getRecordReader, reachedEnd, seekToRow
-
-
-
-
Constructor Detail
-
OrcColumnarRowSplitReader
public OrcColumnarRowSplitReader(OrcShim<BATCH> shim, org.apache.hadoop.conf.Configuration conf, org.apache.orc.TypeDescription schema, int[] selectedFields, OrcColumnarRowSplitReader.ColumnBatchGenerator<BATCH> batchGenerator, List<OrcFilters.Predicate> conjunctPredicates, int batchSize, org.apache.flink.core.fs.Path path, long splitStart, long splitLength) throws IOException
- Throws:
IOException
-
-
Method Detail
-
fillRows
protected int fillRows()
Description copied from class:OrcSplitReaderFills an ORC batch into an array of Row.- Specified by:
fillRowsin classOrcSplitReader<org.apache.flink.table.data.RowData,BATCH>- Returns:
- The number of rows that were filled.
-
nextRecord
public org.apache.flink.table.data.RowData nextRecord(org.apache.flink.table.data.RowData reuse)
Description copied from class:OrcSplitReaderReads the next record from the input.- Specified by:
nextRecordin classOrcSplitReader<org.apache.flink.table.data.RowData,BATCH>- Parameters:
reuse- Object that may be reused.- Returns:
- Read record.
-
-