| Package | Description |
|---|---|
| org.apache.hadoop.hive.ql.exec |
Hive QL execution tasks, operators, functions and other handlers.
|
| org.apache.hadoop.hive.ql.exec.persistence | |
| org.apache.hadoop.hive.ql.exec.vector | |
| org.apache.hadoop.hive.ql.exec.vector.expressions | |
| org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates | |
| org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.gen | |
| org.apache.hadoop.hive.ql.exec.vector.expressions.gen | |
| org.apache.hadoop.hive.ql.exec.vector.mapjoin | |
| org.apache.hadoop.hive.ql.exec.vector.udf | |
| 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.io.parquet | |
| org.apache.hadoop.hive.ql.udf | |
| org.apache.hadoop.hive.ql.udf.generic |
Standard toolkit and framework for generic User-defined functions.
|
| Class and Description |
|---|
| VectorizationContext
Context class for vectorization execution.
|
| Class and Description |
|---|
| VectorHashKeyWrapper
A hash map key wrapper for vectorized processing.
|
| VectorHashKeyWrapperBatch
Class for handling vectorized hash map key wrappers.
|
| Class and Description |
|---|
| BytesColumnVector
This class supports string and binary data by value reference -- i.e.
|
| ColumnVector
ColumnVector contains the shared structure for the sub-types,
including NULL information, and whether this vector
repeats, i.e.
|
| ColumnVector.Type |
| DoubleColumnVector
This class represents a nullable double precision floating point column vector.
|
| LongColumnVector
This class represents a nullable int column vector.
|
| VectorAggregationBufferRow
Represents a set of aggregation buffers to be used for a specific key for UDAF GROUP BY.
|
| VectorAssignRow
This class assigns specified columns of a row from a Writable row Object[].
|
| VectorAssignRow.Assigner |
| VectorAssignRowSameBatch
This class assigns specified columns of a VectorizedRowBatch row from a Writable row Object[].
|
| VectorColumnAssign |
| VectorColumnMapping
This class collects column information for copying a row from one VectorizedRowBatch to
same/another batch.
|
| VectorColumnOrderedMap
This class collects column information for mapping vector columns, including the hive type name.
|
| VectorColumnOrderedMap.Mapping |
| VectorColumnSetInfo
Class to keep information on a set of typed vector columns.
|
| VectorColumnSetInfo.KeyLookupHelper
Helper class for looking up a key value based on key index.
|
| VectorExpressionDescriptor.ArgumentType |
| VectorExpressionDescriptor.Builder
Builder builds a
VectorExpressionDescriptor.Descriptor object. |
| VectorExpressionDescriptor.Descriptor
Descriptor is immutable and is constructed by the
VectorExpressionDescriptor.Builder only. |
| VectorExpressionDescriptor.InputExpressionType |
| VectorExpressionDescriptor.Mode |
| VectorExtractRow
This class extracts specified VectorizedRowBatch row columns into a Writable row Object[].
|
| VectorExtractRow.Extractor |
| VectorHashKeyWrapper
A hash map key wrapper for vectorized processing.
|
| VectorHashKeyWrapperBatch
Class for handling vectorized hash map key wrappers.
|
| VectorizationContext
Context class for vectorization execution.
|
| VectorizationContextRegion
VectorizationContextRegion optional interface implemented by vectorized operators
that are changing the vectorizaiton context (region boundary operators)
|
| VectorizedRowBatch
A VectorizedRowBatch is a set of rows, organized with each column
as a vector.
|
| VectorizedRowBatchCtx
Context for Vectorized row batch.
|
| VectorizedSerde
Serdes that support vectorized
VectorizedRowBatch must implement this interface. |
| VectorMapJoinBaseOperator
The *NON-NATIVE* base vector map join operator class used by VectorMapJoinOperator and
VectorMapJoinOuterFilteredOperator.
|
| VectorUtilBatchObjectPool.IAllocator |
| Class and Description |
|---|
| BytesColumnVector
This class supports string and binary data by value reference -- i.e.
|
| ColumnVector
ColumnVector contains the shared structure for the sub-types,
including NULL information, and whether this vector
repeats, i.e.
|
| DecimalColumnVector |
| DoubleColumnVector
This class represents a nullable double precision floating point column vector.
|
| LongColumnVector
This class represents a nullable int column vector.
|
| VectorExpressionDescriptor.Descriptor
Descriptor is immutable and is constructed by the
VectorExpressionDescriptor.Builder only. |
| VectorizedRowBatch
A VectorizedRowBatch is a set of rows, organized with each column
as a vector.
|
| Class and Description |
|---|
| VectorAggregationBufferRow
Represents a set of aggregation buffers to be used for a specific key for UDAF GROUP BY.
|
| VectorizedRowBatch
A VectorizedRowBatch is a set of rows, organized with each column
as a vector.
|
| Class and Description |
|---|
| VectorAggregationBufferRow
Represents a set of aggregation buffers to be used for a specific key for UDAF GROUP BY.
|
| VectorizedRowBatch
A VectorizedRowBatch is a set of rows, organized with each column
as a vector.
|
| Class and Description |
|---|
| VectorExpressionDescriptor.Descriptor
Descriptor is immutable and is constructed by the
VectorExpressionDescriptor.Builder only. |
| VectorizedRowBatch
A VectorizedRowBatch is a set of rows, organized with each column
as a vector.
|
| Class and Description |
|---|
| VectorColumnOutputMapping
This class collects column information for copying a row from one VectorizedRowBatch to
same/another batch.
|
| VectorColumnSourceMapping
This class collects column information for copying a row from one VectorizedRowBatch to
same/another batch.
|
| VectorCopyRow
This class copies specified columns of a row from one VectorizedRowBatch to another.
|
| VectorDeserializeRow
This class deserializes a serialization format into a row of a VectorizedRowBatch.
|
| VectorizationContext
Context class for vectorization execution.
|
| VectorizationContextRegion
VectorizationContextRegion optional interface implemented by vectorized operators
that are changing the vectorizaiton context (region boundary operators)
|
| VectorizedRowBatch
A VectorizedRowBatch is a set of rows, organized with each column
as a vector.
|
| Class and Description |
|---|
| VectorExpressionDescriptor.Descriptor
Descriptor is immutable and is constructed by the
VectorExpressionDescriptor.Builder only. |
| VectorizedRowBatch
A VectorizedRowBatch is a set of rows, organized with each column
as a vector.
|
| Class and Description |
|---|
| VectorizedRowBatch
A VectorizedRowBatch is a set of rows, organized with each column
as a vector.
|
| Class and Description |
|---|
| BytesColumnVector
This class supports string and binary data by value reference -- i.e.
|
| LongColumnVector
This class represents a nullable int column vector.
|
| VectorizedInputFormatInterface
Marker interface to indicate a given input format supports
vectorization input.
|
| VectorizedRowBatch
A VectorizedRowBatch is a set of rows, organized with each column
as a vector.
|
| VectorizedSerde
Serdes that support vectorized
VectorizedRowBatch must implement this interface. |
| Class and Description |
|---|
| VectorizedInputFormatInterface
Marker interface to indicate a given input format supports
vectorization input.
|
| VectorizedRowBatch
A VectorizedRowBatch is a set of rows, organized with each column
as a vector.
|
| Class and Description |
|---|
| VectorizedExpressions |
| Class and Description |
|---|
| VectorizedExpressions |
Copyright © 2017 The Apache Software Foundation. All rights reserved.