Uses of Class
org.apache.drill.exec.record.VectorContainer
Packages that use 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
Methods in org.apache.drill.exec.cache that return VectorContainerModifier and TypeMethodDescriptionVectorAccessibleSerializable.get()VectorSerializer.Reader.read()Methods in org.apache.drill.exec.cache with parameters of type VectorContainerModifier and TypeMethodDescriptionvoidVectorAccessibleSerializable.readFromStreamWithContainer(VectorContainer myContainer, InputStream input) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl
Methods in org.apache.drill.exec.physical.impl that return VectorContainerConstructors in org.apache.drill.exec.physical.impl with parameters of type VectorContainerModifierConstructorDescriptionMutator(OperatorContext oContext, BufferAllocator allocator, VectorContainer container) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.aggregate
Methods in org.apache.drill.exec.physical.impl.aggregate that return VectorContainerModifier and TypeMethodDescriptionSpilledRecordBatch.getContainer()HashAggBatch.getOutgoingContainer()SpilledRecordBatch.getOutgoingContainer()StreamingAggBatch.getOutgoingContainer()Methods in org.apache.drill.exec.physical.impl.aggregate with parameters of type VectorContainerModifier and TypeMethodDescriptionvoidHashAggregator.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) voidHashAggTemplate.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) voidHashAggTemplate.BatchHolder.setupInterior(RecordBatch incoming, RecordBatch outgoing, VectorContainer aggrValuesContainer) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.common
Methods in org.apache.drill.exec.physical.impl.common that return types with arguments of type VectorContainerModifier 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()Methods in org.apache.drill.exec.physical.impl.common with parameters of type VectorContainerModifier and TypeMethodDescriptionvoidHashPartition.appendInnerRow(VectorContainer buildContainer, int ind, int hashCode, HashJoinMemoryCalculator.BuildSidePartitioning calc) Spills if neededprotected abstract voidHashTableTemplate.doSetup(VectorContainer incomingBuild, RecordBatch incomingProbe) booleanHashTable.outputKeys(int batchIdx, VectorContainer outContainer, int numRecords) Retrieves the key columns and transfers them to the output container.booleanHashTableTemplate.outputKeys(int batchIdx, VectorContainer outContainer, int numRecords) voidHashTable.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.voidHashTableTemplate.setup(HashTableConfig htConfig, BufferAllocator allocator, VectorContainer incomingBuild, RecordBatch incomingProbe, RecordBatch outgoing, VectorContainer htContainerOrig, FragmentContext context, ClassGenerator<?> cg) protected voidHashTableTemplate.BatchHolder.setupInterior(VectorContainer incomingBuild, RecordBatch incomingProbe, RecordBatch outgoing, VectorContainer htContainer) voidHashTable.updateIncoming(VectorContainer newIncoming, RecordBatch newIncomingProbe) Changes the incoming probe and build side batches, and then updates all the value vector references in theHashTableTemplate.BatchHolders.voidHashTableTemplate.updateIncoming(VectorContainer newIncoming, RecordBatch newIncomingProbe) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.flatten
Methods in org.apache.drill.exec.physical.impl.flatten that return VectorContainer -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.join
Fields in org.apache.drill.exec.physical.impl.join declared as VectorContainerMethods in org.apache.drill.exec.physical.impl.join with parameters of type VectorContainerModifier and TypeMethodDescriptionabstract voidJoinTemplate.doSetup(FragmentContext context, JoinStatus status, VectorContainer outgoing) voidNestedLoopJoin.doSetup(FragmentContext context, VectorContainer rightContainer, RecordBatch leftBatch, RecordBatch outgoing) abstract voidNestedLoopJoinTemplate.doSetup(FragmentContext context, VectorContainer rightContainer, RecordBatch leftBatch, RecordBatch outgoing) protected intProbeTemplate.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.voidHashJoinProbeTemplate.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 voidProbe.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 voidProbe.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 voidProbeTemplate.setup(RecordBatch probeBatch, RecordBatch.IterOutcome leftStartState, HashPartition[] partitions, int cycleNum, VectorContainer container, AbstractHashBinaryRecordBatch.SpilledPartition[] spilledInners, boolean buildSideIsEmpty, int numPartitions) voidJoinTemplate.setupJoin(FragmentContext context, JoinStatus status, VectorContainer outgoing) voidJoinWorker.setupJoin(FragmentContext context, JoinStatus status, VectorContainer outgoing) Method parameters in org.apache.drill.exec.physical.impl.join with type arguments of type VectorContainerModifier and TypeMethodDescriptionprotected intProbeTemplate.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
Methods in org.apache.drill.exec.physical.impl.materialize that return VectorContainer -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.orderedpartitioner
Methods in org.apache.drill.exec.physical.impl.orderedpartitioner with parameters of type VectorContainerModifier and TypeMethodDescriptionabstract voidOrderedPartitionProjectorTemplate.doSetup(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, VectorContainer partitionVectors) abstract voidSampleSortTemplate.doSetup(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) voidOrderedPartitionProjector.setup(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, List<TransferPair> transfers, VectorContainer partitionVectors, int partitions, SchemaPath outputField) final voidOrderedPartitionProjectorTemplate.setup(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, List<TransferPair> transfers, VectorContainer partitionVectors, int partitions, SchemaPath outputField) voidSampleSortTemplate.setup(FragmentContext context, VectorContainer sampleBatch, SelectionVector2 vector2) voidSampleSorter.sort(SelectionVector2 vector2, VectorContainer container) voidSampleSortTemplate.sort(SelectionVector2 vector2, VectorContainer container) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.project
Methods in org.apache.drill.exec.physical.impl.project that return VectorContainerConstructors in org.apache.drill.exec.physical.impl.project with parameters of type VectorContainerModifierConstructorDescriptionProjectBatchBuilder(ProjectRecordBatch projectBatch, VectorContainer container, SchemaChangeCallBack callBack, RecordBatch incomingBatch) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.protocol
Fields in org.apache.drill.exec.physical.impl.protocol declared as VectorContainerMethods in org.apache.drill.exec.physical.impl.protocol that return VectorContainerModifier and TypeMethodDescriptionBatchAccessor.container()VectorContainerAccessor.container()OperatorRecordBatch.getContainer()OperatorRecordBatch.getOutgoingContainer()Methods in org.apache.drill.exec.physical.impl.protocol with parameters of type VectorContainerModifier and TypeMethodDescriptionvoidVectorContainerAccessor.addBatch(VectorContainer container) Define an output batch.voidVectorContainerAccessor.setSchema(VectorContainer container) Define a schema that does not necessarily contain any data.voidSchemaTracker.trackSchema(VectorContainer newBatch) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.scan
Methods in org.apache.drill.exec.physical.impl.scan that return VectorContainerModifier and TypeMethodDescriptionRowBatchReader.output()Return the container with the reader's output. -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.scan.framework
Methods in org.apache.drill.exec.physical.impl.scan.framework that return VectorContainer -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.scan.project
Fields in org.apache.drill.exec.physical.impl.scan.project declared as VectorContainerModifier and TypeFieldDescriptionprotected VectorContainerScanSchemaOrchestrator.outputContainerMethods in org.apache.drill.exec.physical.impl.scan.project that return VectorContainerModifier and TypeMethodDescriptionConstantColumnLoader.load(int rowCount) NullColumnLoader.load(int rowCount) abstract VectorContainerStaticColumnLoader.load(int rowCount) Populate static vectors with the defined static values.NullColumnBuilder.output()NullColumnLoader.output()ResolvedTuple.ResolvedRow.output()ScanSchemaOrchestrator.output()Methods in org.apache.drill.exec.physical.impl.scan.project with parameters of type VectorContainerModifier and TypeMethodDescriptionvoidResolvedTuple.ResolvedRow.project(VectorContainer input, VectorContainer output) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.scan.v3.lifecycle
Methods in org.apache.drill.exec.physical.impl.scan.v3.lifecycle that return VectorContainerModifier and TypeMethodDescriptionStaticBatchBuilder.load(int rowCount) Populate static vectors with the defined static values.ReaderLifecycle.output()OutputBatchBuilder.outputContainer()StaticBatchBuilder.outputContainer()Constructors in org.apache.drill.exec.physical.impl.scan.v3.lifecycle with parameters of type VectorContainer -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.setop
Methods in org.apache.drill.exec.physical.impl.setop with parameters of type VectorContainerModifier and TypeMethodDescriptionvoidHashSetOpProbeTemplate.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
Methods in org.apache.drill.exec.physical.impl.sort that return VectorContainerMethods in org.apache.drill.exec.physical.impl.sort that return types with arguments of type VectorContainerMethods in org.apache.drill.exec.physical.impl.sort with parameters of type VectorContainerModifier and TypeMethodDescriptionvoidSortRecordBatchBuilder.build(VectorContainer outputContainer) abstract voidSortTemplate.doSetup(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) voidSorter.setup(FragmentContext context, SelectionVector4 vector4, VectorContainer hyperBatch) voidSortTemplate.setup(FragmentContext context, SelectionVector4 vector4, VectorContainer hyperBatch) voidSorter.sort(SelectionVector4 vector4, VectorContainer container) voidSortTemplate.sort(SelectionVector4 vector4, VectorContainer container) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.statistics
Methods in org.apache.drill.exec.physical.impl.statistics that return VectorContainer -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.svremover
Fields in org.apache.drill.exec.physical.impl.svremover declared as VectorContainerMethods in org.apache.drill.exec.physical.impl.svremover with parameters of type VectorContainerModifier and TypeMethodDescriptionstatic voidAbstractCopier.allocateOutgoing(VectorContainer outgoing, int recordCount) static CopierGenericCopierFactory.createAndSetupCopier(RecordBatch incoming, VectorContainer outputContainer, SchemaChangeCallBack callBack) static CopierGenericCopierFactory.createAndSetupNonSVGenericCopier(RecordBatch incoming, VectorContainer outputContainer) voidAbstractCopier.setup(VectorAccessible incoming, VectorContainer outgoing) voidAbstractSV2Copier.setup(VectorAccessible incoming, VectorContainer outgoing) voidAbstractSV4Copier.setup(VectorAccessible incoming, VectorContainer outgoing) voidCopier.setup(VectorAccessible incoming, VectorContainer outgoing) voidGenericCopier.setup(VectorAccessible incoming, VectorContainer outgoing) voidStraightCopier.setup(VectorAccessible incoming, VectorContainer outgoing) Constructors in org.apache.drill.exec.physical.impl.svremover with parameters of type VectorContainerModifierConstructorDescriptionGenericSV2Copier(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
Methods in org.apache.drill.exec.physical.impl.TopN that return VectorContainerModifier and TypeMethodDescriptionPriorityQueue.getHyperBatch()Retrieves the final priority queue HyperBatch containing the results.PriorityQueueTemplate.getHyperBatch()Methods in org.apache.drill.exec.physical.impl.TopN with parameters of type VectorContainerModifier and TypeMethodDescriptionabstract voidPriorityQueueTemplate.doSetup(VectorContainer incoming, RecordBatch outgoing) Stores the reference to the hyperBatch container which holds all the records across incoming batches in it.voidPriorityQueue.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 SelectionVector4voidPriorityQueueTemplate.resetQueue(VectorContainer container, SelectionVector4 v4) Constructors in org.apache.drill.exec.physical.impl.TopN with parameters of type VectorContainerModifierConstructorDescriptionSimpleSV4RecordBatch(VectorContainer container, SelectionVector4 sv4, FragmentContext context) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.unnest
Methods in org.apache.drill.exec.physical.impl.unnest that return VectorContainer -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.unorderedreceiver
Methods in org.apache.drill.exec.physical.impl.unorderedreceiver that return VectorContainerModifier and TypeMethodDescriptionUnorderedReceiverBatch.getContainer()UnorderedReceiverBatch.getOutgoingContainer() -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.unpivot
Methods in org.apache.drill.exec.physical.impl.unpivot that return VectorContainer -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.validate
Methods in org.apache.drill.exec.physical.impl.validate that return VectorContainerModifier and TypeMethodDescriptionIteratorValidatorBatchIterator.getContainer()IteratorValidatorBatchIterator.getOutgoingContainer() -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.window
Methods in org.apache.drill.exec.physical.impl.window that return VectorContainerMethods in org.apache.drill.exec.physical.impl.window with parameters of type VectorContainerModifier and TypeMethodDescriptionvoidFrameSupportTemplate.setup(List<WindowDataBatch> batches, VectorContainer container, OperatorContext oContext, boolean requireFullPartition, WindowPOP popConfig) voidNoFrameSupportTemplate.setup(List<WindowDataBatch> batches, VectorContainer container, OperatorContext oContext, boolean requireFullPartition, WindowPOP popConfig) voidWindowFramer.setup(List<WindowDataBatch> batches, VectorContainer container, OperatorContext operatorContext, boolean requireFullPartition, WindowPOP popConfig) -
Uses of VectorContainer in org.apache.drill.exec.physical.impl.xsort
Fields in org.apache.drill.exec.physical.impl.xsort declared as VectorContainerMethods in org.apache.drill.exec.physical.impl.xsort that return VectorContainerModifier and TypeMethodDescriptionBatchGroup.getContainer()MergeSortWrapper.getContainer()PriorityQueueCopierWrapper.BatchMerger.getContainer()SortImpl.EmptyResults.getContainer()SortImpl.SingleBatchResults.getContainer()SortImpl.SortResults.getContainer()Container into which results are delivered.Methods in org.apache.drill.exec.physical.impl.xsort with parameters of type VectorContainerModifier and TypeMethodDescriptionabstract voidMSortTemplate.doSetup(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) SpilledRuns.finalMerge(List<? extends BatchGroup> bufferedBatches, VectorContainer container, int mergeRowCount, VectorInitializer allocHelper) voidMSorter.setup(FragmentContext context, BufferAllocator allocator, SelectionVector4 vector4, VectorContainer hyperBatch, int outputBatchSize, int desiredBatchSize) voidMSortTemplate.setup(FragmentContext context, BufferAllocator allocator, SelectionVector4 vector4, VectorContainer hyperBatch, int outputBatchSize, int desiredBatchSize) voidSorterWrapper.sortBatch(VectorContainer convertedBatch, SelectionVector2 sv2) voidSpilledRun.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.voidMergeSortWrapper.updateOutputContainer(VectorContainer container, SelectionVector4 sv4, RecordBatch.IterOutcome outcome, BatchSchema schema) voidPriorityQueueCopierWrapper.BatchMerger.updateOutputContainer(VectorContainer container, SelectionVector4 sv4, RecordBatch.IterOutcome outcome, BatchSchema schema) voidSortImpl.EmptyResults.updateOutputContainer(VectorContainer container, SelectionVector4 sv4, RecordBatch.IterOutcome outcome, BatchSchema schema) voidSortImpl.SingleBatchResults.updateOutputContainer(VectorContainer container, SelectionVector4 sv4, RecordBatch.IterOutcome outcome, BatchSchema schema) voidSortImpl.SortResults.updateOutputContainer(VectorContainer container, SelectionVector4 sv4, RecordBatch.IterOutcome outcome, BatchSchema schema) Constructors in org.apache.drill.exec.physical.impl.xsort with parameters of type VectorContainerModifierConstructorDescriptionBatchGroup(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
Methods in org.apache.drill.exec.physical.resultSet that return VectorContainerModifier 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
Methods in org.apache.drill.exec.physical.resultSet.impl that return VectorContainerModifier and TypeMethodDescriptionPushResultSetReaderImpl.BatchHolder.batch()PushResultSetReaderImpl.UpstreamSource.batch()ResultSetCopierImpl.harvest()ResultSetLoaderImpl.harvest()ResultSetLoaderImpl.outputContainer()TupleState.RowState.outputContainer()Constructors in org.apache.drill.exec.physical.resultSet.impl with parameters of type VectorContainer -
Uses of VectorContainer in org.apache.drill.exec.physical.resultSet.model
Methods in org.apache.drill.exec.physical.resultSet.model that return VectorContainerMethods in org.apache.drill.exec.physical.resultSet.model with parameters of type VectorContainerModifier 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
Methods in org.apache.drill.exec.physical.resultSet.model.hyper with parameters of type VectorContainerModifier and TypeMethodDescriptionstatic RowSetReaderImplHyperReaderBuilder.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
Methods in org.apache.drill.exec.physical.resultSet.model.single that return VectorContainerMethods in org.apache.drill.exec.physical.resultSet.model.single with parameters of type VectorContainerModifier and TypeMethodDescriptionstatic RowSetReaderImplSimpleReaderBuilder.build(VectorContainer container, ReaderIndex rowIndex) static RowSetReaderImplSimpleReaderBuilder.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) Constructors in org.apache.drill.exec.physical.resultSet.model.single with parameters of type VectorContainerModifierConstructorDescriptionDirectRowIndex(VectorContainer container) VectorAllocator(VectorContainer container) -
Uses of VectorContainer in org.apache.drill.exec.physical.rowSet
Fields in org.apache.drill.exec.physical.rowSet declared as VectorContainerMethods in org.apache.drill.exec.physical.rowSet that return VectorContainerMethods in org.apache.drill.exec.physical.rowSet with parameters of type VectorContainerModifier and TypeMethodDescriptionvoidHyperRowSetImpl.HyperRowSetBuilderImpl.addBatch(VectorContainer container) voidRowSet.HyperRowSetBuilder.addBatch(VectorContainer container) static DirectRowSetDirectRowSet.fromContainer(VectorContainer container) static RowSet.HyperRowSetHyperRowSetImpl.fromContainer(VectorContainer container, SelectionVector4 sv4) static IndirectRowSetIndirectRowSet.fromContainer(VectorContainer container) static IndirectRowSetIndirectRowSet.fromSv2(VectorContainer container, SelectionVector2 sv2) static voidRowSetFormatter.print(VectorContainer container) static RowSetRowSets.wrap(VectorContainer container) Constructors in org.apache.drill.exec.physical.rowSet with parameters of type VectorContainerModifierConstructorDescriptionAbstractRowSet(VectorContainer container, TupleMetadata schema) protectedAbstractSingleRowSet(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
Methods in org.apache.drill.exec.planner.logical.partition with parameters of type VectorContainerModifier and TypeMethodDescriptionprotected LogicalExpressionPruneScanRule.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
Subclasses of VectorContainer in org.apache.drill.exec.recordFields in org.apache.drill.exec.record declared as VectorContainerMethods in org.apache.drill.exec.record that return VectorContainerModifier and TypeMethodDescriptionstatic VectorContainerSchemaUtil.coerceContainer(VectorAccessible in, BatchSchema toSchema, BufferAllocator allocator) static VectorContainerSchemaUtil.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 VectorContainerVectorContainer.getTransferClone(VectorAccessible incoming, BufferAllocator allocator) static VectorContainerVectorContainer.getTransferClone(VectorAccessible incoming, OperatorContext oContext) Get a set of transferred clones of this container.static VectorContainerVectorContainer.getTransferClone(VectorAccessible incoming, VectorWrapper<?>[] ignoreWrappers, OperatorContext oContext) VectorContainer.merge(VectorContainer otherContainer) Merge two batches to create a single, combined, batch.Methods in org.apache.drill.exec.record with parameters of type VectorContainerModifier and TypeMethodDescriptionvoidRecordBatchMemoryManager.allocateVectors(VectorContainer container) voidRecordBatchMemoryManager.allocateVectors(VectorContainer container, int recordCount) voidRecordBatchSizer.allocateVectors(VectorContainer container, int recordCount) intVectorContainer.appendRow(VectorContainer srcContainer, int srcIndex) This works with non-hyperVectorContainers which have no selection vectors.voidVectorContainer.exchange(VectorContainer other) Exchange buffers between two identical vector containers.static BaseWriter.ComplexWriterVectorAccessibleComplexWriter.getWriter(String name, VectorContainer container) VectorContainer.merge(VectorContainer otherContainer) Merge two batches to create a single, combined, batch.voidVectorContainer.rawTransferIn(VectorContainer containerIn) voidWritableBatch.reconstructContainer(BufferAllocator allocator, VectorContainer container) voidVectorContainer.transferIn(VectorContainer containerIn) Transfer vectors from containerIn to this.voidVectorContainer.transferOut(VectorContainer containerOut) Transfer vectors from this to containerOutConstructors in org.apache.drill.exec.record with parameters of type VectorContainerModifierConstructorDescriptionSimpleRecordBatch(VectorContainer container, FragmentContext context) -
Uses of VectorContainer in org.apache.drill.exec.record.selection
Methods in org.apache.drill.exec.record.selection with parameters of type VectorContainer -
Uses of VectorContainer in org.apache.drill.exec.store.drill.plugin
Methods in org.apache.drill.exec.store.drill.plugin that return VectorContainerModifier and TypeMethodDescriptionDrillRecordReader.getContainer()DrillRecordReader.getOutgoingContainer()