Uses of Interface
org.apache.drill.exec.vector.ValueVector
Packages that use ValueVector
Package
Description
Drill expression materialization and evaluation facilities.
Handles optional file metadata columns: implicit columns and
partition columns.
Provides run-time semantic analysis of the projection list for the
scan operator.
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.
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.
Handles the details of the result set loader implementation.
The "row set model" provides a "dual" of the vector structure used to create,
allocate and work with a collection of vectors.
Implementation of a row set model for hyper-batches.
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.
Defines a mock data source which generates dummy test data for use
in testing.
Provides a light-weight, simplified set of column readers and writers that
can be plugged into a variety of row-level readers and writers.
Provides implementations of the API defined in the parent package.
Provides the reader hierarchy as explained in the API package.
Implementation of the vector writers.
-
Uses of ValueVector in org.apache.drill.exec.expr
Methods in org.apache.drill.exec.expr that return ValueVectorModifier and TypeMethodDescriptionstatic ValueVectorBasicTypeHelper.getNewVector(String name, BufferAllocator allocator, TypeProtos.MajorType type, CallBack callback) static ValueVectorBasicTypeHelper.getNewVector(MaterializedField field, TypeProtos.MajorType type, BufferAllocator allocator, CallBack callBack) static ValueVectorBasicTypeHelper.getNewVector(MaterializedField field, BufferAllocator allocator) static ValueVectorBasicTypeHelper.getNewVector(MaterializedField field, BufferAllocator allocator, CallBack callBack) Methods in org.apache.drill.exec.expr that return types with arguments of type ValueVectorModifier and TypeMethodDescriptionstatic Class<? extends ValueVector> BasicTypeHelper.getValueVectorClass(TypeProtos.MinorType type, TypeProtos.DataMode mode) Methods in org.apache.drill.exec.expr with parameters of type ValueVectorModifier and TypeMethodDescriptionstatic booleanBasicTypeHelper.compareValues(ValueVector v1, int v1index, ValueVector v2, int v2index) static SqlAccessorTypeHelper.getSqlAccessor(ValueVector vector) static ValueHolderBasicTypeHelper.getValue(ValueVector vector, int index) static voidBasicTypeHelper.setValue(ValueVector vector, int index, ValueHolder holder) static voidBasicTypeHelper.setValueSafe(ValueVector vector, int index, ValueHolder holder) -
Uses of ValueVector in org.apache.drill.exec.expr.fn.interpreter
Methods in org.apache.drill.exec.expr.fn.interpreter with parameters of type ValueVectorModifier and TypeMethodDescriptionstatic voidInterpreterEvaluator.evaluate(int recordCount, UdfUtilities udfUtilities, VectorAccessible incoming, ValueVector outVV, LogicalExpression expr) static voidInterpreterEvaluator.evaluate(RecordBatch incoming, ValueVector outVV, LogicalExpression expr) -
Uses of ValueVector in org.apache.drill.exec.physical.impl
Methods in org.apache.drill.exec.physical.impl with type parameters of type ValueVectorModifier and TypeMethodDescription<T extends ValueVector>
TOutputMutator.addField(MaterializedField field, Class<T> clazz) Add a ValueVector for new (or existing) field.<T extends ValueVector>
TScanBatch.Mutator.addField(MaterializedField field, Class<T> clazz) Methods in org.apache.drill.exec.physical.impl that return types with arguments of type ValueVectorModifier and TypeMethodDescriptionScanBatch.Mutator.fieldVectorMap()ScanBatch.Mutator.implicitFieldVectorMap() -
Uses of ValueVector in org.apache.drill.exec.physical.impl.join
Methods in org.apache.drill.exec.physical.impl.join that return types with arguments of type ValueVectorModifier and TypeMethodDescriptionorg.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.org.apache.commons.lang3.tuple.Pair<ValueVector, Integer> RowKeyJoin.nextRowKeyBatch()Get the next batch of row keysorg.apache.commons.lang3.tuple.Pair<ValueVector, Integer> RowKeyJoinBatch.nextRowKeyBatch() -
Uses of ValueVector in org.apache.drill.exec.physical.impl.project
Fields in org.apache.drill.exec.physical.impl.project with type parameters of type ValueVectorModifier and TypeFieldDescriptionprotected List<ValueVector> ProjectRecordBatch.allocationVectorsMethods in org.apache.drill.exec.physical.impl.project with parameters of type ValueVectorModifier and TypeMethodDescriptionvoidProjectMemoryManager.addComplexField(ValueVector vv) voidProjectMemoryManager.addNewField(ValueVector vvOut, LogicalExpression logicalExpression) voidProjectBatchBuilder.addTransferField(String name, ValueVector vvIn) voidProjectMemoryManager.addTransferField(ValueVector vvIn, String inputColumnName, String outputColumnName) static intProjectMemoryManager.getMetadataWidth(ValueVector vv) -
Uses of ValueVector in org.apache.drill.exec.physical.impl.scan.file
Methods in org.apache.drill.exec.physical.impl.scan.file that return ValueVector -
Uses of ValueVector in org.apache.drill.exec.physical.impl.scan.project
Methods in org.apache.drill.exec.physical.impl.scan.project that return ValueVectorModifier and TypeMethodDescriptionabstract ValueVectorResolvedTuple.ResolvedDict.buildVector()ResolvedTuple.ResolvedSingleDict.buildVector()NullColumnBuilder.vector(int index) ReaderSchemaOrchestrator.vector(int index) ResolvedTuple.ResolvedDictArray.vector(int index) ResolvedTuple.ResolvedMap.vector(int index) ResolvedTuple.ResolvedRow.vector(int index) ResolvedTuple.ResolvedSingleDict.vector(int index) VectorSource.vector(int index) Methods in org.apache.drill.exec.physical.impl.scan.project with parameters of type ValueVectorModifier and TypeMethodDescriptionabstract voidResolvedTuple.addVector(ValueVector vector) voidResolvedTuple.ResolvedDictArray.addVector(ValueVector vector) voidResolvedTuple.ResolvedMap.addVector(ValueVector vector) voidResolvedTuple.ResolvedRow.addVector(ValueVector vector) voidResolvedTuple.ResolvedSingleDict.addVector(ValueVector vector) -
Uses of ValueVector in org.apache.drill.exec.physical.impl.scan.v3.lifecycle
Methods in org.apache.drill.exec.physical.impl.scan.v3.lifecycle that return ValueVectorModifier and TypeMethodDescriptionOutputBatchBuilder.getVector(org.apache.drill.exec.physical.impl.scan.v3.lifecycle.OutputBatchBuilder.VectorSource source) -
Uses of ValueVector in org.apache.drill.exec.physical.impl.sort
Methods in org.apache.drill.exec.physical.impl.sort that return types with arguments of type ValueVector -
Uses of ValueVector in org.apache.drill.exec.physical.impl.svremover
Fields in org.apache.drill.exec.physical.impl.svremover declared as ValueVectorModifier and TypeFieldDescriptionprotected ValueVector[]AbstractSV2Copier.vvInprotected ValueVector[]AbstractCopier.vvOut -
Uses of ValueVector in org.apache.drill.exec.physical.impl.validate
Methods in org.apache.drill.exec.physical.impl.validate with parameters of type ValueVectorModifier and TypeMethodDescriptionvoidBatchValidator.BaseErrorReporter.error(String name, ValueVector vector, String msg) voidBatchValidator.ErrorReporter.error(String name, ValueVector vector, String msg) voidBatchValidator.BaseErrorReporter.warn(String name, ValueVector vector, String msg) voidBatchValidator.ErrorReporter.warn(String name, ValueVector vector, String msg) -
Uses of ValueVector in org.apache.drill.exec.physical.resultSet
Methods in org.apache.drill.exec.physical.resultSet that return ValueVector -
Uses of ValueVector in org.apache.drill.exec.physical.resultSet.impl
Classes in org.apache.drill.exec.physical.resultSet.impl with type parameters of type ValueVectorFields in org.apache.drill.exec.physical.resultSet.impl declared as ValueVectorModifier and TypeFieldDescriptionprotected ValueVectorSingleVectorState.backupVectorprotected final ValueVectorSingleVectorState.mainVectorprotected final TTupleState.DictVectorState.vectorMethods in org.apache.drill.exec.physical.resultSet.impl with type parameters of type ValueVectorModifier and TypeMethodDescription<T extends ValueVector>
TColumnState.vector()<T extends ValueVector>
TNullableVectorState.vector()<T extends ValueVector>
TNullVectorState.UnmanagedVectorState.vector()<T extends ValueVector>
TNullVectorState.vector()<T extends ValueVector>
TRepeatedVectorState.vector()<T extends ValueVector>
TSingleVectorState.vector()<T extends ValueVector>
TVectorState.vector()Underlying vector: the one presented to the consumer of the result set loader.Methods in org.apache.drill.exec.physical.resultSet.impl that return ValueVectorModifier and TypeMethodDescriptionNullResultVectorCacheImpl.vectorFor(MaterializedField colSchema) ResultVectorCacheImpl.vectorFor(MaterializedField colSchema) Methods in org.apache.drill.exec.physical.resultSet.impl with parameters of type ValueVectorModifier and TypeMethodDescriptionabstract intTupleState.addOutputColumn(ValueVector vector, ColumnMetadata colSchema) intTupleState.DictArrayState.addOutputColumn(ValueVector vector, ColumnMetadata colSchema) intTupleState.MapState.addOutputColumn(ValueVector vector, ColumnMetadata colSchema) intTupleState.RowState.addOutputColumn(ValueVector vector, ColumnMetadata colSchema) protected abstract intSingleVectorState.allocateVector(ValueVector vector, int cardinality) intSingleVectorState.FixedWidthVectorState.allocateVector(ValueVector vector, int cardinality) intSingleVectorState.IsSetVectorState.allocateVector(ValueVector vector, int cardinality) intSingleVectorState.OffsetVectorState.allocateVector(ValueVector toAlloc, int cardinality) intSingleVectorState.VariableWidthVectorState.allocateVector(ValueVector vector, int cardinality) protected static TypeProtos.MajorTypeSingleVectorState.parseVectorType(ValueVector vector) The vector mechanism here relies on the vector metadata.SingleVectorState.vectorState(ColumnMetadata schema, WriterEvents writer, ValueVector mainVector) Constructors in org.apache.drill.exec.physical.resultSet.impl with parameters of type ValueVectorModifierConstructorDescriptionFixedWidthVectorState(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) -
Uses of ValueVector in org.apache.drill.exec.physical.resultSet.model
Methods in org.apache.drill.exec.physical.resultSet.model with parameters of type ValueVectorModifier and TypeMethodDescriptionprotected RContainerVisitor.apply(ValueVector vector, A arg) protected RContainerVisitor.visitPrimitive(ValueVector vector, A arg) protected RContainerVisitor.visitVector(ValueVector vector, A arg) -
Uses of ValueVector in org.apache.drill.exec.physical.resultSet.model.hyper
Methods in org.apache.drill.exec.physical.resultSet.model.hyper with type parameters of type ValueVectorModifier and TypeMethodDescription<T extends ValueVector>
THyperReaderBuilder.HyperVectorAccessor.vector() -
Uses of ValueVector in org.apache.drill.exec.physical.resultSet.model.single
Methods in org.apache.drill.exec.physical.resultSet.model.single with parameters of type ValueVectorModifier and TypeMethodDescriptionprotected AbstractObjectReaderSimpleReaderBuilder.buildVectorReader(ValueVector vector, MetadataProvider.VectorDescrip descrip) -
Uses of ValueVector in org.apache.drill.exec.planner
Methods in org.apache.drill.exec.planner with parameters of type ValueVectorModifier and TypeMethodDescriptionvoidFileSystemPartitionDescriptor.populatePartitionVectors(ValueVector[] vectors, List<PartitionLocation> partitions, BitSet partitionColumnBitSet, Map<Integer, String> fieldNameMap) voidParquetPartitionDescriptor.populatePartitionVectors(ValueVector[] vectors, List<PartitionLocation> partitions, BitSet partitionColumnBitSet, Map<Integer, String> fieldNameMap) voidPartitionDescriptor.populatePartitionVectors(ValueVector[] vectors, List<PartitionLocation> partitions, BitSet partitionColumnBitSet, Map<Integer, String> fieldNameMap) Creates an in memory representation of all the partitions. -
Uses of ValueVector in org.apache.drill.exec.planner.sql
Methods in org.apache.drill.exec.planner.sql with parameters of type ValueVectorModifier and TypeMethodDescriptionvoidHivePartitionDescriptor.populatePartitionVectors(ValueVector[] vectors, List<PartitionLocation> partitions, BitSet partitionColumnBitSet, Map<Integer, String> fieldNameMap) -
Uses of ValueVector in org.apache.drill.exec.record
Classes in org.apache.drill.exec.record with type parameters of type ValueVectorModifier and TypeClassDescriptionclassHyperVectorWrapper<T extends ValueVector>classSimpleVectorWrapper<T extends ValueVector>interfaceVectorWrapper<T extends ValueVector>Classes in org.apache.drill.exec.record that implement ValueVectorMethods in org.apache.drill.exec.record with type parameters of type ValueVectorModifier and TypeMethodDescription<T extends ValueVector>
TVectorAccessibleComplexWriter.addOrGet(String name, TypeProtos.MajorType type, Class<T> clazz) <T extends ValueVector>
TVectorContainer.addOrGet(String name, TypeProtos.MajorType type, Class<T> clazz) <T extends ValueVector>
TVectorContainer.addOrGet(MaterializedField field) <T extends ValueVector>
TVectorContainer.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.static <T extends ValueVector>
HyperVectorWrapper<T> HyperVectorWrapper.create(MaterializedField f, T[] v, boolean releasable) static <T extends ValueVector>
SimpleVectorWrapper<T> SimpleVectorWrapper.create(T v) Methods in org.apache.drill.exec.record that return ValueVectorModifier and TypeMethodDescriptionVectorContainer.getLast()TransferPair.getTo()T[]HyperVectorWrapper.getValueVectors()T[]SimpleVectorWrapper.getValueVectors()T[]VectorWrapper.getValueVectors()Methods in org.apache.drill.exec.record that return types with arguments of type ValueVectorModifier and TypeMethodDescriptionClass<? extends ValueVector> TypedFieldId.getIntermediateClass()Return the class for the value vector (type, mode).Methods in org.apache.drill.exec.record with parameters of type ValueVectorModifier and TypeMethodDescriptionVectorContainer.add(ValueVector vv) voidVectorContainer.add(ValueVector[] hyperVector) voidVectorContainer.add(ValueVector[] hyperVector, boolean releasable) voidHyperVectorWrapper.addVector(ValueVector v) voidHyperVectorWrapper.addVectors(ValueVector[] vv) voidRecordBatchSizer.ColumnSize.allocateVector(ValueVector vector, int recordCount) voidVectorInitializer.allocateVector(ValueVector vector, int recordCount, VectorInitializer.AllocationHint hint) voidVectorInitializer.allocateVector(ValueVector vector, String prefix, int recordCount) static <T extends ValueVector>
HyperVectorWrapper<T> HyperVectorWrapper.create(MaterializedField f, T[] v, boolean releasable) voidVectorContainer.remove(ValueVector v) voidHyperVectorWrapper.updateVectorList(ValueVector[] vv) Method to replace existing list of vectors with the newly provided ValueVectors list in this HyperVectorWrapperMethod parameters in org.apache.drill.exec.record with type arguments of type ValueVectorModifier and TypeMethodDescriptionvoidVectorContainer.addCollection(Iterable<ValueVector> vectors) voidVectorContainer.addHyperList(List<ValueVector> vectors) voidVectorContainer.addHyperList(List<ValueVector> vectors, boolean releasable) voidRecordBatchMemoryManager.allocateVectors(List<ValueVector> valueVectors) voidRecordBatchMemoryManager.allocateVectors(List<ValueVector> valueVectors, int recordCount) voidVectorInitializer.allocateVectors(List<ValueVector> valueVectors, int recordCount) static voidVectorAccessibleUtilities.clear(Iterable<ValueVector> iter) static WritableBatchWritableBatch.getBatchNoHV(int recordCount, Iterable<ValueVector> vectors, boolean isSV2) Constructors in org.apache.drill.exec.record with parameters of type ValueVectorModifierConstructorDescriptionColumnSize(ValueVector v, String prefix) HyperVectorWrapper(MaterializedField f, T[] v) HyperVectorWrapper(MaterializedField f, T[] v, boolean releasable) -
Uses of ValueVector in org.apache.drill.exec.store
Method parameters in org.apache.drill.exec.store with type arguments of type ValueVectorModifier and TypeMethodDescriptionvoidAbstractRecordReader.allocate(Map<String, ValueVector> vectorMap) voidRecordReader.allocate(Map<String, ValueVector> vectorMap) -
Uses of ValueVector in org.apache.drill.exec.store.hive
Methods in org.apache.drill.exec.store.hive with parameters of type ValueVectorModifier and TypeMethodDescriptionstatic voidHiveUtilities.populateVector(ValueVector vector, DrillBuf managedBuffer, Object val, int start, int end) Populates vector with given value based on its type. -
Uses of ValueVector in org.apache.drill.exec.store.mock
Method parameters in org.apache.drill.exec.store.mock with type arguments of type ValueVectorModifier and TypeMethodDescriptionvoidMockRecordReader.allocate(Map<String, ValueVector> vectorMap) -
Uses of ValueVector in org.apache.drill.exec.store.parquet.columnreaders
Classes in org.apache.drill.exec.store.parquet.columnreaders with type parameters of type ValueVectorModifier and TypeClassDescriptionclassColumnReader<V extends ValueVector>classNullableVarLengthValuesColumn<V extends ValueVector>final classVarLenColumnBulkInput<V extends ValueVector>Implements theVarLenBulkInputinterface to optimize data copyclassVarLengthColumn<V extends ValueVector>classVarLengthValuesColumn<V extends ValueVector>Methods in org.apache.drill.exec.store.parquet.columnreaders with parameters of type ValueVectorModifier and TypeMethodDescriptionstatic 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) Method parameters in org.apache.drill.exec.store.parquet.columnreaders with type arguments of type ValueVectorModifier and TypeMethodDescriptionvoidParquetRecordReader.allocate(Map<String, ValueVector> vectorMap) Constructor parameters in org.apache.drill.exec.store.parquet.columnreaders with type arguments of type ValueVectorModifierConstructorDescriptionVarLenBinaryReader(ParquetRecordReader parentReader, List<VarLengthColumn<? extends ValueVector>> columns) -
Uses of ValueVector in org.apache.drill.exec.store.parquet.columnreaders.batchsizing
Fields in org.apache.drill.exec.store.parquet.columnreaders.batchsizing declared as ValueVectorModifier and TypeFieldDescriptionBatchSizingMemoryUtil.ColumnMemoryUsageInfo.vectorValue vector which contains the column batch datafinal ValueVectorRecordBatchSizerManager.VarLenColumnBatchStats.vectorValue vector associated with a VL columnMethods in org.apache.drill.exec.store.parquet.columnreaders.batchsizing with parameters of type ValueVectorModifier and TypeMethodDescriptionvoidRecordBatchOverflow.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 voidBatchSizingMemoryUtil.getMemoryUsage(ValueVector sourceVector, int currValueCount, BatchSizingMemoryUtil.VectorMemoryUsageInfo vectorMemoryUsage) Load memory usage information for a variable length value vectorMethod parameters in org.apache.drill.exec.store.parquet.columnreaders.batchsizing with type arguments of type ValueVectorModifier and TypeMethodDescriptionvoidRecordBatchSizerManager.allocate(Map<String, ValueVector> vectorMap) Allocates value vectors for the current batch.Constructors in org.apache.drill.exec.store.parquet.columnreaders.batchsizing with parameters of type ValueVectorModifierConstructorDescriptionVarLenColumnBatchStats(ValueVector vector, int numValuesRead) Constructor. -
Uses of ValueVector in org.apache.drill.exec.store.parquet2
Method parameters in org.apache.drill.exec.store.parquet2 with type arguments of type ValueVectorModifier and TypeMethodDescriptionvoidDrillParquetReader.allocate(Map<String, ValueVector> vectorMap) -
Uses of ValueVector in org.apache.drill.exec.store.pojo
Classes in org.apache.drill.exec.store.pojo with type parameters of type ValueVectorModifier and TypeClassDescriptionclassAbstractPojoWriter<V extends ValueVector>Parent class for all pojo writers created for each field.Fields in org.apache.drill.exec.store.pojo declared as ValueVectorMethod parameters in org.apache.drill.exec.store.pojo with type arguments of type ValueVectorModifier and TypeMethodDescriptionvoidAbstractPojoRecordReader.allocate(Map<String, ValueVector> vectorMap) -
Uses of ValueVector in org.apache.drill.exec.util
Method parameters in org.apache.drill.exec.util with type arguments of type ValueVectorModifier and TypeMethodDescriptionstatic voidVectorUtil.allocateVectors(Iterable<ValueVector> valueVectors, int count) static voidVectorUtil.setValueCount(Iterable<ValueVector> valueVectors, int count) -
Uses of ValueVector in org.apache.drill.exec.vector
Classes in org.apache.drill.exec.vector with type parameters of type ValueVectorSubinterfaces of ValueVector in org.apache.drill.exec.vectorModifier and TypeInterfaceDescriptioninterfaceinterfaceinterfaceClasses in org.apache.drill.exec.vector that implement ValueVectorModifier and TypeClassDescriptionclassclassfinal classBigInt implements a vector of fixed width values.final classBit implements a vector of bit-width values.final classDate implements a vector of fixed width values.final classDecimal18 implements a vector of fixed width values.final classDecimal28Dense implements a vector of fixed width values.final classDecimal28Sparse implements a vector of fixed width values.final classDecimal38Dense implements a vector of fixed width values.final classDecimal38Sparse implements a vector of fixed width values.final classDecimal9 implements a vector of fixed width values.final classFloat4 implements a vector of fixed width values.final classFloat8 implements a vector of fixed width values.final classIntervalDay implements a vector of fixed width values.final classInterval implements a vector of fixed width values.final classIntervalYear implements a vector of fixed width values.final classInt implements a vector of fixed width values.final classNullableBigInt implements a vector of values which could be null.final classNullableBit implements a vector of values which could be null.final classNullableDate implements a vector of values which could be null.final classNullableDecimal18 implements a vector of values which could be null.final classNullableDecimal28Dense implements a vector of values which could be null.final classNullableDecimal28Sparse implements a vector of values which could be null.final classNullableDecimal38Dense implements a vector of values which could be null.final classNullableDecimal38Sparse implements a vector of values which could be null.final classNullableDecimal9 implements a vector of values which could be null.final classNullableFloat4 implements a vector of values which could be null.final classNullableFloat8 implements a vector of values which could be null.final classNullableIntervalDay implements a vector of values which could be null.final classNullableInterval implements a vector of values which could be null.final classNullableIntervalYear implements a vector of values which could be null.final classNullableInt implements a vector of values which could be null.final classNullableSmallInt implements a vector of values which could be null.final classNullableTimeStamp implements a vector of values which could be null.final classNullableTime implements a vector of values which could be null.final classNullableTinyInt implements a vector of values which could be null.final classNullableUInt1 implements a vector of values which could be null.final classNullableUInt2 implements a vector of values which could be null.final classNullableUInt4 implements a vector of values which could be null.final classNullableUInt8 implements a vector of values which could be null.final classNullableVar16Char implements a vector of values which could be null.final classNullableVarBinary implements a vector of values which could be null.final classNullableVarChar implements a vector of values which could be null.final classNullableVarDecimal implements a vector of values which could be null.classfinal classRepeatedBigInt implements a vector with multiple values per row (e.g.final classRepeatedBit implements a vector with multiple values per row (e.g.final classRepeatedDate implements a vector with multiple values per row (e.g.final classRepeatedDecimal18 implements a vector with multiple values per row (e.g.final classRepeatedDecimal28Dense implements a vector with multiple values per row (e.g.final classRepeatedDecimal28Sparse implements a vector with multiple values per row (e.g.final classRepeatedDecimal38Dense implements a vector with multiple values per row (e.g.final classRepeatedDecimal38Sparse implements a vector with multiple values per row (e.g.final classRepeatedDecimal9 implements a vector with multiple values per row (e.g.final classRepeatedFloat4 implements a vector with multiple values per row (e.g.final classRepeatedFloat8 implements a vector with multiple values per row (e.g.final classRepeatedIntervalDay implements a vector with multiple values per row (e.g.final classRepeatedInterval implements a vector with multiple values per row (e.g.final classRepeatedIntervalYear implements a vector with multiple values per row (e.g.final classRepeatedInt implements a vector with multiple values per row (e.g.final classRepeatedSmallInt implements a vector with multiple values per row (e.g.final classRepeatedTimeStamp implements a vector with multiple values per row (e.g.final classRepeatedTime implements a vector with multiple values per row (e.g.final classRepeatedTinyInt implements a vector with multiple values per row (e.g.final classRepeatedUInt1 implements a vector with multiple values per row (e.g.final classRepeatedUInt2 implements a vector with multiple values per row (e.g.final classRepeatedUInt4 implements a vector with multiple values per row (e.g.final classRepeatedUInt8 implements a vector with multiple values per row (e.g.final classRepeatedVar16Char implements a vector with multiple values per row (e.g.final classRepeatedVarBinary implements a vector with multiple values per row (e.g.final classRepeatedVarChar implements a vector with multiple values per row (e.g.final classRepeatedVarDecimal implements a vector with multiple values per row (e.g.final classSmallInt implements a vector of fixed width values.final classTimeStamp implements a vector of fixed width values.final classTime implements a vector of fixed width values.final classTinyInt implements a vector of fixed width values.final classUInt1 implements a vector of fixed width values.final classUInt2 implements a vector of fixed width values.final classUInt4 implements a vector of fixed width values.final classUInt8 implements a vector of fixed width values.final classUntypedNullVector is to represent a value vector withTypeProtos.MinorType.NULLAll values in the vector represent two semantic implications: 1) the value is unknown, 2) the type is unknown.final classVar16CharVector implements a vector of variable width values.final classVarBinaryVector implements a vector of variable width values.final classVarCharVector implements a vector of variable width values.final classVarDecimalVector implements a vector of variable width values.classMethods in org.apache.drill.exec.vector that return ValueVectorModifier and TypeMethodDescriptionNullableVector.getBitsVector()NullableVector.getValuesVector()Methods in org.apache.drill.exec.vector that return types with arguments of type ValueVectorModifier and TypeMethodDescriptionBaseValueVector.iterator()ObjectVector.iterator()ZeroVector.iterator()Methods in org.apache.drill.exec.vector with parameters of type ValueVectorModifier and TypeMethodDescriptionstatic voidAllocationHelper.allocate(ValueVector vector, int valueCount, int bytesPerValue) static voidAllocationHelper.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 voidAllocationHelper.allocate(ValueVector vector, int valueCount, int bytesPerValue, int repeatedPerTop) static voidAllocationHelper.allocateNew(ValueVector vector, int valueCount) Allocates the exact amount if v is fixed width, otherwise falls back to dynamic allocationstatic voidAllocationHelper.allocatePrecomputedChildCount(ValueVector vector, int valueCount, int bytesPerValue, int childValCount) static booleanBaseValueVector.checkBufRefs(ValueVector vv) voidBigIntVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidBitVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidDateVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidDecimal18Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidDecimal28DenseVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidDecimal28SparseVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidDecimal38DenseVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidDecimal38SparseVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidDecimal9Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidFloat4Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidFloat8Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidIntervalDayVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidIntervalVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidIntervalYearVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidIntVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableBigIntVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableBitVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableDateVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableDecimal18Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableDecimal28DenseVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableDecimal28SparseVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableDecimal38DenseVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableDecimal38SparseVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableDecimal9Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableFloat4Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableFloat8Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableIntervalDayVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableIntervalVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableIntervalYearVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableIntVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableSmallIntVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableTimeStampVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableTimeVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableTinyIntVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableUInt1Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableUInt2Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableUInt4Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableUInt8Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableVar16CharVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableVarBinaryVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableVarCharVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidNullableVarDecimalVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidObjectVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedBigIntVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedBitVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedDateVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedDecimal18Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedDecimal28DenseVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedDecimal28SparseVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedDecimal38DenseVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedDecimal38SparseVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedDecimal9Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedFloat4Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedFloat8Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedIntervalDayVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedIntervalVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedIntervalYearVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedIntVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedSmallIntVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedTimeStampVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedTimeVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedTinyIntVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedUInt1Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedUInt2Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedUInt4Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedUInt8Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedVar16CharVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedVarBinaryVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedVarCharVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedVarDecimalVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidSmallIntVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidTimeStampVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidTimeVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidTinyIntVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidUInt1Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidUInt2Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidUInt4Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidUInt8Vector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidUntypedNullVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidValueVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidVar16CharVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidVarBinaryVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidVarCharVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidVarDecimalVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidZeroVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidBaseDataValueVector.exchange(ValueVector other) voidBitVector.exchange(ValueVector other) voidNullableBigIntVector.exchange(ValueVector other) voidNullableBitVector.exchange(ValueVector other) voidNullableDateVector.exchange(ValueVector other) voidNullableDecimal18Vector.exchange(ValueVector other) voidNullableDecimal28DenseVector.exchange(ValueVector other) voidNullableDecimal28SparseVector.exchange(ValueVector other) voidNullableDecimal38DenseVector.exchange(ValueVector other) voidNullableDecimal38SparseVector.exchange(ValueVector other) voidNullableDecimal9Vector.exchange(ValueVector other) voidNullableFloat4Vector.exchange(ValueVector other) voidNullableFloat8Vector.exchange(ValueVector other) voidNullableIntervalDayVector.exchange(ValueVector other) voidNullableIntervalVector.exchange(ValueVector other) voidNullableIntervalYearVector.exchange(ValueVector other) voidNullableIntVector.exchange(ValueVector other) voidNullableSmallIntVector.exchange(ValueVector other) voidNullableTimeStampVector.exchange(ValueVector other) voidNullableTimeVector.exchange(ValueVector other) voidNullableTinyIntVector.exchange(ValueVector other) voidNullableUInt1Vector.exchange(ValueVector other) voidNullableUInt2Vector.exchange(ValueVector other) voidNullableUInt4Vector.exchange(ValueVector other) voidNullableUInt8Vector.exchange(ValueVector other) voidNullableVar16CharVector.exchange(ValueVector other) voidNullableVarBinaryVector.exchange(ValueVector other) voidNullableVarCharVector.exchange(ValueVector other) voidNullableVarDecimalVector.exchange(ValueVector other) voidObjectVector.exchange(ValueVector other) voidValueVector.exchange(ValueVector other) Exchange state with another value vector of the same type.voidVar16CharVector.exchange(ValueVector other) voidVarBinaryVector.exchange(ValueVector other) voidVarCharVector.exchange(ValueVector other) voidVarDecimalVector.exchange(ValueVector other) voidZeroVector.exchange(ValueVector other) BigIntVector.makeTransferPair(ValueVector to) BitVector.makeTransferPair(ValueVector to) DateVector.makeTransferPair(ValueVector to) Decimal18Vector.makeTransferPair(ValueVector to) Decimal28DenseVector.makeTransferPair(ValueVector to) Decimal28SparseVector.makeTransferPair(ValueVector to) Decimal38DenseVector.makeTransferPair(ValueVector to) Decimal38SparseVector.makeTransferPair(ValueVector to) Decimal9Vector.makeTransferPair(ValueVector to) Float4Vector.makeTransferPair(ValueVector to) Float8Vector.makeTransferPair(ValueVector to) IntervalDayVector.makeTransferPair(ValueVector to) IntervalVector.makeTransferPair(ValueVector to) IntervalYearVector.makeTransferPair(ValueVector to) IntVector.makeTransferPair(ValueVector to) NullableBigIntVector.makeTransferPair(ValueVector to) NullableBitVector.makeTransferPair(ValueVector to) NullableDateVector.makeTransferPair(ValueVector to) NullableDecimal18Vector.makeTransferPair(ValueVector to) NullableDecimal28DenseVector.makeTransferPair(ValueVector to) NullableDecimal28SparseVector.makeTransferPair(ValueVector to) NullableDecimal38DenseVector.makeTransferPair(ValueVector to) NullableDecimal38SparseVector.makeTransferPair(ValueVector to) NullableDecimal9Vector.makeTransferPair(ValueVector to) NullableFloat4Vector.makeTransferPair(ValueVector to) NullableFloat8Vector.makeTransferPair(ValueVector to) NullableIntervalDayVector.makeTransferPair(ValueVector to) NullableIntervalVector.makeTransferPair(ValueVector to) NullableIntervalYearVector.makeTransferPair(ValueVector to) NullableIntVector.makeTransferPair(ValueVector to) NullableSmallIntVector.makeTransferPair(ValueVector to) NullableTimeStampVector.makeTransferPair(ValueVector to) NullableTimeVector.makeTransferPair(ValueVector to) NullableTinyIntVector.makeTransferPair(ValueVector to) NullableUInt1Vector.makeTransferPair(ValueVector to) NullableUInt2Vector.makeTransferPair(ValueVector to) NullableUInt4Vector.makeTransferPair(ValueVector to) NullableUInt8Vector.makeTransferPair(ValueVector to) NullableVar16CharVector.makeTransferPair(ValueVector to) NullableVarBinaryVector.makeTransferPair(ValueVector to) NullableVarCharVector.makeTransferPair(ValueVector to) NullableVarDecimalVector.makeTransferPair(ValueVector to) ObjectVector.makeTransferPair(ValueVector to) RepeatedBigIntVector.makeTransferPair(ValueVector to) RepeatedBitVector.makeTransferPair(ValueVector to) RepeatedDateVector.makeTransferPair(ValueVector to) RepeatedDecimal18Vector.makeTransferPair(ValueVector to) RepeatedDecimal28DenseVector.makeTransferPair(ValueVector to) RepeatedDecimal28SparseVector.makeTransferPair(ValueVector to) RepeatedDecimal38DenseVector.makeTransferPair(ValueVector to) RepeatedDecimal38SparseVector.makeTransferPair(ValueVector to) RepeatedDecimal9Vector.makeTransferPair(ValueVector to) RepeatedFloat4Vector.makeTransferPair(ValueVector to) RepeatedFloat8Vector.makeTransferPair(ValueVector to) RepeatedIntervalDayVector.makeTransferPair(ValueVector to) RepeatedIntervalVector.makeTransferPair(ValueVector to) RepeatedIntervalYearVector.makeTransferPair(ValueVector to) RepeatedIntVector.makeTransferPair(ValueVector to) RepeatedSmallIntVector.makeTransferPair(ValueVector to) RepeatedTimeStampVector.makeTransferPair(ValueVector to) RepeatedTimeVector.makeTransferPair(ValueVector to) RepeatedTinyIntVector.makeTransferPair(ValueVector to) RepeatedUInt1Vector.makeTransferPair(ValueVector to) RepeatedUInt2Vector.makeTransferPair(ValueVector to) RepeatedUInt4Vector.makeTransferPair(ValueVector to) RepeatedUInt8Vector.makeTransferPair(ValueVector to) RepeatedVar16CharVector.makeTransferPair(ValueVector to) RepeatedVarBinaryVector.makeTransferPair(ValueVector to) RepeatedVarCharVector.makeTransferPair(ValueVector to) RepeatedVarDecimalVector.makeTransferPair(ValueVector to) SmallIntVector.makeTransferPair(ValueVector to) TimeStampVector.makeTransferPair(ValueVector to) TimeVector.makeTransferPair(ValueVector to) TinyIntVector.makeTransferPair(ValueVector to) UInt1Vector.makeTransferPair(ValueVector to) UInt2Vector.makeTransferPair(ValueVector to) UInt4Vector.makeTransferPair(ValueVector to) UInt8Vector.makeTransferPair(ValueVector to) UntypedNullVector.makeTransferPair(ValueVector to) ValueVector.makeTransferPair(ValueVector target) Returns a newtransfer pairthat is used to transfer underlying buffers into the target vector.Var16CharVector.makeTransferPair(ValueVector to) VarBinaryVector.makeTransferPair(ValueVector to) VarCharVector.makeTransferPair(ValueVector to) VarDecimalVector.makeTransferPair(ValueVector to) ZeroVector.makeTransferPair(ValueVector target) voidBaseValueVector.toNullable(ValueVector nullableVector) voidBigIntVector.toNullable(ValueVector nullableVector) voidBitVector.toNullable(ValueVector nullableVector) voidDateVector.toNullable(ValueVector nullableVector) voidDecimal18Vector.toNullable(ValueVector nullableVector) voidDecimal28DenseVector.toNullable(ValueVector nullableVector) voidDecimal28SparseVector.toNullable(ValueVector nullableVector) voidDecimal38DenseVector.toNullable(ValueVector nullableVector) voidDecimal38SparseVector.toNullable(ValueVector nullableVector) voidDecimal9Vector.toNullable(ValueVector nullableVector) voidFloat4Vector.toNullable(ValueVector nullableVector) voidFloat8Vector.toNullable(ValueVector nullableVector) voidIntervalDayVector.toNullable(ValueVector nullableVector) voidIntervalVector.toNullable(ValueVector nullableVector) voidIntervalYearVector.toNullable(ValueVector nullableVector) voidIntVector.toNullable(ValueVector nullableVector) voidNullableBigIntVector.toNullable(ValueVector nullableVector) voidNullableBitVector.toNullable(ValueVector nullableVector) voidNullableDateVector.toNullable(ValueVector nullableVector) voidNullableDecimal18Vector.toNullable(ValueVector nullableVector) voidNullableDecimal28DenseVector.toNullable(ValueVector nullableVector) voidNullableDecimal28SparseVector.toNullable(ValueVector nullableVector) voidNullableDecimal38DenseVector.toNullable(ValueVector nullableVector) voidNullableDecimal38SparseVector.toNullable(ValueVector nullableVector) voidNullableDecimal9Vector.toNullable(ValueVector nullableVector) voidNullableFloat4Vector.toNullable(ValueVector nullableVector) voidNullableFloat8Vector.toNullable(ValueVector nullableVector) voidNullableIntervalDayVector.toNullable(ValueVector nullableVector) voidNullableIntervalVector.toNullable(ValueVector nullableVector) voidNullableIntervalYearVector.toNullable(ValueVector nullableVector) voidNullableIntVector.toNullable(ValueVector nullableVector) voidNullableSmallIntVector.toNullable(ValueVector nullableVector) voidNullableTimeStampVector.toNullable(ValueVector nullableVector) voidNullableTimeVector.toNullable(ValueVector nullableVector) voidNullableTinyIntVector.toNullable(ValueVector nullableVector) voidNullableUInt1Vector.toNullable(ValueVector nullableVector) voidNullableUInt2Vector.toNullable(ValueVector nullableVector) voidNullableUInt4Vector.toNullable(ValueVector nullableVector) voidNullableUInt8Vector.toNullable(ValueVector nullableVector) voidObjectVector.toNullable(ValueVector nullableVector) voidSmallIntVector.toNullable(ValueVector nullableVector) voidTimeStampVector.toNullable(ValueVector nullableVector) voidTimeVector.toNullable(ValueVector nullableVector) voidTinyIntVector.toNullable(ValueVector nullableVector) voidUInt1Vector.toNullable(ValueVector nullableVector) voidUInt2Vector.toNullable(ValueVector nullableVector) voidUInt4Vector.toNullable(ValueVector nullableVector) voidUInt8Vector.toNullable(ValueVector nullableVector) voidValueVector.toNullable(ValueVector nullableVector) Convert a non-nullable vector to nullable by shuffling the data from one to the other.voidVar16CharVector.toNullable(ValueVector nullableVector) voidVarBinaryVector.toNullable(ValueVector nullableVector) voidVarCharVector.toNullable(ValueVector nullableVector) voidVarDecimalVector.toNullable(ValueVector nullableVector) voidZeroVector.toNullable(ValueVector nullableVector) -
Uses of ValueVector in org.apache.drill.exec.vector.accessor
Constructors in org.apache.drill.exec.vector.accessor with parameters of type ValueVectorModifierConstructorDescriptionBigIntColumnWriter(ValueVector vector) BoundCheckingAccessor(ValueVector vector, SqlAccessor inner) DateColumnWriter(ValueVector vector) Decimal18ColumnWriter(ValueVector vector) Decimal9ColumnWriter(ValueVector vector) Float4ColumnWriter(ValueVector vector) Float8ColumnWriter(ValueVector vector) IntColumnWriter(ValueVector vector) IntervalColumnWriter(ValueVector vector) IntervalDayColumnWriter(ValueVector vector) IntervalYearColumnWriter(ValueVector vector) SmallIntColumnWriter(ValueVector vector) TimeColumnWriter(ValueVector vector) TimeStampColumnWriter(ValueVector vector) TinyIntColumnWriter(ValueVector vector) UInt1ColumnWriter(ValueVector vector) UInt2ColumnWriter(ValueVector vector) UInt4ColumnWriter(ValueVector vector) UInt8ColumnWriter(ValueVector vector) Var16CharColumnWriter(ValueVector vector) VarBinaryColumnWriter(ValueVector vector) VarCharColumnWriter(ValueVector vector) VarDecimalColumnWriter(ValueVector vector) -
Uses of ValueVector in org.apache.drill.exec.vector.accessor.impl
Methods in org.apache.drill.exec.vector.accessor.impl with parameters of type ValueVectorModifier and TypeMethodDescriptionstatic voidVectorPrinter.header(ValueVector vector, int start, int length) -
Uses of ValueVector in org.apache.drill.exec.vector.accessor.reader
Methods in org.apache.drill.exec.vector.accessor.reader with type parameters of type ValueVectorModifier and TypeMethodDescription<T extends ValueVector>
TVectorAccessor.vector()<T extends ValueVector>
TVectorAccessors.ArrayDataHyperVectorAccessor.vector()<T extends ValueVector>
TVectorAccessors.ArrayOffsetHyperVectorAccessor.vector()<T extends ValueVector>
TVectorAccessors.ListBitsHyperVectorStateReader.vector()<T extends ValueVector>
TVectorAccessors.ListMemberHyperVectorAccessor.vector()<T extends ValueVector>
TVectorAccessors.MapMemberHyperVectorAccessor.vector()<T extends ValueVector>
TVectorAccessors.NullableBitsHyperVectorStateReader.vector()<T extends ValueVector>
TVectorAccessors.NullableValuesHyperVectorAccessor.vector()<T extends ValueVector>
TVectorAccessors.NullVectorAccesor.vector()<T extends ValueVector>
TVectorAccessors.SingleVectorAccessor.vector()<T extends ValueVector>
TVectorAccessors.UnionMemberHyperVectorAccessor.vector()<T extends ValueVector>
TVectorAccessors.UnionTypeHyperVectorAccessor.vector()<T extends ValueVector>
TVectorAccessors.VarWidthOffsetHyperVectorAccessor.vector()Constructors in org.apache.drill.exec.vector.accessor.reader with parameters of type ValueVector -
Uses of ValueVector in org.apache.drill.exec.vector.accessor.writer
Methods in org.apache.drill.exec.vector.accessor.writer with parameters of type ValueVectorModifier and TypeMethodDescriptionstatic AbstractObjectWriterColumnWriterFactory.buildColumnWriter(ColumnMetadata schema, ValueVector vector) static BaseScalarWriterColumnWriterFactory.newWriter(ValueVector vector) Constructors in org.apache.drill.exec.vector.accessor.writer with parameters of type ValueVector -
Uses of ValueVector in org.apache.drill.exec.vector.complex
Subinterfaces of ValueVector in org.apache.drill.exec.vector.complexModifier and TypeInterfaceDescriptioninterfaceRepresents repeated (AKA "array") value vectors.Classes in org.apache.drill.exec.vector.complex that implement ValueVectorModifier and TypeClassDescriptionclassBase class for composite vectors.classBase class for MapVectors.classclassfinal classAValueVectorholding key-value pairs.class"Non-repeated" LIST vector.classclassclassprotected static classclassclassFields in org.apache.drill.exec.vector.complex declared as ValueVectorModifier and TypeFieldDescriptionstatic final ValueVectorBaseRepeatedValueVector.DEFAULT_DATA_VECTORprotected ValueVectorBaseRepeatedValueVector.vectorfinal ValueVectorVectorWithOrdinal.vectorMethods in org.apache.drill.exec.vector.complex with type parameters of type ValueVectorModifier and TypeMethodDescriptionabstract <T extends ValueVector>
TAbstractContainerVector.addOrGet(String name, TypeProtos.MajorType type, Class<T> clazz) <T extends ValueVector>
TAbstractMapVector.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 resultantValueVector.<T extends ValueVector>
TRepeatedListVector.addOrGet(String name, TypeProtos.MajorType type, Class<T> clazz) Deprecated.<T extends ValueVector>
AddOrGetResult<T> AbstractRepeatedMapVector.addOrGetVector(VectorDescriptor descriptor) <T extends ValueVector>
AddOrGetResult<T> BaseRepeatedValueVector.addOrGetVector(VectorDescriptor descriptor) <T extends ValueVector>
AddOrGetResult<T> 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>
AddOrGetResult<T> ListVector.addOrGetVector(VectorDescriptor descriptor) <T extends ValueVector>
AddOrGetResult<T> RepeatedListVector.addOrGetVector(VectorDescriptor descriptor) abstract <T extends ValueVector>
T<T extends ValueVector>
TReturns aValueVectorinstance of subtype ofcorresponding to the given field name if exists or null. <T extends ValueVector>
T<T extends ValueVector>
T<T extends ValueVector>
TUnionVector.member(TypeProtos.MinorType type) <T extends ValueVector>
TUnionVector.subtype(TypeProtos.MinorType type) protected <T extends ValueVector>
TAbstractContainerVector.typeify(ValueVector v, Class<T> clazz) Methods in org.apache.drill.exec.vector.complex that return ValueVectorModifier and TypeMethodDescriptionUnionVector.addVector(ValueVector v) Add a vector that matches the argument.ListVector.getBitsVector()Returns aValueVectorcorresponding to the given field name if exists or null.Returns aValueVectorcorresponding to the given field name if exists or null.AbstractMapVector.getChildByOrdinal(int id) Returns aValueVectorcorresponding to the given ordinal identifier.AbstractRepeatedMapVector.getDataVector()BaseRepeatedValueVector.getDataVector()ListVector.getDataVector()RepeatedListVector.getDataVector()RepeatedValueVector.getDataVector()DictVector.getKeys()UnionVector.getMember(TypeProtos.MinorType type) Add or get a type member given the type.BaseRepeatedValueVector.BaseRepeatedValueVectorTransferPair.getTo()MapVector.MapTransferPair.getTo()RepeatedListVector.RepeatedListTransferPair.getTo()DictVector.getValues()MapVector.getVectorById(int id) UnionVector.setFirstType(ValueVector v, int newValueCount) Methods in org.apache.drill.exec.vector.complex that return types with arguments of type ValueVectorModifier and TypeMethodDescriptionprotected Collection<ValueVector> AbstractMapVector.getChildren()Returns a sequence of underlying child vectors.AbstractMapVector.getPrimitiveVectors()Returns a list of scalar child vectors recursing the entire vector hierarchy.AbstractRepeatedMapVector.getPrimitiveVectors()AbstractMapVector.iterator()BaseRepeatedValueVector.iterator()RepeatedListVector.iterator()UnionVector.iterator()Methods in org.apache.drill.exec.vector.complex with parameters of type ValueVectorModifier and TypeMethodDescriptionvoidUnionVector.addType(ValueVector vector) Add an externally-created subtype vector.UnionVector.addVector(ValueVector v) Add a vector that matches the argument.voidAbstractRepeatedMapVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidListVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidMapVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedDictVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedListVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidRepeatedListVector.DelegateRepeatedVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidUnionVector.copyEntry(int toIndex, ValueVector from, int fromIndex) voidAbstractMapVector.exchange(ValueVector other) voidAbstractRepeatedMapVector.exchange(ValueVector other) voidBaseRepeatedValueVector.exchange(ValueVector other) voidDictVector.exchange(ValueVector other) voidMapVector.exchange(ValueVector other) voidRepeatedListVector.exchange(ValueVector other) voidUnionVector.exchange(ValueVector other) static TypedFieldIdFieldIdUtil.getFieldId(ValueVector vector, int id, SchemaPath expectedPath, boolean hyper) static TypedFieldIdFieldIdUtil.getFieldIdIfMatches(ValueVector vector, TypedFieldId.Builder builder, boolean addToBreadCrumb, PathSegment seg) Utility method to obtainTypedFieldId, providing metadata for specified field given by value vector used in code generation.DictVector.makeTransferPair(ValueVector to) ListVector.makeTransferPair(ValueVector target) MapVector.makeTransferPair(ValueVector to) RepeatedDictVector.makeTransferPair(ValueVector target) RepeatedListVector.DelegateRepeatedVector.makeTransferPair(ValueVector target) RepeatedListVector.makeTransferPair(ValueVector to) RepeatedMapVector.makeTransferPair(ValueVector to) UnionVector.makeTransferPair(ValueVector target) voidAbstractMapVector.putChild(String name, ValueVector vector) Inserts the vector with the given name if it does not exist else replaces it with the new value.voidDictVector.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 voidAbstractMapVector.putVector(String name, ValueVector vector) Inserts the input vector into the map if it does not exist, replaces if it exists alreadyprotected voidBaseRepeatedValueVector.replaceDataVector(ValueVector v) voidBaseRepeatedValueVector.setChildVector(ValueVector childVector) voidListVector.setChildVector(ValueVector childVector) voidRepeatedListVector.setChildVector(ValueVector childVector) UnionVector.setFirstType(ValueVector v, int newValueCount) voidAbstractRepeatedMapVector.toNullable(ValueVector nullableVector) voidMapVector.toNullable(ValueVector nullableVector) voidRepeatedListVector.toNullable(ValueVector nullableVector) voidUnionVector.toNullable(ValueVector nullableVector) protected <T extends ValueVector>
TAbstractContainerVector.typeify(ValueVector v, Class<T> clazz) Constructors in org.apache.drill.exec.vector.complex with parameters of type ValueVectorModifierConstructorDescriptionprotectedBaseRepeatedValueVector(MaterializedField field, BufferAllocator allocator, ValueVector vector) VectorWithOrdinal(ValueVector v, int ordinal) -
Uses of ValueVector in org.apache.drill.exec.vector.complex.impl
Constructors in org.apache.drill.exec.vector.complex.impl with parameters of type ValueVectorModifierConstructorDescriptionPromotableWriter(ValueVector v, AbstractMapVector parentContainer) PromotableWriter(ValueVector v, ListVector listVector)
RepeatedListVector.addOrGetVector(org.apache.drill.exec.vector.VectorDescriptor)instead.