public interface OrcShim<BATCH> extends Serializable
Modifier and Type | Method and 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 orc
RecordReader 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.
|
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
RecordReader
from conf, schema and etc...IOException
OrcVectorizedBatchWrapper<BATCH> createBatchWrapper(org.apache.orc.TypeDescription schema, int batchSize)
boolean nextBatch(org.apache.orc.RecordReader reader, BATCH rowBatch) throws IOException
IOException
static OrcShim<org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch> defaultShim()
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.