| Interface | Description |
|---|---|
| VectorColumnAssign | |
| VectorizationContextRegion |
VectorizationContextRegion optional interface implemented by vectorized operators
that are changing the vectorization context (region boundary operators)
|
| VectorizationOperator |
VectorizationOperator required interface implemented by vectorized operators
to return the vectorization context and description.
|
| VectorizedInputFormatInterface |
Marker interface to indicate a given input format supports
vectorization input.
|
| VectorUtilBatchObjectPool.IAllocator<T> |
| Class | Description |
|---|---|
| TimestampUtils | |
| VectorAggregationBufferBatch |
This maps a batch to the aggregation buffers sets to use for each row (key)
|
| VectorAggregationBufferRow |
Represents a set of aggregation buffers to be used for a specific key for UDAF GROUP BY.
|
| VectorAggregationDesc |
VectorAggregationDesc.
|
| VectorAppMasterEventOperator |
App Master Event operator implementation.
|
| VectorAssignRow |
This class assigns specified columns of a row from a Writable row objects.
|
| VectorBatchDebug | |
| VectorColumnAssignFactory |
This class is used as a static factory for 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.
|
| VectorColumnOutputMapping |
This class collects column information for copying a row from one VectorizedRowBatch to
same/another batch.
|
| VectorColumnSetInfo |
Class to keep information on a set of typed vector columns.
|
| 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<T extends DeserializeRead> |
This class deserializes a serialization format into a row of a VectorizedRowBatch.
|
| VectorExpressionDescriptor |
Describes a vector expression and encapsulates the
VectorExpressionDescriptor.Mode, number of arguments,
argument types VectorExpressionDescriptor.ArgumentType and expression types VectorExpressionDescriptor.InputExpressionType. |
| VectorExpressionDescriptor.Builder |
Builder builds a
VectorExpressionDescriptor.Descriptor object. |
| VectorExpressionDescriptor.Descriptor |
Descriptor is immutable and is constructed by the
VectorExpressionDescriptor.Builder only. |
| VectorExtractRow |
This class extracts specified VectorizedRowBatch row columns into writables.
|
| VectorFileSinkOperator |
File Sink operator implementation.
|
| VectorFilterOperator |
Filter operator implementation.
|
| VectorGroupByOperator |
Vectorized GROUP BY operator implementation.
|
| VectorGroupKeyHelper |
Class for copying the group key from an input batch to an output batch.
|
| VectorHashKeyWrapper |
A hash map key wrapper for vectorized processing.
|
| VectorHashKeyWrapper.EmptyVectorHashKeyWrapper | |
| VectorHashKeyWrapper.HashContext | |
| VectorHashKeyWrapperBatch |
Class for handling vectorized hash map key wrappers.
|
| VectorizationContext |
Context class for vectorization execution.
|
| VectorizedBatchUtil | |
| VectorizedRowBatchCtx |
Context for Vectorized row batch.
|
| VectorizedSerde |
Serdes that support vectorized
VectorizedRowBatch must implement this interface. |
| VectorizedSupport | |
| VectorLimitOperator |
Limit operator implementation Limits the number of rows to be passed on.
|
| VectorMapJoinBaseOperator |
The *NON-NATIVE* base vector map join operator class used by VectorMapJoinOperator and
VectorMapJoinOuterFilteredOperator.
|
| VectorMapJoinOperator |
The vectorized version of the MapJoinOperator.
|
| VectorMapJoinOuterFilteredOperator |
This is the *NON-NATIVE* vector map join operator for just LEFT OUTER JOIN and filtered.
|
| VectorMapOperator | |
| VectorReduceSinkOperator | |
| VectorSelectOperator |
Select operator implementation.
|
| VectorSerializeRow<T extends SerializeWrite> |
This class serializes columns from a row in a VectorizedRowBatch into a serialization format.
|
| VectorSMBMapJoinOperator |
VectorSMBJoinOperator.
|
| VectorSparkHashTableSinkOperator |
Vectorized version of SparkHashTableSinkOperator
Currently the implementation just delegates all the work to super class
Copied from VectorFileSinkOperator
|
| VectorSparkPartitionPruningSinkOperator |
Vectorized version for SparkPartitionPruningSinkOperator.
|
| VectorUtilBatchObjectPool<T> |
| Annotation Type | Description |
|---|---|
| VectorizedExpressions | |
| VectorizedExpressionsSupportDecimal64 | |
| VectorizedUDAFs |
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.