Package org.apache.flink.orc.shim
Interface OrcShim<BATCH>
-
- All Superinterfaces:
Serializable
- All Known Implementing Classes:
OrcNoHiveShim
,OrcShimV200
,OrcShimV210
,OrcShimV230
public interface OrcShim<BATCH> extends Serializable
A shim layer to support orc with different dependents versions of Hive.
-
-
Method Summary
All Methods Static Methods Instance Methods Abstract Methods Modifier and Type Method Description OrcVectorizedBatchWrapper<BATCH>
createBatchWrapper(org.apache.orc.TypeDescription schema, int batchSize)
org.apache.orc.RecordReader
createRecordReader(org.apache.hadoop.conf.Configuration conf, org.apache.orc.TypeDescription schema, int[] selectedFields, List<OrcFilters.Predicate> conjunctPredicates, Path path, long splitStart, long splitLength)
Create orcRecordReader
from conf, schema and etc...static OrcShim<org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch>
createShim(String hiveVersion)
Create shim from hive version.static OrcShim<org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch>
defaultShim()
Default with orc dependent, we should use v2.3.0.boolean
nextBatch(org.apache.orc.RecordReader reader, BATCH rowBatch)
Read the next row batch.
-
-
-
Method Detail
-
createRecordReader
org.apache.orc.RecordReader createRecordReader(org.apache.hadoop.conf.Configuration conf, org.apache.orc.TypeDescription schema, int[] selectedFields, List<OrcFilters.Predicate> conjunctPredicates, Path path, long splitStart, long splitLength) throws IOException
Create orcRecordReader
from conf, schema and etc...- Throws:
IOException
-
createBatchWrapper
OrcVectorizedBatchWrapper<BATCH> createBatchWrapper(org.apache.orc.TypeDescription schema, int batchSize)
-
nextBatch
boolean nextBatch(org.apache.orc.RecordReader reader, BATCH rowBatch) throws IOException
Read the next row batch.- Throws:
IOException
-
defaultShim
static OrcShim<org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch> defaultShim()
Default with orc dependent, we should use v2.3.0.
-
-