| Package | Description |
|---|---|
| org.apache.hadoop.hive.ql.exec |
Hive QL execution tasks, operators, functions and other handlers.
|
| org.apache.hadoop.hive.ql.exec.vector | |
| org.apache.hadoop.hive.ql.io | |
| org.apache.hadoop.hive.ql.io.orc |
The Optimized Row Columnar (ORC) File Format.
|
| org.apache.hadoop.hive.ql.plan |
| Modifier and Type | Method and Description |
|---|---|
static VectorizedRowBatchCtx |
Utilities.getVectorizedRowBatchCtx(org.apache.hadoop.conf.Configuration conf) |
| Modifier and Type | Field and Description |
|---|---|
protected VectorizedRowBatchCtx |
VectorMapJoinBaseOperator.vrbCtx |
| Modifier and Type | Method and Description |
|---|---|
static void |
VectorizedBatchUtil.acidAddRowToBatch(Object row,
StructObjectInspector oi,
int rowIndex,
org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch batch,
VectorizedRowBatchCtx context,
org.apache.hadoop.io.DataOutputBuffer buffer)
Iterates thru all the columns in a given row and populates the batch
from a given offset
|
static void |
VectorizedRowBatchCtx.getPartitionValues(VectorizedRowBatchCtx vrbCtx,
org.apache.hadoop.conf.Configuration hiveConf,
org.apache.hadoop.mapred.FileSplit split,
Object[] partitionValues) |
static void |
VectorizedRowBatchCtx.getPartitionValues(VectorizedRowBatchCtx vrbCtx,
MapWork mapWork,
org.apache.hadoop.mapred.FileSplit split,
Object[] partitionValues) |
static void |
VectorizedRowBatchCtx.getPartitionValues(VectorizedRowBatchCtx vrbCtx,
PartitionDesc partDesc,
Object[] partitionValues) |
| Modifier and Type | Field and Description |
|---|---|
protected VectorizedRowBatchCtx |
NullRowsInputFormat.NullRowsRecordReader.rbCtx |
| Modifier and Type | Method and Description |
|---|---|
BatchToRowReader<?,?> |
BatchToRowInputFormat.getWrapper(org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.NullWritable,org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch> vrr,
VectorizedRowBatchCtx vrbCtx,
List<Integer> includedCols) |
| Constructor and Description |
|---|
BatchToRowReader(org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.NullWritable,org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch> vrbReader,
VectorizedRowBatchCtx vrbCtx,
List<Integer> includedCols) |
| Modifier and Type | Method and Description |
|---|---|
BatchToRowReader<?,?> |
OrcInputFormat.getWrapper(org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.NullWritable,org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch> vrr,
VectorizedRowBatchCtx vrbCtx,
List<Integer> includedCols) |
| Constructor and Description |
|---|
OrcOiBatchToRowReader(org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.NullWritable,org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch> vrbReader,
VectorizedRowBatchCtx vrbCtx,
List<Integer> includedCols) |
VectorizedOrcAcidRowBatchReader(OrcSplit inputSplit,
org.apache.hadoop.mapred.JobConf conf,
org.apache.hadoop.mapred.Reporter reporter,
org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.NullWritable,org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch> baseReader,
VectorizedRowBatchCtx rbCtx,
boolean isFlatPayload)
LLAP IO c'tor
|
| Modifier and Type | Field and Description |
|---|---|
protected VectorizedRowBatchCtx |
BaseWork.vectorizedRowBatchCtx |
| Modifier and Type | Method and Description |
|---|---|
VectorizedRowBatchCtx |
BaseWork.getVectorizedRowBatchCtx() |
| Modifier and Type | Method and Description |
|---|---|
static List<String> |
BaseWork.BaseExplainVectorization.getColumns(VectorizedRowBatchCtx vectorizedRowBatchCtx,
int startIndex,
int count) |
static String |
BaseWork.BaseExplainVectorization.getScratchColumns(VectorizedRowBatchCtx vectorizedRowBatchCtx) |
void |
BaseWork.setVectorizedRowBatchCtx(VectorizedRowBatchCtx vectorizedRowBatchCtx) |
| Constructor and Description |
|---|
RowBatchContextExplainVectorization(VectorizedRowBatchCtx vectorizedRowBatchCtx) |
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.