Package | Description |
---|---|
org.apache.drill.exec.expr |
Drill expression materialization and evaluation facilities.
|
org.apache.drill.exec.expr.fn.interpreter | |
org.apache.drill.exec.physical.impl | |
org.apache.drill.exec.physical.impl.join | |
org.apache.drill.exec.physical.impl.project | |
org.apache.drill.exec.physical.impl.scan.file |
Handles optional file metadata columns: implicit columns and
partition columns.
|
org.apache.drill.exec.physical.impl.scan.project |
Provides run-time semantic analysis of the projection list for the
scan operator.
|
org.apache.drill.exec.physical.impl.scan.v3.lifecycle |
Implements the details of the scan lifecycle for a set of readers,
primarily the process of resolving the scan output schema from a variety
of input schemas, then running each reader, each of which will produce
some number of batches.
|
org.apache.drill.exec.physical.impl.sort | |
org.apache.drill.exec.physical.impl.svremover | |
org.apache.drill.exec.physical.impl.validate | |
org.apache.drill.exec.physical.resultSet |
Provides a second-generation row set (AKA "record batch") writer used
by client code to
Define the schema of a result set.
Write data into the vectors backing a row set.
|
org.apache.drill.exec.physical.resultSet.impl |
Handles the details of the result set loader implementation.
|
org.apache.drill.exec.physical.resultSet.model |
The "row set model" provides a "dual" of the vector structure used to create,
allocate and work with a collection of vectors.
|
org.apache.drill.exec.physical.resultSet.model.hyper |
Implementation of a row set model for hyper-batches.
|
org.apache.drill.exec.physical.resultSet.model.single |
This set of classes models the structure of a batch consisting
of single vectors (as contrasted with a hyper batch.) Provides tools
or metdata-based construction, allocation, reading and writing of
the vectors.
|
org.apache.drill.exec.planner | |
org.apache.drill.exec.planner.sql | |
org.apache.drill.exec.record | |
org.apache.drill.exec.store | |
org.apache.drill.exec.store.hive | |
org.apache.drill.exec.store.mapr.db.json | |
org.apache.drill.exec.store.mock |
Defines a mock data source which generates dummy test data for use
in testing.
|
org.apache.drill.exec.store.parquet.columnreaders | |
org.apache.drill.exec.store.parquet.columnreaders.batchsizing | |
org.apache.drill.exec.store.parquet2 | |
org.apache.drill.exec.store.pojo | |
org.apache.drill.exec.util | |
org.apache.drill.exec.vector | |
org.apache.drill.exec.vector.accessor |
Provides a light-weight, simplified set of column readers and writers that
can be plugged into a variety of row-level readers and writers.
|
org.apache.drill.exec.vector.accessor.impl |
Provides implementations of the API defined in the parent package.
|
org.apache.drill.exec.vector.accessor.reader |
Provides the reader hierarchy as explained in the API package.
|
org.apache.drill.exec.vector.accessor.writer |
Implementation of the vector writers.
|
org.apache.drill.exec.vector.complex | |
org.apache.drill.exec.vector.complex.impl |
Modifier and Type | Method and Description |
---|---|
static ValueVector |
BasicTypeHelper.getNewVector(MaterializedField field,
BufferAllocator allocator) |
static ValueVector |
BasicTypeHelper.getNewVector(MaterializedField field,
BufferAllocator allocator,
CallBack callBack) |
static ValueVector |
BasicTypeHelper.getNewVector(MaterializedField field,
TypeProtos.MajorType type,
BufferAllocator allocator,
CallBack callBack) |
static ValueVector |
BasicTypeHelper.getNewVector(String name,
BufferAllocator allocator,
TypeProtos.MajorType type,
CallBack callback) |
Modifier and Type | Method and Description |
---|---|
static Class<? extends ValueVector> |
BasicTypeHelper.getValueVectorClass(TypeProtos.MinorType type,
TypeProtos.DataMode mode) |
Modifier and Type | Method and Description |
---|---|
static boolean |
BasicTypeHelper.compareValues(ValueVector v1,
int v1index,
ValueVector v2,
int v2index) |
static SqlAccessor |
TypeHelper.getSqlAccessor(ValueVector vector) |
static ValueHolder |
BasicTypeHelper.getValue(ValueVector vector,
int index) |
static void |
BasicTypeHelper.setValue(ValueVector vector,
int index,
ValueHolder holder) |
static void |
BasicTypeHelper.setValueSafe(ValueVector vector,
int index,
ValueHolder holder) |
Modifier and Type | Method and Description |
---|---|
static void |
InterpreterEvaluator.evaluate(int recordCount,
UdfUtilities udfUtilities,
VectorAccessible incoming,
ValueVector outVV,
LogicalExpression expr) |
static void |
InterpreterEvaluator.evaluate(RecordBatch incoming,
ValueVector outVV,
LogicalExpression expr) |
Modifier and Type | Method and Description |
---|---|
<T extends ValueVector> |
OutputMutator.addField(MaterializedField field,
Class<T> clazz)
Add a ValueVector for new (or existing) field.
|
<T extends ValueVector> |
ScanBatch.Mutator.addField(MaterializedField field,
Class<T> clazz) |
Modifier and Type | Method and Description |
---|---|
Map<String,ValueVector> |
ScanBatch.Mutator.fieldVectorMap() |
Map<String,ValueVector> |
ScanBatch.Mutator.implicitFieldVectorMap() |
Modifier and Type | Method and Description |
---|---|
org.apache.commons.lang3.tuple.Pair<ValueVector,Integer> |
RowKeyJoinBatch.nextRowKeyBatch() |
org.apache.commons.lang3.tuple.Pair<ValueVector,Integer> |
RowKeyJoin.nextRowKeyBatch()
Get the next batch of row keys
|
org.apache.commons.lang3.tuple.Pair<ValueVector,Integer> |
HashJoinBatch.nextRowKeyBatch()
Get the hash table iterator that is created for the build side of the hash
join if this hash join was instantiated as a row-key join.
|
Modifier and Type | Field and Description |
---|---|
protected List<ValueVector> |
ProjectRecordBatch.allocationVectors |
Modifier and Type | Method and Description |
---|---|
void |
ProjectMemoryManager.addComplexField(ValueVector vv) |
void |
ProjectMemoryManager.addNewField(ValueVector vvOut,
LogicalExpression logicalExpression) |
void |
ProjectBatchBuilder.addTransferField(String name,
ValueVector vvIn) |
void |
ProjectMemoryManager.addTransferField(ValueVector vvIn,
String inputColumnName,
String outputColumnName) |
static int |
ProjectMemoryManager.getMetadataWidth(ValueVector vv) |
Modifier and Type | Method and Description |
---|---|
ValueVector |
ImplicitColumnManager.vector(int index) |
Modifier and Type | Method and Description |
---|---|
abstract ValueVector |
ResolvedTuple.ResolvedDict.buildVector() |
ValueVector |
ResolvedTuple.ResolvedSingleDict.buildVector() |
ValueVector |
NullColumnBuilder.vector(int index) |
ValueVector |
VectorSource.vector(int index) |
ValueVector |
ReaderSchemaOrchestrator.vector(int index) |
ValueVector |
ResolvedTuple.ResolvedRow.vector(int index) |
ValueVector |
ResolvedTuple.ResolvedMap.vector(int index) |
ValueVector |
ResolvedTuple.ResolvedSingleDict.vector(int index) |
ValueVector |
ResolvedTuple.ResolvedDictArray.vector(int index) |
Modifier and Type | Method and Description |
---|---|
abstract void |
ResolvedTuple.addVector(ValueVector vector) |
void |
ResolvedTuple.ResolvedRow.addVector(ValueVector vector) |
void |
ResolvedTuple.ResolvedMap.addVector(ValueVector vector) |
void |
ResolvedTuple.ResolvedSingleDict.addVector(ValueVector vector) |
void |
ResolvedTuple.ResolvedDictArray.addVector(ValueVector vector) |
Modifier and Type | Method and Description |
---|---|
ValueVector |
OutputBatchBuilder.getVector(org.apache.drill.exec.physical.impl.scan.v3.lifecycle.OutputBatchBuilder.VectorSource source) |
Modifier and Type | Method and Description |
---|---|
List<ValueVector> |
RecordBatchData.getVectors() |
Modifier and Type | Field and Description |
---|---|
protected ValueVector[] |
AbstractSV2Copier.vvIn |
protected ValueVector[] |
AbstractCopier.vvOut |
Modifier and Type | Method and Description |
---|---|
void |
BatchValidator.ErrorReporter.error(String name,
ValueVector vector,
String msg) |
void |
BatchValidator.BaseErrorReporter.error(String name,
ValueVector vector,
String msg) |
void |
BatchValidator.ErrorReporter.warn(String name,
ValueVector vector,
String msg) |
void |
BatchValidator.BaseErrorReporter.warn(String name,
ValueVector vector,
String msg) |
Modifier and Type | Method and Description |
---|---|
ValueVector |
ResultVectorCache.vectorFor(MaterializedField colSchema) |
Modifier and Type | Class and Description |
---|---|
static class |
TupleState.DictVectorState<T extends ValueVector> |
Modifier and Type | Field and Description |
---|---|
protected ValueVector |
SingleVectorState.backupVector |
protected ValueVector |
SingleVectorState.mainVector |
protected T |
TupleState.DictVectorState.vector |
Modifier and Type | Method and Description |
---|---|
<T extends ValueVector> |
ColumnState.vector() |
<T extends ValueVector> |
NullableVectorState.vector() |
<T extends ValueVector> |
NullVectorState.vector() |
<T extends ValueVector> |
NullVectorState.UnmanagedVectorState.vector() |
<T extends ValueVector> |
RepeatedVectorState.vector() |
<T extends ValueVector> |
VectorState.vector()
Underlying vector: the one presented to the consumer of the
result set loader.
|
<T extends ValueVector> |
SingleVectorState.vector() |
Modifier and Type | Method and Description |
---|---|
ValueVector |
NullResultVectorCacheImpl.vectorFor(MaterializedField colSchema) |
ValueVector |
ResultVectorCacheImpl.vectorFor(MaterializedField colSchema) |
Modifier and Type | Method and Description |
---|---|
abstract int |
TupleState.addOutputColumn(ValueVector vector,
ColumnMetadata colSchema) |
int |
TupleState.RowState.addOutputColumn(ValueVector vector,
ColumnMetadata colSchema) |
int |
TupleState.MapState.addOutputColumn(ValueVector vector,
ColumnMetadata colSchema) |
int |
TupleState.DictArrayState.addOutputColumn(ValueVector vector,
ColumnMetadata colSchema) |
protected abstract int |
SingleVectorState.allocateVector(ValueVector vector,
int cardinality) |
int |
SingleVectorState.FixedWidthVectorState.allocateVector(ValueVector vector,
int cardinality) |
int |
SingleVectorState.IsSetVectorState.allocateVector(ValueVector vector,
int cardinality) |
int |
SingleVectorState.VariableWidthVectorState.allocateVector(ValueVector vector,
int cardinality) |
int |
SingleVectorState.OffsetVectorState.allocateVector(ValueVector toAlloc,
int cardinality) |
protected static TypeProtos.MajorType |
SingleVectorState.parseVectorType(ValueVector vector)
The vector mechanism here relies on the vector metadata.
|
static SingleVectorState.SimpleVectorState |
SingleVectorState.vectorState(ColumnMetadata schema,
WriterEvents writer,
ValueVector mainVector) |
Constructor and Description |
---|
FixedWidthVectorState(WriterEvents writer,
ValueVector mainVector) |
IsSetVectorState(WriterEvents writer,
ValueVector mainVector) |
OffsetVectorState(WriterEvents writer,
ValueVector mainVector,
WriterPosition childWriter) |
SimpleVectorState(WriterEvents writer,
ValueVector mainVector) |
SingleVectorState(WriterEvents writer,
ValueVector mainVector) |
UnmanagedVectorState(ValueVector vector) |
VariableWidthVectorState(ColumnMetadata schema,
WriterEvents writer,
ValueVector mainVector) |
Modifier and Type | Method and Description |
---|---|
protected R |
ContainerVisitor.apply(ValueVector vector,
A arg) |
protected R |
ContainerVisitor.visitPrimitive(ValueVector vector,
A arg) |
protected R |
ContainerVisitor.visitVector(ValueVector vector,
A arg) |
Modifier and Type | Method and Description |
---|---|
<T extends ValueVector> |
HyperReaderBuilder.HyperVectorAccessor.vector() |
Modifier and Type | Method and Description |
---|---|
protected AbstractObjectReader |
SimpleReaderBuilder.buildVectorReader(ValueVector vector,
MetadataProvider.VectorDescrip descrip) |
Modifier and Type | Method and Description |
---|---|
void |
PartitionDescriptor.populatePartitionVectors(ValueVector[] vectors,
List<PartitionLocation> partitions,
BitSet partitionColumnBitSet,
Map<Integer,String> fieldNameMap)
Creates an in memory representation of all the partitions.
|
void |
FileSystemPartitionDescriptor.populatePartitionVectors(ValueVector[] vectors,
List<PartitionLocation> partitions,
BitSet partitionColumnBitSet,
Map<Integer,String> fieldNameMap) |
void |
ParquetPartitionDescriptor.populatePartitionVectors(ValueVector[] vectors,
List<PartitionLocation> partitions,
BitSet partitionColumnBitSet,
Map<Integer,String> fieldNameMap) |
Modifier and Type | Method and Description |
---|---|
void |
HivePartitionDescriptor.populatePartitionVectors(ValueVector[] vectors,
List<PartitionLocation> partitions,
BitSet partitionColumnBitSet,
Map<Integer,String> fieldNameMap) |
Modifier and Type | Class and Description |
---|---|
class |
HyperVectorWrapper<T extends ValueVector> |
class |
SimpleVectorWrapper<T extends ValueVector> |
interface |
VectorWrapper<T extends ValueVector> |
Modifier and Type | Class and Description |
---|---|
class |
VectorAccessibleComplexWriter |
Modifier and Type | Method and Description |
---|---|
<T extends ValueVector> |
VectorContainer.addOrGet(MaterializedField field) |
<T extends ValueVector> |
VectorContainer.addOrGet(MaterializedField field,
SchemaChangeCallBack callBack)
This method should be called with MaterializedField which also has correct children field list specially when
the field type is MAP.
|
<T extends ValueVector> |
VectorAccessibleComplexWriter.addOrGet(String name,
TypeProtos.MajorType type,
Class<T> clazz) |
<T extends ValueVector> |
VectorContainer.addOrGet(String name,
TypeProtos.MajorType type,
Class<T> clazz) |
static <T extends ValueVector> |
HyperVectorWrapper.create(MaterializedField f,
T[] v,
boolean releasable) |
static <T extends ValueVector> |
SimpleVectorWrapper.create(T v) |
Modifier and Type | Method and Description |
---|---|
ValueVector |
VectorContainer.getLast() |
ValueVector |
TransferPair.getTo() |
T[] |
HyperVectorWrapper.getValueVectors() |
T[] |
SimpleVectorWrapper.getValueVectors() |
T[] |
VectorWrapper.getValueVectors() |
Modifier and Type | Method and Description |
---|---|
Class<? extends ValueVector> |
TypedFieldId.getIntermediateClass()
Return the class for the value vector (type, mode).
|
Modifier and Type | Method and Description |
---|---|
TypedFieldId |
VectorContainer.add(ValueVector vv) |
void |
VectorContainer.add(ValueVector[] hyperVector) |
void |
VectorContainer.add(ValueVector[] hyperVector,
boolean releasable) |
void |
HyperVectorWrapper.addVector(ValueVector v) |
void |
HyperVectorWrapper.addVectors(ValueVector[] vv) |
void |
RecordBatchSizer.ColumnSize.allocateVector(ValueVector vector,
int recordCount) |
void |
VectorInitializer.allocateVector(ValueVector vector,
int recordCount,
VectorInitializer.AllocationHint hint) |
void |
VectorInitializer.allocateVector(ValueVector vector,
String prefix,
int recordCount) |
static <T extends ValueVector> |
HyperVectorWrapper.create(MaterializedField f,
T[] v,
boolean releasable) |
void |
VectorContainer.remove(ValueVector v) |
void |
HyperVectorWrapper.updateVectorList(ValueVector[] vv)
Method to replace existing list of vectors with the newly provided ValueVectors list in this HyperVectorWrapper
|
Modifier and Type | Method and Description |
---|---|
void |
VectorContainer.addCollection(Iterable<ValueVector> vectors) |
void |
VectorContainer.addHyperList(List<ValueVector> vectors) |
void |
VectorContainer.addHyperList(List<ValueVector> vectors,
boolean releasable) |
void |
RecordBatchMemoryManager.allocateVectors(List<ValueVector> valueVectors) |
void |
RecordBatchMemoryManager.allocateVectors(List<ValueVector> valueVectors,
int recordCount) |
void |
VectorInitializer.allocateVectors(List<ValueVector> valueVectors,
int recordCount) |
static void |
VectorAccessibleUtilities.clear(Iterable<ValueVector> iter) |
static WritableBatch |
WritableBatch.getBatchNoHV(int recordCount,
Iterable<ValueVector> vectors,
boolean isSV2) |
Constructor and Description |
---|
ColumnSize(ValueVector v,
String prefix) |
HyperVectorWrapper(MaterializedField f,
T[] v) |
HyperVectorWrapper(MaterializedField f,
T[] v,
boolean releasable) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractRecordReader.allocate(Map<String,ValueVector> vectorMap) |
void |
RecordReader.allocate(Map<String,ValueVector> vectorMap) |
Modifier and Type | Method and Description |
---|---|
static void |
HiveUtilities.populateVector(ValueVector vector,
DrillBuf managedBuffer,
Object val,
int start,
int end)
Populates vector with given value based on its type.
|
Modifier and Type | Field and Description |
---|---|
protected ValueVector |
JsonTableRangePartitionFunction.partitionKeyVector |
Modifier and Type | Method and Description |
---|---|
void |
MockRecordReader.allocate(Map<String,ValueVector> vectorMap) |
Modifier and Type | Class and Description |
---|---|
class |
ColumnReader<V extends ValueVector> |
class |
NullableVarLengthValuesColumn<V extends ValueVector> |
class |
VarLenColumnBulkInput<V extends ValueVector>
Implements the
VarLenBulkInput interface to optimize data copy |
class |
VarLengthColumn<V extends ValueVector> |
class |
VarLengthValuesColumn<V extends ValueVector> |
Modifier and Type | Method and Description |
---|---|
static ColumnReader<?> |
ColumnReaderFactory.getNullableColumnReader(ParquetRecordReader parentReader,
org.apache.parquet.column.ColumnDescriptor columnDescriptor,
org.apache.parquet.hadoop.metadata.ColumnChunkMetaData columnChunkMetaData,
boolean fixedLength,
ValueVector valueVec,
org.apache.parquet.format.SchemaElement schemaElement) |
Modifier and Type | Method and Description |
---|---|
void |
ParquetRecordReader.allocate(Map<String,ValueVector> vectorMap) |
Constructor and Description |
---|
VarLenBinaryReader(ParquetRecordReader parentReader,
List<VarLengthColumn<? extends ValueVector>> columns) |
Modifier and Type | Field and Description |
---|---|
ValueVector |
RecordBatchSizerManager.VarLenColumnBatchStats.vector
Value vector associated with a VL column
|
ValueVector |
BatchSizingMemoryUtil.ColumnMemoryUsageInfo.vector
Value vector which contains the column batch data
|
Modifier and Type | Method and Description |
---|---|
void |
RecordBatchOverflow.Builder.addFieldOverflow(ValueVector vector,
int firstValueIdx,
int numValues)
Add an overflow field to this batch record overflow object; note that currently only
variable numValues objects are supported.
|
static void |
BatchSizingMemoryUtil.getMemoryUsage(ValueVector sourceVector,
int currValueCount,
BatchSizingMemoryUtil.VectorMemoryUsageInfo vectorMemoryUsage)
Load memory usage information for a variable length value vector
|
Modifier and Type | Method and Description |
---|---|
void |
RecordBatchSizerManager.allocate(Map<String,ValueVector> vectorMap)
Allocates value vectors for the current batch.
|
Constructor and Description |
---|
VarLenColumnBatchStats(ValueVector vector,
int numValuesRead)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
void |
DrillParquetReader.allocate(Map<String,ValueVector> vectorMap) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractPojoWriter<V extends ValueVector>
Parent class for all pojo writers created for each field.
|
Modifier and Type | Field and Description |
---|---|
protected V |
AbstractPojoWriter.vector |
Modifier and Type | Method and Description |
---|---|
void |
AbstractPojoRecordReader.allocate(Map<String,ValueVector> vectorMap) |
Modifier and Type | Method and Description |
---|---|
static void |
VectorUtil.allocateVectors(Iterable<ValueVector> valueVectors,
int count) |
static void |
VectorUtil.setValueCount(Iterable<ValueVector> valueVectors,
int count) |
Modifier and Type | Class and Description |
---|---|
class |
AddOrGetResult<V extends ValueVector> |
Modifier and Type | Interface and Description |
---|---|
interface |
FixedWidthVector |
interface |
NullableVector |
interface |
VariableWidthVector |
Modifier and Type | Class and Description |
---|---|
class |
BaseDataValueVector |
class |
BaseValueVector |
class |
BigIntVector
BigInt implements a vector of fixed width values.
|
class |
BitVector
Bit implements a vector of bit-width values.
|
class |
DateVector
Date implements a vector of fixed width values.
|
class |
Decimal18Vector
Decimal18 implements a vector of fixed width values.
|
class |
Decimal28DenseVector
Decimal28Dense implements a vector of fixed width values.
|
class |
Decimal28SparseVector
Decimal28Sparse implements a vector of fixed width values.
|
class |
Decimal38DenseVector
Decimal38Dense implements a vector of fixed width values.
|
class |
Decimal38SparseVector
Decimal38Sparse implements a vector of fixed width values.
|
class |
Decimal9Vector
Decimal9 implements a vector of fixed width values.
|
class |
Float4Vector
Float4 implements a vector of fixed width values.
|
class |
Float8Vector
Float8 implements a vector of fixed width values.
|
class |
IntervalDayVector
IntervalDay implements a vector of fixed width values.
|
class |
IntervalVector
Interval implements a vector of fixed width values.
|
class |
IntervalYearVector
IntervalYear implements a vector of fixed width values.
|
class |
IntVector
Int implements a vector of fixed width values.
|
class |
NullableBigIntVector
NullableBigInt implements a vector of values which could be null.
|
class |
NullableBitVector
NullableBit implements a vector of values which could be null.
|
class |
NullableDateVector
NullableDate implements a vector of values which could be null.
|
class |
NullableDecimal18Vector
NullableDecimal18 implements a vector of values which could be null.
|
class |
NullableDecimal28DenseVector
NullableDecimal28Dense implements a vector of values which could be null.
|
class |
NullableDecimal28SparseVector
NullableDecimal28Sparse implements a vector of values which could be null.
|
class |
NullableDecimal38DenseVector
NullableDecimal38Dense implements a vector of values which could be null.
|
class |
NullableDecimal38SparseVector
NullableDecimal38Sparse implements a vector of values which could be null.
|
class |
NullableDecimal9Vector
NullableDecimal9 implements a vector of values which could be null.
|
class |
NullableFloat4Vector
NullableFloat4 implements a vector of values which could be null.
|
class |
NullableFloat8Vector
NullableFloat8 implements a vector of values which could be null.
|
class |
NullableIntervalDayVector
NullableIntervalDay implements a vector of values which could be null.
|
class |
NullableIntervalVector
NullableInterval implements a vector of values which could be null.
|
class |
NullableIntervalYearVector
NullableIntervalYear implements a vector of values which could be null.
|
class |
NullableIntVector
NullableInt implements a vector of values which could be null.
|
class |
NullableSmallIntVector
NullableSmallInt implements a vector of values which could be null.
|
class |
NullableTimeStampVector
NullableTimeStamp implements a vector of values which could be null.
|
class |
NullableTimeVector
NullableTime implements a vector of values which could be null.
|
class |
NullableTinyIntVector
NullableTinyInt implements a vector of values which could be null.
|
class |
NullableUInt1Vector
NullableUInt1 implements a vector of values which could be null.
|
class |
NullableUInt2Vector
NullableUInt2 implements a vector of values which could be null.
|
class |
NullableUInt4Vector
NullableUInt4 implements a vector of values which could be null.
|
class |
NullableUInt8Vector
NullableUInt8 implements a vector of values which could be null.
|
class |
NullableVar16CharVector
NullableVar16Char implements a vector of values which could be null.
|
class |
NullableVarBinaryVector
NullableVarBinary implements a vector of values which could be null.
|
class |
NullableVarCharVector
NullableVarChar implements a vector of values which could be null.
|
class |
NullableVarDecimalVector
NullableVarDecimal implements a vector of values which could be null.
|
class |
ObjectVector |
class |
RepeatedBigIntVector
RepeatedBigInt implements a vector with multiple values per row (e.g.
|
class |
RepeatedBitVector
RepeatedBit implements a vector with multiple values per row (e.g.
|
class |
RepeatedDateVector
RepeatedDate implements a vector with multiple values per row (e.g.
|
class |
RepeatedDecimal18Vector
RepeatedDecimal18 implements a vector with multiple values per row (e.g.
|
class |
RepeatedDecimal28DenseVector
RepeatedDecimal28Dense implements a vector with multiple values per row (e.g.
|
class |
RepeatedDecimal28SparseVector
RepeatedDecimal28Sparse implements a vector with multiple values per row (e.g.
|
class |
RepeatedDecimal38DenseVector
RepeatedDecimal38Dense implements a vector with multiple values per row (e.g.
|
class |
RepeatedDecimal38SparseVector
RepeatedDecimal38Sparse implements a vector with multiple values per row (e.g.
|
class |
RepeatedDecimal9Vector
RepeatedDecimal9 implements a vector with multiple values per row (e.g.
|
class |
RepeatedFloat4Vector
RepeatedFloat4 implements a vector with multiple values per row (e.g.
|
class |
RepeatedFloat8Vector
RepeatedFloat8 implements a vector with multiple values per row (e.g.
|
class |
RepeatedIntervalDayVector
RepeatedIntervalDay implements a vector with multiple values per row (e.g.
|
class |
RepeatedIntervalVector
RepeatedInterval implements a vector with multiple values per row (e.g.
|
class |
RepeatedIntervalYearVector
RepeatedIntervalYear implements a vector with multiple values per row (e.g.
|
class |
RepeatedIntVector
RepeatedInt implements a vector with multiple values per row (e.g.
|
class |
RepeatedSmallIntVector
RepeatedSmallInt implements a vector with multiple values per row (e.g.
|
class |
RepeatedTimeStampVector
RepeatedTimeStamp implements a vector with multiple values per row (e.g.
|
class |
RepeatedTimeVector
RepeatedTime implements a vector with multiple values per row (e.g.
|
class |
RepeatedTinyIntVector
RepeatedTinyInt implements a vector with multiple values per row (e.g.
|
class |
RepeatedUInt1Vector
RepeatedUInt1 implements a vector with multiple values per row (e.g.
|
class |
RepeatedUInt2Vector
RepeatedUInt2 implements a vector with multiple values per row (e.g.
|
class |
RepeatedUInt4Vector
RepeatedUInt4 implements a vector with multiple values per row (e.g.
|
class |
RepeatedUInt8Vector
RepeatedUInt8 implements a vector with multiple values per row (e.g.
|
class |
RepeatedVar16CharVector
RepeatedVar16Char implements a vector with multiple values per row (e.g.
|
class |
RepeatedVarBinaryVector
RepeatedVarBinary implements a vector with multiple values per row (e.g.
|
class |
RepeatedVarCharVector
RepeatedVarChar implements a vector with multiple values per row (e.g.
|
class |
RepeatedVarDecimalVector
RepeatedVarDecimal implements a vector with multiple values per row (e.g.
|
class |
SmallIntVector
SmallInt implements a vector of fixed width values.
|
class |
TimeStampVector
TimeStamp implements a vector of fixed width values.
|
class |
TimeVector
Time implements a vector of fixed width values.
|
class |
TinyIntVector
TinyInt implements a vector of fixed width values.
|
class |
UInt1Vector
UInt1 implements a vector of fixed width values.
|
class |
UInt2Vector
UInt2 implements a vector of fixed width values.
|
class |
UInt4Vector
UInt4 implements a vector of fixed width values.
|
class |
UInt8Vector
UInt8 implements a vector of fixed width values.
|
class |
UntypedNullVector
UntypedNullVector is to represent a value vector with
TypeProtos.MinorType.NULL
All values in the vector represent two semantic implications: 1) the value is unknown, 2) the type is unknown. |
class |
Var16CharVector
Var16CharVector implements a vector of variable width values.
|
class |
VarBinaryVector
VarBinaryVector implements a vector of variable width values.
|
class |
VarCharVector
VarCharVector implements a vector of variable width values.
|
class |
VarDecimalVector
VarDecimalVector implements a vector of variable width values.
|
class |
ZeroVector |
Modifier and Type | Method and Description |
---|---|
ValueVector |
NullableVector.getBitsVector() |
ValueVector |
NullableVector.getValuesVector() |
Modifier and Type | Method and Description |
---|---|
Iterator<ValueVector> |
BaseValueVector.iterator() |
Iterator<ValueVector> |
ObjectVector.iterator() |
Iterator<ValueVector> |
ZeroVector.iterator() |
Modifier and Type | Method and Description |
---|---|
static void |
AllocationHelper.allocate(ValueVector vector,
int valueCount,
int bytesPerValue) |
static void |
AllocationHelper.allocate(ValueVector vector,
int valueCount,
int bytesPerValue,
float repeatedPerTop)
Allocate an array, but with a fractional value for the number of elements
per array.
|
static void |
AllocationHelper.allocate(ValueVector vector,
int valueCount,
int bytesPerValue,
int repeatedPerTop) |
static void |
AllocationHelper.allocateNew(ValueVector vector,
int valueCount)
Allocates the exact amount if v is fixed width, otherwise falls back to dynamic allocation
|
static void |
AllocationHelper.allocatePrecomputedChildCount(ValueVector vector,
int valueCount,
int bytesPerValue,
int childValCount) |
static boolean |
BaseValueVector.checkBufRefs(ValueVector vv) |
void |
ObjectVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
UntypedNullVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
ValueVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
ZeroVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
BitVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
TinyIntVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
UInt1Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
UInt2Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
SmallIntVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
IntVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
UInt4Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
Float4Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
TimeVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
IntervalYearVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
Decimal9Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
BigIntVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
UInt8Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
Float8Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
DateVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
TimeStampVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
Decimal18Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
IntervalDayVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
IntervalVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
Decimal28DenseVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
Decimal38DenseVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
Decimal38SparseVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
Decimal28SparseVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableTinyIntVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableUInt1Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableUInt2Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableSmallIntVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableIntVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableUInt4Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableFloat4Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableTimeVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableIntervalYearVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableDecimal9Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableBigIntVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableUInt8Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableFloat8Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableDateVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableTimeStampVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableDecimal18Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableIntervalDayVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableIntervalVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableDecimal28DenseVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableDecimal38DenseVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableDecimal38SparseVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableDecimal28SparseVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableVarBinaryVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableVarCharVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableVar16CharVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableVarDecimalVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
NullableBitVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedTinyIntVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedUInt1Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedUInt2Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedSmallIntVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedIntVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedUInt4Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedFloat4Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedTimeVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedIntervalYearVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedDecimal9Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedBigIntVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedUInt8Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedFloat8Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedDateVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedTimeStampVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedDecimal18Vector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedIntervalDayVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedIntervalVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedDecimal28DenseVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedDecimal38DenseVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedDecimal38SparseVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedDecimal28SparseVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedVarBinaryVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedVarCharVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedVar16CharVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedVarDecimalVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedBitVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
VarBinaryVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
VarCharVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
Var16CharVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
VarDecimalVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
BaseDataValueVector.exchange(ValueVector other) |
void |
ObjectVector.exchange(ValueVector other) |
void |
ValueVector.exchange(ValueVector other)
Exchange state with another value vector of the same type.
|
void |
ZeroVector.exchange(ValueVector other) |
void |
BitVector.exchange(ValueVector other) |
void |
NullableTinyIntVector.exchange(ValueVector other) |
void |
NullableUInt1Vector.exchange(ValueVector other) |
void |
NullableUInt2Vector.exchange(ValueVector other) |
void |
NullableSmallIntVector.exchange(ValueVector other) |
void |
NullableIntVector.exchange(ValueVector other) |
void |
NullableUInt4Vector.exchange(ValueVector other) |
void |
NullableFloat4Vector.exchange(ValueVector other) |
void |
NullableTimeVector.exchange(ValueVector other) |
void |
NullableIntervalYearVector.exchange(ValueVector other) |
void |
NullableDecimal9Vector.exchange(ValueVector other) |
void |
NullableBigIntVector.exchange(ValueVector other) |
void |
NullableUInt8Vector.exchange(ValueVector other) |
void |
NullableFloat8Vector.exchange(ValueVector other) |
void |
NullableDateVector.exchange(ValueVector other) |
void |
NullableTimeStampVector.exchange(ValueVector other) |
void |
NullableDecimal18Vector.exchange(ValueVector other) |
void |
NullableIntervalDayVector.exchange(ValueVector other) |
void |
NullableIntervalVector.exchange(ValueVector other) |
void |
NullableDecimal28DenseVector.exchange(ValueVector other) |
void |
NullableDecimal38DenseVector.exchange(ValueVector other) |
void |
NullableDecimal38SparseVector.exchange(ValueVector other) |
void |
NullableDecimal28SparseVector.exchange(ValueVector other) |
void |
NullableVarBinaryVector.exchange(ValueVector other) |
void |
NullableVarCharVector.exchange(ValueVector other) |
void |
NullableVar16CharVector.exchange(ValueVector other) |
void |
NullableVarDecimalVector.exchange(ValueVector other) |
void |
NullableBitVector.exchange(ValueVector other) |
void |
VarBinaryVector.exchange(ValueVector other) |
void |
VarCharVector.exchange(ValueVector other) |
void |
Var16CharVector.exchange(ValueVector other) |
void |
VarDecimalVector.exchange(ValueVector other) |
TransferPair |
ObjectVector.makeTransferPair(ValueVector to) |
TransferPair |
UntypedNullVector.makeTransferPair(ValueVector to) |
TransferPair |
ValueVector.makeTransferPair(ValueVector target)
Returns a new
transfer pair that is used to transfer underlying
buffers into the target vector. |
TransferPair |
ZeroVector.makeTransferPair(ValueVector target) |
TransferPair |
BitVector.makeTransferPair(ValueVector to) |
TransferPair |
TinyIntVector.makeTransferPair(ValueVector to) |
TransferPair |
UInt1Vector.makeTransferPair(ValueVector to) |
TransferPair |
UInt2Vector.makeTransferPair(ValueVector to) |
TransferPair |
SmallIntVector.makeTransferPair(ValueVector to) |
TransferPair |
IntVector.makeTransferPair(ValueVector to) |
TransferPair |
UInt4Vector.makeTransferPair(ValueVector to) |
TransferPair |
Float4Vector.makeTransferPair(ValueVector to) |
TransferPair |
TimeVector.makeTransferPair(ValueVector to) |
TransferPair |
IntervalYearVector.makeTransferPair(ValueVector to) |
TransferPair |
Decimal9Vector.makeTransferPair(ValueVector to) |
TransferPair |
BigIntVector.makeTransferPair(ValueVector to) |
TransferPair |
UInt8Vector.makeTransferPair(ValueVector to) |
TransferPair |
Float8Vector.makeTransferPair(ValueVector to) |
TransferPair |
DateVector.makeTransferPair(ValueVector to) |
TransferPair |
TimeStampVector.makeTransferPair(ValueVector to) |
TransferPair |
Decimal18Vector.makeTransferPair(ValueVector to) |
TransferPair |
IntervalDayVector.makeTransferPair(ValueVector to) |
TransferPair |
IntervalVector.makeTransferPair(ValueVector to) |
TransferPair |
Decimal28DenseVector.makeTransferPair(ValueVector to) |
TransferPair |
Decimal38DenseVector.makeTransferPair(ValueVector to) |
TransferPair |
Decimal38SparseVector.makeTransferPair(ValueVector to) |
TransferPair |
Decimal28SparseVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableTinyIntVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableUInt1Vector.makeTransferPair(ValueVector to) |
TransferPair |
NullableUInt2Vector.makeTransferPair(ValueVector to) |
TransferPair |
NullableSmallIntVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableIntVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableUInt4Vector.makeTransferPair(ValueVector to) |
TransferPair |
NullableFloat4Vector.makeTransferPair(ValueVector to) |
TransferPair |
NullableTimeVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableIntervalYearVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableDecimal9Vector.makeTransferPair(ValueVector to) |
TransferPair |
NullableBigIntVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableUInt8Vector.makeTransferPair(ValueVector to) |
TransferPair |
NullableFloat8Vector.makeTransferPair(ValueVector to) |
TransferPair |
NullableDateVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableTimeStampVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableDecimal18Vector.makeTransferPair(ValueVector to) |
TransferPair |
NullableIntervalDayVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableIntervalVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableDecimal28DenseVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableDecimal38DenseVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableDecimal38SparseVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableDecimal28SparseVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableVarBinaryVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableVarCharVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableVar16CharVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableVarDecimalVector.makeTransferPair(ValueVector to) |
TransferPair |
NullableBitVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedTinyIntVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedUInt1Vector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedUInt2Vector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedSmallIntVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedIntVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedUInt4Vector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedFloat4Vector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedTimeVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedIntervalYearVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedDecimal9Vector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedBigIntVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedUInt8Vector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedFloat8Vector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedDateVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedTimeStampVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedDecimal18Vector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedIntervalDayVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedIntervalVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedDecimal28DenseVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedDecimal38DenseVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedDecimal38SparseVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedDecimal28SparseVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedVarBinaryVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedVarCharVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedVar16CharVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedVarDecimalVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedBitVector.makeTransferPair(ValueVector to) |
TransferPair |
VarBinaryVector.makeTransferPair(ValueVector to) |
TransferPair |
VarCharVector.makeTransferPair(ValueVector to) |
TransferPair |
Var16CharVector.makeTransferPair(ValueVector to) |
TransferPair |
VarDecimalVector.makeTransferPair(ValueVector to) |
void |
BaseValueVector.toNullable(ValueVector nullableVector) |
void |
ObjectVector.toNullable(ValueVector nullableVector) |
void |
ValueVector.toNullable(ValueVector nullableVector)
Convert a non-nullable vector to nullable by shuffling the data from
one to the other.
|
void |
ZeroVector.toNullable(ValueVector nullableVector) |
void |
BitVector.toNullable(ValueVector nullableVector) |
void |
TinyIntVector.toNullable(ValueVector nullableVector) |
void |
UInt1Vector.toNullable(ValueVector nullableVector) |
void |
UInt2Vector.toNullable(ValueVector nullableVector) |
void |
SmallIntVector.toNullable(ValueVector nullableVector) |
void |
IntVector.toNullable(ValueVector nullableVector) |
void |
UInt4Vector.toNullable(ValueVector nullableVector) |
void |
Float4Vector.toNullable(ValueVector nullableVector) |
void |
TimeVector.toNullable(ValueVector nullableVector) |
void |
IntervalYearVector.toNullable(ValueVector nullableVector) |
void |
Decimal9Vector.toNullable(ValueVector nullableVector) |
void |
BigIntVector.toNullable(ValueVector nullableVector) |
void |
UInt8Vector.toNullable(ValueVector nullableVector) |
void |
Float8Vector.toNullable(ValueVector nullableVector) |
void |
DateVector.toNullable(ValueVector nullableVector) |
void |
TimeStampVector.toNullable(ValueVector nullableVector) |
void |
Decimal18Vector.toNullable(ValueVector nullableVector) |
void |
IntervalDayVector.toNullable(ValueVector nullableVector) |
void |
IntervalVector.toNullable(ValueVector nullableVector) |
void |
Decimal28DenseVector.toNullable(ValueVector nullableVector) |
void |
Decimal38DenseVector.toNullable(ValueVector nullableVector) |
void |
Decimal38SparseVector.toNullable(ValueVector nullableVector) |
void |
Decimal28SparseVector.toNullable(ValueVector nullableVector) |
void |
NullableTinyIntVector.toNullable(ValueVector nullableVector) |
void |
NullableUInt1Vector.toNullable(ValueVector nullableVector) |
void |
NullableUInt2Vector.toNullable(ValueVector nullableVector) |
void |
NullableSmallIntVector.toNullable(ValueVector nullableVector) |
void |
NullableIntVector.toNullable(ValueVector nullableVector) |
void |
NullableUInt4Vector.toNullable(ValueVector nullableVector) |
void |
NullableFloat4Vector.toNullable(ValueVector nullableVector) |
void |
NullableTimeVector.toNullable(ValueVector nullableVector) |
void |
NullableIntervalYearVector.toNullable(ValueVector nullableVector) |
void |
NullableDecimal9Vector.toNullable(ValueVector nullableVector) |
void |
NullableBigIntVector.toNullable(ValueVector nullableVector) |
void |
NullableUInt8Vector.toNullable(ValueVector nullableVector) |
void |
NullableFloat8Vector.toNullable(ValueVector nullableVector) |
void |
NullableDateVector.toNullable(ValueVector nullableVector) |
void |
NullableTimeStampVector.toNullable(ValueVector nullableVector) |
void |
NullableDecimal18Vector.toNullable(ValueVector nullableVector) |
void |
NullableIntervalDayVector.toNullable(ValueVector nullableVector) |
void |
NullableIntervalVector.toNullable(ValueVector nullableVector) |
void |
NullableDecimal28DenseVector.toNullable(ValueVector nullableVector) |
void |
NullableDecimal38DenseVector.toNullable(ValueVector nullableVector) |
void |
NullableDecimal38SparseVector.toNullable(ValueVector nullableVector) |
void |
NullableDecimal28SparseVector.toNullable(ValueVector nullableVector) |
void |
NullableBitVector.toNullable(ValueVector nullableVector) |
void |
VarBinaryVector.toNullable(ValueVector nullableVector) |
void |
VarCharVector.toNullable(ValueVector nullableVector) |
void |
Var16CharVector.toNullable(ValueVector nullableVector) |
void |
VarDecimalVector.toNullable(ValueVector nullableVector) |
Modifier and Type | Method and Description |
---|---|
static void |
VectorPrinter.header(ValueVector vector,
int start,
int length) |
Modifier and Type | Method and Description |
---|---|
<T extends ValueVector> |
VectorAccessor.vector() |
<T extends ValueVector> |
VectorAccessors.NullVectorAccesor.vector() |
<T extends ValueVector> |
VectorAccessors.SingleVectorAccessor.vector() |
<T extends ValueVector> |
VectorAccessors.ArrayOffsetHyperVectorAccessor.vector() |
<T extends ValueVector> |
VectorAccessors.ArrayDataHyperVectorAccessor.vector() |
<T extends ValueVector> |
VectorAccessors.VarWidthOffsetHyperVectorAccessor.vector() |
<T extends ValueVector> |
VectorAccessors.NullableValuesHyperVectorAccessor.vector() |
<T extends ValueVector> |
VectorAccessors.NullableBitsHyperVectorStateReader.vector() |
<T extends ValueVector> |
VectorAccessors.ListBitsHyperVectorStateReader.vector() |
<T extends ValueVector> |
VectorAccessors.ListMemberHyperVectorAccessor.vector() |
<T extends ValueVector> |
VectorAccessors.MapMemberHyperVectorAccessor.vector() |
<T extends ValueVector> |
VectorAccessors.UnionTypeHyperVectorAccessor.vector() |
<T extends ValueVector> |
VectorAccessors.UnionMemberHyperVectorAccessor.vector() |
Constructor and Description |
---|
SingleVectorAccessor(ValueVector vector) |
Modifier and Type | Method and Description |
---|---|
static AbstractObjectWriter |
ColumnWriterFactory.buildColumnWriter(ColumnMetadata schema,
ValueVector vector) |
static BaseScalarWriter |
ColumnWriterFactory.newWriter(ValueVector vector) |
Constructor and Description |
---|
BitColumnWriter(ValueVector vector) |
Modifier and Type | Interface and Description |
---|---|
interface |
RepeatedValueVector
Represents repeated (AKA "array") value vectors.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractContainerVector
Base class for composite vectors.
|
class |
AbstractMapVector
Base class for MapVectors.
|
class |
AbstractRepeatedMapVector |
class |
BaseRepeatedValueVector |
class |
DictVector
A
ValueVector holding key-value pairs. |
class |
ListVector
"Non-repeated" LIST vector.
|
class |
MapVector |
class |
RepeatedDictVector |
class |
RepeatedListVector |
protected static class |
RepeatedListVector.DelegateRepeatedVector |
class |
RepeatedMapVector |
class |
UnionVector |
Modifier and Type | Field and Description |
---|---|
static ValueVector |
BaseRepeatedValueVector.DEFAULT_DATA_VECTOR |
protected ValueVector |
BaseRepeatedValueVector.vector |
ValueVector |
VectorWithOrdinal.vector |
Modifier and Type | Method and Description |
---|---|
abstract <T extends ValueVector> |
AbstractContainerVector.addOrGet(String name,
TypeProtos.MajorType type,
Class<T> clazz) |
<T extends ValueVector> |
AbstractMapVector.addOrGet(String name,
TypeProtos.MajorType type,
Class<T> clazz)
Adds a new field with the given parameters or replaces the existing one and consequently returns the resultant
ValueVector . |
<T extends ValueVector> |
RepeatedListVector.addOrGet(String name,
TypeProtos.MajorType type,
Class<T> clazz)
Deprecated.
prefer using
RepeatedListVector.addOrGetVector(org.apache.drill.exec.vector.VectorDescriptor) instead. |
<T extends ValueVector> |
AbstractRepeatedMapVector.addOrGetVector(VectorDescriptor descriptor) |
<T extends ValueVector> |
BaseRepeatedValueVector.addOrGetVector(VectorDescriptor descriptor) |
<T extends ValueVector> |
ContainerVectorLike.addOrGetVector(VectorDescriptor descriptor)
Creates and adds a child vector if none with the same name exists, else returns the vector instance.
|
<T extends ValueVector> |
ListVector.addOrGetVector(VectorDescriptor descriptor) |
<T extends ValueVector> |
RepeatedListVector.addOrGetVector(VectorDescriptor descriptor) |
abstract <T extends ValueVector> |
AbstractContainerVector.getChild(String name,
Class<T> clazz) |
<T extends ValueVector> |
AbstractMapVector.getChild(String name,
Class<T> clazz)
Returns a
ValueVector instance of subtype of |
<T extends ValueVector> |
DictVector.getChild(String name,
Class<T> clazz) |
<T extends ValueVector> |
RepeatedListVector.getChild(String name,
Class<T> clazz) |
<T extends ValueVector> |
UnionVector.member(TypeProtos.MinorType type) |
<T extends ValueVector> |
UnionVector.subtype(TypeProtos.MinorType type) |
protected <T extends ValueVector> |
AbstractContainerVector.typeify(ValueVector v,
Class<T> clazz) |
Modifier and Type | Method and Description |
---|---|
ValueVector |
UnionVector.addVector(ValueVector v)
Add a vector that matches the argument.
|
ValueVector |
ListVector.getBitsVector() |
ValueVector |
AbstractContainerVector.getChild(String name)
Returns a
ValueVector corresponding to the given field name if exists or null. |
ValueVector |
DictVector.getChild(String name)
Returns a
ValueVector corresponding to the given field name if exists or null. |
ValueVector |
AbstractMapVector.getChildByOrdinal(int id)
Returns a
ValueVector corresponding to the given ordinal identifier. |
ValueVector |
AbstractRepeatedMapVector.getDataVector() |
ValueVector |
BaseRepeatedValueVector.getDataVector() |
ValueVector |
ListVector.getDataVector() |
ValueVector |
RepeatedListVector.getDataVector() |
ValueVector |
RepeatedValueVector.getDataVector() |
ValueVector |
DictVector.getKeys() |
ValueVector |
UnionVector.getMember(TypeProtos.MinorType type)
Add or get a type member given the type.
|
ValueVector |
BaseRepeatedValueVector.BaseRepeatedValueVectorTransferPair.getTo() |
ValueVector |
MapVector.MapTransferPair.getTo() |
ValueVector |
RepeatedListVector.RepeatedListTransferPair.getTo() |
ValueVector |
DictVector.getValues() |
ValueVector |
MapVector.getVectorById(int id) |
ValueVector |
UnionVector.setFirstType(ValueVector v,
int newValueCount) |
Modifier and Type | Method and Description |
---|---|
protected Collection<ValueVector> |
AbstractMapVector.getChildren()
Returns a sequence of underlying child vectors.
|
List<ValueVector> |
AbstractMapVector.getPrimitiveVectors()
Returns a list of scalar child vectors recursing the entire vector hierarchy.
|
List<ValueVector> |
AbstractRepeatedMapVector.getPrimitiveVectors() |
Iterator<ValueVector> |
AbstractMapVector.iterator() |
Iterator<ValueVector> |
BaseRepeatedValueVector.iterator() |
Iterator<ValueVector> |
RepeatedListVector.iterator() |
Iterator<ValueVector> |
UnionVector.iterator() |
Modifier and Type | Method and Description |
---|---|
void |
UnionVector.addType(ValueVector vector)
Add an externally-created subtype vector.
|
ValueVector |
UnionVector.addVector(ValueVector v)
Add a vector that matches the argument.
|
void |
AbstractRepeatedMapVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
ListVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
MapVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedDictVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedListVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
RepeatedListVector.DelegateRepeatedVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
UnionVector.copyEntry(int toIndex,
ValueVector from,
int fromIndex) |
void |
AbstractMapVector.exchange(ValueVector other) |
void |
AbstractRepeatedMapVector.exchange(ValueVector other) |
void |
BaseRepeatedValueVector.exchange(ValueVector other) |
void |
DictVector.exchange(ValueVector other) |
void |
MapVector.exchange(ValueVector other) |
void |
RepeatedListVector.exchange(ValueVector other) |
void |
UnionVector.exchange(ValueVector other) |
static TypedFieldId |
FieldIdUtil.getFieldId(ValueVector vector,
int id,
SchemaPath expectedPath,
boolean hyper) |
static TypedFieldId |
FieldIdUtil.getFieldIdIfMatches(ValueVector vector,
TypedFieldId.Builder builder,
boolean addToBreadCrumb,
PathSegment seg)
Utility method to obtain
TypedFieldId , providing metadata
for specified field given by value vector used in code generation. |
TransferPair |
DictVector.makeTransferPair(ValueVector to) |
TransferPair |
ListVector.makeTransferPair(ValueVector target) |
TransferPair |
MapVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedDictVector.makeTransferPair(ValueVector target) |
TransferPair |
RepeatedListVector.makeTransferPair(ValueVector to) |
TransferPair |
RepeatedListVector.DelegateRepeatedVector.makeTransferPair(ValueVector target) |
TransferPair |
RepeatedMapVector.makeTransferPair(ValueVector to) |
TransferPair |
UnionVector.makeTransferPair(ValueVector target) |
void |
AbstractMapVector.putChild(String name,
ValueVector vector)
Inserts the vector with the given name if it does not exist else replaces it with the new value.
|
void |
DictVector.putChild(String name,
ValueVector vector)
Inserts the vector with the given name if it does not exist else replaces it with the new value.
|
protected void |
AbstractMapVector.putVector(String name,
ValueVector vector)
Inserts the input vector into the map if it does not exist, replaces if it exists already
|
protected void |
BaseRepeatedValueVector.replaceDataVector(ValueVector v) |
void |
BaseRepeatedValueVector.setChildVector(ValueVector childVector) |
void |
ListVector.setChildVector(ValueVector childVector) |
void |
RepeatedListVector.setChildVector(ValueVector childVector) |
ValueVector |
UnionVector.setFirstType(ValueVector v,
int newValueCount) |
void |
AbstractRepeatedMapVector.toNullable(ValueVector nullableVector) |
void |
MapVector.toNullable(ValueVector nullableVector) |
void |
RepeatedListVector.toNullable(ValueVector nullableVector) |
void |
UnionVector.toNullable(ValueVector nullableVector) |
protected <T extends ValueVector> |
AbstractContainerVector.typeify(ValueVector v,
Class<T> clazz) |
Constructor and Description |
---|
BaseRepeatedValueVector(MaterializedField field,
BufferAllocator allocator,
ValueVector vector) |
VectorWithOrdinal(ValueVector v,
int ordinal) |
Constructor and Description |
---|
PromotableWriter(ValueVector v,
AbstractMapVector parentContainer) |
PromotableWriter(ValueVector v,
ListVector listVector) |
Copyright © 1970 The Apache Software Foundation. All rights reserved.