public abstract class OrcSplitReader<T,BATCH> extends Object implements Closeable
Modifier and Type | Field and Description |
---|---|
protected int |
nextRow |
protected OrcVectorizedBatchWrapper<BATCH> |
rowBatchWrapper |
Constructor and Description |
---|
OrcSplitReader(OrcShim<BATCH> shim,
org.apache.hadoop.conf.Configuration conf,
org.apache.orc.TypeDescription schema,
int[] selectedFields,
List<OrcFilters.Predicate> conjunctPredicates,
int batchSize,
Path path,
long splitStart,
long splitLength) |
Modifier and Type | Method and Description |
---|---|
void |
close() |
protected abstract int |
fillRows()
Fills an ORC batch into an array of Row.
|
org.apache.orc.RecordReader |
getRecordReader() |
abstract T |
nextRecord(T reuse)
Reads the next record from the input.
|
boolean |
reachedEnd()
Method used to check if the end of the input is reached.
|
void |
seekToRow(long rowCount)
Seek to a particular row number.
|
protected final OrcVectorizedBatchWrapper<BATCH> rowBatchWrapper
protected int nextRow
public OrcSplitReader(OrcShim<BATCH> shim, org.apache.hadoop.conf.Configuration conf, org.apache.orc.TypeDescription schema, int[] selectedFields, List<OrcFilters.Predicate> conjunctPredicates, int batchSize, Path path, long splitStart, long splitLength) throws IOException
IOException
public void seekToRow(long rowCount) throws IOException
IOException
@VisibleForTesting public org.apache.orc.RecordReader getRecordReader()
public boolean reachedEnd() throws IOException
IOException
- Thrown, if an I/O error occurred.protected abstract int fillRows()
public abstract T nextRecord(T reuse) throws IOException
reuse
- Object that may be reused.IOException
- Thrown, if an I/O error occurred.public void close() throws IOException
close
in interface Closeable
close
in interface AutoCloseable
IOException
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.