Package | Description |
---|---|
org.apache.hadoop.hive.llap.io.decode | |
org.apache.hadoop.hive.llap.io.encoded | |
org.apache.hadoop.hive.ql.io.orc.encoded |
Modifier and Type | Method and Description |
---|---|
protected void |
OrcEncodedDataConsumer.decodeBatch(Reader.OrcEncodedColumnBatch batch,
Consumer<ColumnVectorBatch> downstreamConsumer) |
Modifier and Type | Method and Description |
---|---|
void |
OrcEncodedDataConsumer.init(ConsumerFeedback<Reader.OrcEncodedColumnBatch> upstreamFeedback,
Callable<Void> readCallable,
IoTrace trace) |
Modifier and Type | Field and Description |
---|---|
static FixedSizedObjectPool<Reader.OrcEncodedColumnBatch> |
SerDeEncodedDataReader.ECB_POOL |
static FixedSizedObjectPool<Reader.OrcEncodedColumnBatch> |
OrcEncodedDataReader.ECB_POOL |
Modifier and Type | Method and Description |
---|---|
void |
SerDeEncodedDataReader.returnData(Reader.OrcEncodedColumnBatch ecb) |
void |
OrcEncodedDataReader.returnData(Reader.OrcEncodedColumnBatch ecb) |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.hive.common.Pool<Reader.OrcEncodedColumnBatch> |
Reader.PoolFactory.createEncodedColumnBatchPool() |
Modifier and Type | Method and Description |
---|---|
static org.apache.orc.impl.TreeReaderFactory.StructTreeReader |
EncodedTreeReaderFactory.createRootTreeReader(org.apache.orc.TypeDescription[] batchSchemas,
List<org.apache.orc.OrcProto.ColumnEncoding> encodings,
Reader.OrcEncodedColumnBatch batch,
org.apache.orc.CompressionCodec codec,
org.apache.orc.impl.TreeReaderFactory.Context context,
boolean useDecimal64ColumnVectors) |
Modifier and Type | Method and Description |
---|---|
void |
EncodedReader.readEncodedColumns(int stripeIx,
org.apache.orc.StripeInformation stripe,
org.apache.orc.OrcProto.RowIndex[] index,
List<org.apache.orc.OrcProto.ColumnEncoding> encodings,
List<org.apache.orc.OrcProto.Stream> streams,
boolean[] physicalFileIncludes,
boolean[] rgs,
Consumer<Reader.OrcEncodedColumnBatch> consumer)
Reads encoded data from ORC file.
|
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.