Uses of Class
org.apache.drill.exec.record.VectorContainer
Package
Description
Distributed cache for syncing state and data between Drillbits.
Defines a revised implementation of the Drill RecordBatch protocol.
Defines the scan operation implementation.
Defines the projection, vector continuity and other operations for
a set of one or more readers.
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.
Provides a set of tools to work with row sets.
Drill storage plugin.
-
Uses of VectorContainer in org.apache.drill.exec.cache
Modifier and TypeMethodDescriptionVectorAccessibleSerializable.get()
VectorSerializer.Reader.read()
Modifier and TypeMethodDescriptionvoid
VectorAccessibleSerializable.readFromStreamWithContainer
(VectorContainer myContainer, InputStream input) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl
ModifierConstructorDescriptionMutator
(OperatorContext oContext, BufferAllocator allocator, VectorContainer container) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.aggregate
Modifier and TypeMethodDescriptionSpilledRecordBatch.getContainer()
HashAggBatch.getOutgoingContainer()
SpilledRecordBatch.getOutgoingContainer()
StreamingAggBatch.getOutgoingContainer()
Modifier and TypeMethodDescriptionvoid
HashAggregator.setup
(HashAggregate hashAggrConfig, HashTableConfig htConfig, FragmentContext context, OperatorContext oContext, RecordBatch incoming, HashAggBatch outgoing, LogicalExpression[] valueExprs, List<TypedFieldId> valueFieldIds, ClassGenerator<?> cg, TypedFieldId[] keyFieldIds, VectorContainer outContainer, int extraRowBytes) void
HashAggTemplate.setup
(HashAggregate hashAggrConfig, HashTableConfig htConfig, FragmentContext context, OperatorContext oContext, RecordBatch incoming, HashAggBatch outgoing, LogicalExpression[] valueExprs, List<TypedFieldId> valueFieldIds, ClassGenerator<?> cg, TypedFieldId[] groupByOutFieldIds, VectorContainer outContainer, int extraRowBytes) void
HashAggTemplate.BatchHolder.setupInterior
(RecordBatch incoming, RecordBatch outgoing, VectorContainer aggrValuesContainer) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.common
Modifier and TypeMethodDescriptionHashPartition.getContainers()
org.apache.commons.lang3.tuple.Pair<VectorContainer,
Integer> HashPartition.nextBatch()
org.apache.commons.lang3.tuple.Pair<VectorContainer,
Integer> HashTable.nextBatch()
org.apache.commons.lang3.tuple.Pair<VectorContainer,
Integer> HashTableTemplate.nextBatch()
Modifier and TypeMethodDescriptionvoid
HashPartition.appendInnerRow
(VectorContainer buildContainer, int ind, int hashCode, HashJoinMemoryCalculator.BuildSidePartitioning calc) Spills if neededprotected abstract void
HashTableTemplate.doSetup
(VectorContainer incomingBuild, RecordBatch incomingProbe) boolean
HashTable.outputKeys
(int batchIdx, VectorContainer outContainer, int numRecords) Retrieves the key columns and transfers them to the output container.boolean
HashTableTemplate.outputKeys
(int batchIdx, VectorContainer outContainer, int numRecords) void
HashTable.setup
(HashTableConfig htConfig, BufferAllocator allocator, VectorContainer incomingBuild, RecordBatch incomingProbe, RecordBatch outgoing, VectorContainer htContainerOrig, FragmentContext context, ClassGenerator<?> cg) HashTable.setup(org.apache.drill.exec.physical.impl.common.HashTableConfig, org.apache.drill.exec.memory.BufferAllocator, org.apache.drill.exec.record.VectorContainer, org.apache.drill.exec.record.RecordBatch, org.apache.drill.exec.record.RecordBatch, org.apache.drill.exec.record.VectorContainer, org.apache.drill.exec.ops.FragmentContext, org.apache.drill.exec.expr.ClassGenerator<?>)
must be called before anything can be done to theHashTable
.void
HashTableTemplate.setup
(HashTableConfig htConfig, BufferAllocator allocator, VectorContainer incomingBuild, RecordBatch incomingProbe, RecordBatch outgoing, VectorContainer htContainerOrig, FragmentContext context, ClassGenerator<?> cg) protected void
HashTableTemplate.BatchHolder.setupInterior
(VectorContainer incomingBuild, RecordBatch incomingProbe, RecordBatch outgoing, VectorContainer htContainer) void
HashTable.updateIncoming
(VectorContainer newIncoming, RecordBatch newIncomingProbe) Changes the incoming probe and build side batches, and then updates all the value vector references in theHashTableTemplate.BatchHolder
s.void
HashTableTemplate.updateIncoming
(VectorContainer newIncoming, RecordBatch newIncomingProbe) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.flatten
-
Uses of VectorContainer in org.apache.drill.exec.physical.impl.join
Modifier and TypeMethodDescriptionabstract void
JoinTemplate.doSetup
(FragmentContext context, JoinStatus status, VectorContainer outgoing) void
NestedLoopJoin.doSetup
(FragmentContext context, VectorContainer rightContainer, RecordBatch leftBatch, RecordBatch outgoing) abstract void
NestedLoopJoinTemplate.doSetup
(FragmentContext context, VectorContainer rightContainer, RecordBatch leftBatch, RecordBatch outgoing) protected int
ProbeTemplate.outputRow
(ArrayList<VectorContainer> buildSrcContainers, int compositeBuildSrcIndex, VectorContainer probeSrcContainer, int probeSrcIndex) A special version of the VectorContainer's appendRow for the HashJoin; (following a probe) it copies the build and probe sides into the outgoing container.void
HashJoinProbeTemplate.setup
(RecordBatch probeBatch, HashJoinBatch outgoing, org.apache.calcite.rel.core.JoinRelType joinRelType, boolean semiJoin, RecordBatch.IterOutcome leftStartState, HashPartition[] partitions, int cycleNum, VectorContainer container, AbstractHashBinaryRecordBatch.SpilledPartition[] spilledInners, boolean buildSideIsEmpty, int numPartitions, int rightHVColPosition) Setup the Hash Join Probe objectdefault void
Probe.setup
(RecordBatch probeBatch, HashJoinBatch outgoing, org.apache.calcite.rel.core.JoinRelType joinRelType, boolean semiJoin, RecordBatch.IterOutcome leftStartState, HashPartition[] partitions, int cycleNum, VectorContainer container, AbstractHashBinaryRecordBatch.SpilledPartition[] spilledInners, boolean buildSideIsEmpty, int numPartitions, int rightHVColPosition) default void
Probe.setup
(RecordBatch probeBatch, HashSetOpRecordBatch outgoing, org.apache.calcite.sql.SqlKind opType, boolean isAll, RecordBatch.IterOutcome leftStartState, HashPartition[] partitions, int cycleNum, VectorContainer container, AbstractHashBinaryRecordBatch.SpilledPartition[] spilledInners, boolean buildSideIsEmpty, int numPartitions) protected void
ProbeTemplate.setup
(RecordBatch probeBatch, RecordBatch.IterOutcome leftStartState, HashPartition[] partitions, int cycleNum, VectorContainer container, AbstractHashBinaryRecordBatch.SpilledPartition[] spilledInners, boolean buildSideIsEmpty, int numPartitions) void
JoinTemplate.setupJoin
(FragmentContext context, JoinStatus status, VectorContainer outgoing) void
JoinWorker.setupJoin
(FragmentContext context, JoinStatus status, VectorContainer outgoing) Modifier and TypeMethodDescriptionprotected int
ProbeTemplate.outputRow
(ArrayList<VectorContainer> buildSrcContainers, int compositeBuildSrcIndex, VectorContainer probeSrcContainer, int probeSrcIndex) A special version of the VectorContainer's appendRow for the HashJoin; (following a probe) it copies the build and probe sides into the outgoing container. -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.materialize
-
Uses of VectorContainer in org.apache.drill.exec.physical.impl.orderedpartitioner
Modifier and TypeMethodDescriptionabstract void
OrderedPartitionProjectorTemplate.doSetup
(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, VectorContainer partitionVectors) abstract void
SampleSortTemplate.doSetup
(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) void
OrderedPartitionProjector.setup
(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, List<TransferPair> transfers, VectorContainer partitionVectors, int partitions, SchemaPath outputField) final void
OrderedPartitionProjectorTemplate.setup
(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, List<TransferPair> transfers, VectorContainer partitionVectors, int partitions, SchemaPath outputField) void
SampleSortTemplate.setup
(FragmentContext context, VectorContainer sampleBatch, SelectionVector2 vector2) void
SampleSorter.sort
(SelectionVector2 vector2, VectorContainer container) void
SampleSortTemplate.sort
(SelectionVector2 vector2, VectorContainer container) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.project
ModifierConstructorDescriptionProjectBatchBuilder
(ProjectRecordBatch projectBatch, VectorContainer container, SchemaChangeCallBack callBack, RecordBatch incomingBatch) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.protocol
Modifier and TypeMethodDescriptionBatchAccessor.container()
VectorContainerAccessor.container()
OperatorRecordBatch.getContainer()
OperatorRecordBatch.getOutgoingContainer()
Modifier and TypeMethodDescriptionvoid
VectorContainerAccessor.addBatch
(VectorContainer container) Define an output batch.void
VectorContainerAccessor.setSchema
(VectorContainer container) Define a schema that does not necessarily contain any data.void
SchemaTracker.trackSchema
(VectorContainer newBatch) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.scan
Modifier and TypeMethodDescriptionRowBatchReader.output()
Return the container with the reader's output. -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.scan.framework
-
Uses of VectorContainer in org.apache.drill.exec.physical.impl.scan.project
Modifier and TypeFieldDescriptionprotected VectorContainer
ScanSchemaOrchestrator.outputContainer
Modifier and TypeMethodDescriptionConstantColumnLoader.load
(int rowCount) NullColumnLoader.load
(int rowCount) abstract VectorContainer
StaticColumnLoader.load
(int rowCount) Populate static vectors with the defined static values.NullColumnBuilder.output()
NullColumnLoader.output()
ResolvedTuple.ResolvedRow.output()
ScanSchemaOrchestrator.output()
Modifier and TypeMethodDescriptionvoid
ResolvedTuple.ResolvedRow.project
(VectorContainer input, VectorContainer output) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.scan.v3.lifecycle
Modifier and TypeMethodDescriptionStaticBatchBuilder.load
(int rowCount) Populate static vectors with the defined static values.ReaderLifecycle.output()
OutputBatchBuilder.outputContainer()
StaticBatchBuilder.outputContainer()
-
Uses of VectorContainer in org.apache.drill.exec.physical.impl.setop
Modifier and TypeMethodDescriptionvoid
HashSetOpProbeTemplate.setup
(RecordBatch probeBatch, HashSetOpRecordBatch outgoing, org.apache.calcite.sql.SqlKind opType, boolean isAll, RecordBatch.IterOutcome leftStartState, HashPartition[] partitions, int cycleNum, VectorContainer container, AbstractHashBinaryRecordBatch.SpilledPartition[] spilledInners, boolean buildSideIsEmpty, int numPartitions) Setup the Hash Set Op Probe object -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.sort
Modifier and TypeMethodDescriptionvoid
SortRecordBatchBuilder.build
(VectorContainer outputContainer) abstract void
SortTemplate.doSetup
(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) void
Sorter.setup
(FragmentContext context, SelectionVector4 vector4, VectorContainer hyperBatch) void
SortTemplate.setup
(FragmentContext context, SelectionVector4 vector4, VectorContainer hyperBatch) void
Sorter.sort
(SelectionVector4 vector4, VectorContainer container) void
SortTemplate.sort
(SelectionVector4 vector4, VectorContainer container) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.statistics
-
Uses of VectorContainer in org.apache.drill.exec.physical.impl.svremover
Modifier and TypeMethodDescriptionstatic void
AbstractCopier.allocateOutgoing
(VectorContainer outgoing, int recordCount) static Copier
GenericCopierFactory.createAndSetupCopier
(RecordBatch incoming, VectorContainer outputContainer, SchemaChangeCallBack callBack) static Copier
GenericCopierFactory.createAndSetupNonSVGenericCopier
(RecordBatch incoming, VectorContainer outputContainer) void
AbstractCopier.setup
(VectorAccessible incoming, VectorContainer outgoing) void
AbstractSV2Copier.setup
(VectorAccessible incoming, VectorContainer outgoing) void
AbstractSV4Copier.setup
(VectorAccessible incoming, VectorContainer outgoing) void
Copier.setup
(VectorAccessible incoming, VectorContainer outgoing) void
GenericCopier.setup
(VectorAccessible incoming, VectorContainer outgoing) void
StraightCopier.setup
(VectorAccessible incoming, VectorContainer outgoing) ModifierConstructorDescriptionGenericSV2Copier
(RecordBatch incomingBatch, VectorContainer outputContainer, SchemaChangeCallBack callBack) GenericSV4Copier
(RecordBatch incomingBatch, VectorContainer outputContainer, SchemaChangeCallBack callBack) StraightCopier
(RecordBatch incomingBatch, VectorContainer outputContainer, SchemaChangeCallBack callBack) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.TopN
Modifier and TypeMethodDescriptionPriorityQueue.getHyperBatch()
Retrieves the final priority queue HyperBatch containing the results.PriorityQueueTemplate.getHyperBatch()
Modifier and TypeMethodDescriptionabstract void
PriorityQueueTemplate.doSetup
(VectorContainer incoming, RecordBatch outgoing) Stores the reference to the hyperBatch container which holds all the records across incoming batches in it.void
PriorityQueue.resetQueue
(VectorContainer container, SelectionVector4 vector4) Cleanup the old state of queue and recreate a new one with HyperContainer containing vectors in input container and the corresponding indexes (in SV4 format) from input SelectionVector4void
PriorityQueueTemplate.resetQueue
(VectorContainer container, SelectionVector4 v4) ModifierConstructorDescriptionSimpleSV4RecordBatch
(VectorContainer container, SelectionVector4 sv4, FragmentContext context) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.unnest
-
Uses of VectorContainer in org.apache.drill.exec.physical.impl.unorderedreceiver
Modifier and TypeMethodDescriptionUnorderedReceiverBatch.getContainer()
UnorderedReceiverBatch.getOutgoingContainer()
-
Uses of VectorContainer in org.apache.drill.exec.physical.impl.unpivot
-
Uses of VectorContainer in org.apache.drill.exec.physical.impl.validate
Modifier and TypeMethodDescriptionIteratorValidatorBatchIterator.getContainer()
IteratorValidatorBatchIterator.getOutgoingContainer()
-
Uses of VectorContainer in org.apache.drill.exec.physical.impl.window
Modifier and TypeMethodDescriptionvoid
FrameSupportTemplate.setup
(List<WindowDataBatch> batches, VectorContainer container, OperatorContext oContext, boolean requireFullPartition, WindowPOP popConfig) void
NoFrameSupportTemplate.setup
(List<WindowDataBatch> batches, VectorContainer container, OperatorContext oContext, boolean requireFullPartition, WindowPOP popConfig) void
WindowFramer.setup
(List<WindowDataBatch> batches, VectorContainer container, OperatorContext operatorContext, boolean requireFullPartition, WindowPOP popConfig) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.xsort
Modifier and TypeMethodDescriptionBatchGroup.getContainer()
MergeSortWrapper.getContainer()
PriorityQueueCopierWrapper.BatchMerger.getContainer()
SortImpl.EmptyResults.getContainer()
SortImpl.SingleBatchResults.getContainer()
SortImpl.SortResults.getContainer()
Container into which results are delivered.Modifier and TypeMethodDescriptionabstract void
MSortTemplate.doSetup
(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) SpilledRuns.finalMerge
(List<? extends BatchGroup> bufferedBatches, VectorContainer container, int mergeRowCount, VectorInitializer allocHelper) void
MSorter.setup
(FragmentContext context, BufferAllocator allocator, SelectionVector4 vector4, VectorContainer hyperBatch, int outputBatchSize, int desiredBatchSize) void
MSortTemplate.setup
(FragmentContext context, BufferAllocator allocator, SelectionVector4 vector4, VectorContainer hyperBatch, int outputBatchSize, int desiredBatchSize) void
SorterWrapper.sortBatch
(VectorContainer convertedBatch, SelectionVector2 sv2) void
SpilledRun.spillBatch
(VectorContainer newContainer) PriorityQueueCopierWrapper.startMerge
(BatchSchema schema, List<? extends BatchGroup> batchGroupList, VectorContainer outputContainer, int targetRecordCount, VectorInitializer allocHelper) Start a merge operation using the specified vector container.void
MergeSortWrapper.updateOutputContainer
(VectorContainer container, SelectionVector4 sv4, RecordBatch.IterOutcome outcome, BatchSchema schema) void
PriorityQueueCopierWrapper.BatchMerger.updateOutputContainer
(VectorContainer container, SelectionVector4 sv4, RecordBatch.IterOutcome outcome, BatchSchema schema) void
SortImpl.EmptyResults.updateOutputContainer
(VectorContainer container, SelectionVector4 sv4, RecordBatch.IterOutcome outcome, BatchSchema schema) void
SortImpl.SingleBatchResults.updateOutputContainer
(VectorContainer container, SelectionVector4 sv4, RecordBatch.IterOutcome outcome, BatchSchema schema) void
SortImpl.SortResults.updateOutputContainer
(VectorContainer container, SelectionVector4 sv4, RecordBatch.IterOutcome outcome, BatchSchema schema) ModifierConstructorDescriptionBatchGroup
(VectorContainer container, BufferAllocator allocator) EmptyResults
(VectorContainer dest) InputBatch
(VectorContainer container, SelectionVector2 sv2, BufferAllocator allocator, long dataSize) MergeSortWrapper
(OperatorContext opContext, VectorContainer destContainer) SingleBatchResults
(InputBatch batch, VectorContainer outputContainer) SortImpl
(OperatorContext opContext, SortConfig sortConfig, SpilledRuns spilledRuns, VectorContainer batch) -
Uses of VectorContainer in org.apache.drill.exec.physical.resultSet
Modifier and TypeMethodDescriptionResultSetCopier.harvest()
Obtain the output batch.ResultSetLoader.harvest()
Harvest the current row batch, and reset the mutator to the start of the next row batch (which may already contain an overflow row.ResultSetLoader.outputContainer()
Returns the output container which holds (or will hold) batches from this loader. -
Uses of VectorContainer in org.apache.drill.exec.physical.resultSet.impl
Modifier and TypeMethodDescriptionPushResultSetReaderImpl.BatchHolder.batch()
PushResultSetReaderImpl.UpstreamSource.batch()
ResultSetCopierImpl.harvest()
ResultSetLoaderImpl.harvest()
ResultSetLoaderImpl.outputContainer()
TupleState.RowState.outputContainer()
-
Uses of VectorContainer in org.apache.drill.exec.physical.resultSet.model
Modifier and TypeMethodDescriptionContainerVisitor.apply
(VectorContainer container, A arg) ContainerVisitor.visitChildren
(VectorContainer container, A arg) -
Uses of VectorContainer in org.apache.drill.exec.physical.resultSet.model.hyper
Modifier and TypeMethodDescriptionstatic RowSetReaderImpl
HyperReaderBuilder.build
(VectorContainer container, TupleMetadata schema, SelectionVector4 sv4) protected List<AbstractObjectReader>
HyperReaderBuilder.buildContainerChildren
(VectorContainer container) protected List<AbstractObjectReader>
HyperReaderBuilder.buildContainerChildren
(VectorContainer container, TupleMetadata schema) HyperSchemaInference.infer
(VectorContainer container) -
Uses of VectorContainer in org.apache.drill.exec.physical.resultSet.model.single
Modifier and TypeMethodDescriptionstatic RowSetReaderImpl
SimpleReaderBuilder.build
(VectorContainer container, ReaderIndex rowIndex) static RowSetReaderImpl
SimpleReaderBuilder.build
(VectorContainer container, TupleMetadata schema, ReaderIndex rowIndex) protected List<AbstractObjectWriter>
BaseWriterBuilder.buildContainerChildren
(VectorContainer container, MetadataProvider mdProvider) SimpleReaderBuilder.buildContainerChildren
(VectorContainer container, MetadataProvider mdProvider) SingleSchemaInference.infer
(VectorContainer container) ModifierConstructorDescriptionDirectRowIndex
(VectorContainer container) VectorAllocator
(VectorContainer container) -
Uses of VectorContainer in org.apache.drill.exec.physical.rowSet
Modifier and TypeMethodDescriptionvoid
HyperRowSetImpl.HyperRowSetBuilderImpl.addBatch
(VectorContainer container) void
RowSet.HyperRowSetBuilder.addBatch
(VectorContainer container) static DirectRowSet
DirectRowSet.fromContainer
(VectorContainer container) static RowSet.HyperRowSet
HyperRowSetImpl.fromContainer
(VectorContainer container, SelectionVector4 sv4) static IndirectRowSet
IndirectRowSet.fromContainer
(VectorContainer container) static IndirectRowSet
IndirectRowSet.fromSv2
(VectorContainer container, SelectionVector2 sv2) static void
RowSetFormatter.print
(VectorContainer container) static RowSet
RowSets.wrap
(VectorContainer container) ModifierConstructorDescriptionAbstractRowSet
(VectorContainer container, TupleMetadata schema) protected
AbstractSingleRowSet
(VectorContainer container, TupleMetadata schema) HyperRowSetImpl
(TupleMetadata schema, VectorContainer container, SelectionVector4 sv4) HyperRowSetImpl
(VectorContainer container, SelectionVector4 sv4) IndirectRowSet
(VectorContainer container) -
Uses of VectorContainer in org.apache.drill.exec.planner.logical.partition
Modifier and TypeMethodDescriptionprotected LogicalExpression
PruneScanRule.materializePruneExpr
(org.apache.calcite.rex.RexNode pruneCondition, PlannerSettings settings, org.apache.calcite.rel.RelNode scanRel, VectorContainer container) -
Uses of VectorContainer in org.apache.drill.exec.record
Modifier and TypeMethodDescriptionstatic VectorContainer
SchemaUtil.coerceContainer
(VectorAccessible in, BatchSchema toSchema, BufferAllocator allocator) static VectorContainer
SchemaUtil.coerceContainer
(VectorAccessible in, BatchSchema toSchema, OperatorContext context) Creates a copy a record batch, converting any fields as necessary to coerce it into the provided schemaAbstractRecordBatch.getContainer()
RecordBatch.getContainer()
Return the internal vector containerRecordBatchLoader.getContainer()
SchemalessBatch.getContainer()
SimpleRecordBatch.getContainer()
AbstractRecordBatch.getOutgoingContainer()
RecordBatch.getOutgoingContainer()
SchemalessBatch.getOutgoingContainer()
SimpleRecordBatch.getOutgoingContainer()
static VectorContainer
VectorContainer.getTransferClone
(VectorAccessible incoming, BufferAllocator allocator) static VectorContainer
VectorContainer.getTransferClone
(VectorAccessible incoming, OperatorContext oContext) Get a set of transferred clones of this container.static VectorContainer
VectorContainer.getTransferClone
(VectorAccessible incoming, VectorWrapper<?>[] ignoreWrappers, OperatorContext oContext) VectorContainer.merge
(VectorContainer otherContainer) Merge two batches to create a single, combined, batch.Modifier and TypeMethodDescriptionvoid
RecordBatchMemoryManager.allocateVectors
(VectorContainer container) void
RecordBatchMemoryManager.allocateVectors
(VectorContainer container, int recordCount) void
RecordBatchSizer.allocateVectors
(VectorContainer container, int recordCount) int
VectorContainer.appendRow
(VectorContainer srcContainer, int srcIndex) This works with non-hyperVectorContainer
s which have no selection vectors.void
VectorContainer.exchange
(VectorContainer other) Exchange buffers between two identical vector containers.static BaseWriter.ComplexWriter
VectorAccessibleComplexWriter.getWriter
(String name, VectorContainer container) VectorContainer.merge
(VectorContainer otherContainer) Merge two batches to create a single, combined, batch.void
VectorContainer.rawTransferIn
(VectorContainer containerIn) void
WritableBatch.reconstructContainer
(BufferAllocator allocator, VectorContainer container) void
VectorContainer.transferIn
(VectorContainer containerIn) Transfer vectors from containerIn to this.void
VectorContainer.transferOut
(VectorContainer containerOut) Transfer vectors from this to containerOutModifierConstructorDescriptionSimpleRecordBatch
(VectorContainer container, FragmentContext context) -
Uses of VectorContainer in org.apache.drill.exec.record.selection
-
Uses of VectorContainer in org.apache.drill.exec.store.drill.plugin
Modifier and TypeMethodDescriptionDrillRecordReader.getContainer()
DrillRecordReader.getOutgoingContainer()