Class ParquetColumnarRowSplitReader
- java.lang.Object
-
- org.apache.flink.formats.parquet.vector.ParquetColumnarRowSplitReader
-
- All Implemented Interfaces:
Closeable
,AutoCloseable
public class ParquetColumnarRowSplitReader extends Object implements Closeable
This reader is used to read aVectorizedColumnBatch
from input split.
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static interface
ParquetColumnarRowSplitReader.ColumnBatchGenerator
Interface to genVectorizedColumnBatch
.
-
Constructor Summary
Constructors Constructor Description ParquetColumnarRowSplitReader(boolean utcTimestamp, boolean caseSensitive, org.apache.hadoop.conf.Configuration conf, LogicalType[] selectedTypes, String[] selectedFieldNames, ParquetColumnarRowSplitReader.ColumnBatchGenerator generator, int batchSize, org.apache.hadoop.fs.Path path, long splitStart, long splitLength)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
close()
ColumnarRowData
nextRecord()
boolean
reachedEnd()
Method used to check if the end of the input is reached.void
seekToRow(long rowCount)
Seek to a particular row number.
-
-
-
Constructor Detail
-
ParquetColumnarRowSplitReader
public ParquetColumnarRowSplitReader(boolean utcTimestamp, boolean caseSensitive, org.apache.hadoop.conf.Configuration conf, LogicalType[] selectedTypes, String[] selectedFieldNames, ParquetColumnarRowSplitReader.ColumnBatchGenerator generator, int batchSize, org.apache.hadoop.fs.Path path, long splitStart, long splitLength) throws IOException
- Throws:
IOException
-
-
Method Detail
-
reachedEnd
public boolean reachedEnd() throws IOException
Method used to check if the end of the input is reached.- Returns:
- True if the end is reached, otherwise false.
- Throws:
IOException
- Thrown, if an I/O error occurred.
-
nextRecord
public ColumnarRowData nextRecord()
-
seekToRow
public void seekToRow(long rowCount) throws IOException
Seek to a particular row number.- Throws:
IOException
-
close
public void close() throws IOException
- Specified by:
close
in interfaceAutoCloseable
- Specified by:
close
in interfaceCloseable
- Throws:
IOException
-
-