| Package | Description |
|---|---|
| org.apache.drill.exec.cache |
Distributed cache for syncing state and data between Drillbits.
|
| org.apache.drill.exec.physical.impl | |
| org.apache.drill.exec.physical.impl.aggregate | |
| org.apache.drill.exec.physical.impl.common | |
| org.apache.drill.exec.physical.impl.flatten | |
| org.apache.drill.exec.physical.impl.join | |
| org.apache.drill.exec.physical.impl.materialize | |
| org.apache.drill.exec.physical.impl.orderedpartitioner | |
| org.apache.drill.exec.physical.impl.project | |
| org.apache.drill.exec.physical.impl.protocol |
Defines a revised implementation of the Drill RecordBatch protocol.
|
| org.apache.drill.exec.physical.impl.scan |
Defines the scan operation implementation.
|
| org.apache.drill.exec.physical.impl.scan.framework |
Defines the projection, vector continuity and other operations for
a set of one or more readers.
|
| org.apache.drill.exec.physical.impl.scan.project |
Provides run-time semantic analysis of the projection list for the
scan operator.
|
| org.apache.drill.exec.physical.impl.scan.v3 |
Provides the "version 3" scan framework (which can also be thought of
as EVF version 2).
|
| org.apache.drill.exec.physical.impl.scan.v3.lifecycle |
Implements the details of the scan lifecycle for a set of readers,
primarily the process of resolving the scan output schema from a variety
of input schemas, then running each reader, each of which will produce
some number of batches.
|
| org.apache.drill.exec.physical.impl.sort | |
| org.apache.drill.exec.physical.impl.statistics | |
| org.apache.drill.exec.physical.impl.svremover | |
| org.apache.drill.exec.physical.impl.TopN | |
| org.apache.drill.exec.physical.impl.unnest | |
| org.apache.drill.exec.physical.impl.unorderedreceiver | |
| org.apache.drill.exec.physical.impl.unpivot | |
| org.apache.drill.exec.physical.impl.validate | |
| org.apache.drill.exec.physical.impl.window | |
| org.apache.drill.exec.physical.impl.xsort | |
| org.apache.drill.exec.physical.resultSet |
Provides a second-generation row set (AKA "record batch") writer used
by client code to
Define the schema of a result set.
Write data into the vectors backing a row set.
|
| org.apache.drill.exec.physical.resultSet.impl |
Handles the details of the result set loader implementation.
|
| org.apache.drill.exec.physical.resultSet.model |
The "row set model" provides a "dual" of the vector structure used to create,
allocate and work with a collection of vectors.
|
| org.apache.drill.exec.physical.resultSet.model.hyper |
Implementation of a row set model for hyper-batches.
|
| org.apache.drill.exec.physical.resultSet.model.single |
This set of classes models the structure of a batch consisting
of single vectors (as contrasted with a hyper batch.) Provides tools
or metdata-based construction, allocation, reading and writing of
the vectors.
|
| org.apache.drill.exec.physical.rowSet |
Provides a set of tools to work with row sets.
|
| org.apache.drill.exec.planner.logical.partition | |
| org.apache.drill.exec.record | |
| org.apache.drill.exec.record.selection | |
| org.apache.drill.exec.store | |
| org.apache.drill.test |
Provides a variety of test framework tools to simplify Drill unit
tests and ad-hoc tests created while developing features.
|
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
VectorAccessibleSerializable.get() |
VectorContainer |
VectorSerializer.Reader.read() |
| Modifier and Type | Method and Description |
|---|---|
void |
VectorAccessibleSerializable.readFromStreamWithContainer(VectorContainer myContainer,
InputStream input) |
| Modifier and Type | Field and Description |
|---|---|
protected VectorContainer |
MockRecordBatch.container |
| Modifier and Type | Field and Description |
|---|---|
protected List<VectorContainer> |
BaseTestOpBatchEmitOutcome.inputContainer |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
MockRecordBatch.getContainer() |
VectorContainer |
ScanBatch.getContainer() |
VectorContainer |
MockRecordBatch.getOutgoingContainer() |
VectorContainer |
ScanBatch.getOutgoingContainer() |
| Constructor and Description |
|---|
Mutator(OperatorContext oContext,
BufferAllocator allocator,
VectorContainer container) |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
SpilledRecordBatch.getContainer() |
VectorContainer |
StreamingAggBatch.getOutgoingContainer() |
VectorContainer |
HashAggBatch.getOutgoingContainer() |
VectorContainer |
SpilledRecordBatch.getOutgoingContainer() |
| Modifier and Type | Method and Description |
|---|---|
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 |
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.BatchHolder.setupInterior(RecordBatch incoming,
RecordBatch outgoing,
VectorContainer aggrValuesContainer) |
| Modifier and Type | Method and Description |
|---|---|
ArrayList<VectorContainer> |
HashPartition.getContainers() |
org.apache.commons.lang3.tuple.Pair<VectorContainer,Integer> |
HashTableTemplate.nextBatch() |
org.apache.commons.lang3.tuple.Pair<VectorContainer,Integer> |
HashPartition.nextBatch() |
org.apache.commons.lang3.tuple.Pair<VectorContainer,Integer> |
HashTable.nextBatch() |
| Modifier and Type | Method and Description |
|---|---|
void |
HashPartition.appendInnerRow(VectorContainer buildContainer,
int ind,
int hashCode,
HashJoinMemoryCalculator.BuildSidePartitioning calc)
Spills if needed
|
protected abstract void |
HashTableTemplate.doSetup(VectorContainer incomingBuild,
RecordBatch incomingProbe) |
boolean |
HashTableTemplate.outputKeys(int batchIdx,
VectorContainer outContainer,
int numRecords) |
boolean |
HashTable.outputKeys(int batchIdx,
VectorContainer outContainer,
int numRecords)
Retrieves the key columns and transfers them to the output container.
|
void |
HashTableTemplate.setup(HashTableConfig htConfig,
BufferAllocator allocator,
VectorContainer incomingBuild,
RecordBatch incomingProbe,
RecordBatch outgoing,
VectorContainer htContainerOrig,
FragmentContext context,
ClassGenerator<?> cg) |
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 the HashTable. |
protected void |
HashTableTemplate.BatchHolder.setupInterior(VectorContainer incomingBuild,
RecordBatch incomingProbe,
RecordBatch outgoing,
VectorContainer htContainer) |
void |
HashTableTemplate.updateIncoming(VectorContainer newIncoming,
RecordBatch newIncomingProbe) |
void |
HashTable.updateIncoming(VectorContainer newIncoming,
RecordBatch newIncomingProbe)
Changes the incoming probe and build side batches, and then updates all the value vector references in the
HashTableTemplate.BatchHolders. |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
FlattenRecordBatch.getOutgoingContainer() |
| Modifier and Type | Method and Description |
|---|---|
abstract 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) |
void |
HashJoinProbeTemplate.setupHashJoinProbe(RecordBatch probeBatch,
HashJoinBatch outgoing,
org.apache.calcite.rel.core.JoinRelType joinRelType,
boolean semiJoin,
RecordBatch.IterOutcome leftStartState,
HashPartition[] partitions,
int cycleNum,
VectorContainer container,
HashJoinBatch.HashJoinSpilledPartition[] spilledInners,
boolean buildSideIsEmpty,
int numPartitions,
int rightHVColPosition)
Setup the Hash Join Probe object
|
void |
HashJoinProbe.setupHashJoinProbe(RecordBatch probeBatch,
HashJoinBatch outgoing,
org.apache.calcite.rel.core.JoinRelType joinRelType,
boolean semiJoin,
RecordBatch.IterOutcome leftStartState,
HashPartition[] partitions,
int cycleNum,
VectorContainer container,
HashJoinBatch.HashJoinSpilledPartition[] spilledInners,
boolean buildSideIsEmpty,
int numPartitions,
int rightHVColPosition) |
void |
JoinTemplate.setupJoin(FragmentContext context,
JoinStatus status,
VectorContainer outgoing) |
void |
JoinWorker.setupJoin(FragmentContext context,
JoinStatus status,
VectorContainer outgoing) |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
QueryDataPackage.batch() |
VectorContainer |
QueryDataPackage.EmptyResultsPackage.batch() |
VectorContainer |
QueryDataPackage.DataPackage.batch() |
VectorContainer |
VectorRecordMaterializer.incoming() |
VectorContainer |
RecordMaterializer.incoming() |
| Modifier and Type | Method and Description |
|---|---|
abstract 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) |
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) |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
ProjectRecordBatch.getOutgoingContainer() |
| Constructor and Description |
|---|
ProjectBatchBuilder(ProjectRecordBatch projectBatch,
VectorContainer container,
SchemaChangeCallBack callBack,
RecordBatch incomingBatch) |
| Modifier and Type | Field and Description |
|---|---|
protected VectorContainer |
VectorContainerAccessor.container |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
BatchAccessor.container() |
VectorContainer |
VectorContainerAccessor.container() |
VectorContainer |
OperatorRecordBatch.getContainer() |
VectorContainer |
OperatorRecordBatch.getOutgoingContainer() |
| Modifier and Type | Method and Description |
|---|---|
void |
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) |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
RowBatchReader.output()
Return the container with the reader's output.
|
| Modifier and Type | Method and Description |
|---|---|
protected void |
BaseScanOperatorExecTest.verifyBatch(int offset,
VectorContainer output) |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
ShimBatchReader.output() |
| Modifier and Type | Field and Description |
|---|---|
protected VectorContainer |
ScanSchemaOrchestrator.outputContainer |
| Modifier and Type | Method and Description |
|---|---|
abstract VectorContainer |
StaticColumnLoader.load(int rowCount)
Populate static vectors with the defined static values.
|
VectorContainer |
ConstantColumnLoader.load(int rowCount) |
VectorContainer |
NullColumnLoader.load(int rowCount) |
VectorContainer |
ScanSchemaOrchestrator.output() |
VectorContainer |
ResolvedTuple.ResolvedRow.output() |
VectorContainer |
NullColumnLoader.output() |
VectorContainer |
NullColumnBuilder.output() |
| Modifier and Type | Method and Description |
|---|---|
void |
ResolvedTuple.ResolvedRow.project(VectorContainer input,
VectorContainer output) |
| Modifier and Type | Method and Description |
|---|---|
protected void |
BaseScanTest.verifyBatch(int offset,
VectorContainer output) |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
StaticBatchBuilder.load(int rowCount)
Populate static vectors with the defined static values.
|
VectorContainer |
ReaderLifecycle.output() |
VectorContainer |
OutputBatchBuilder.outputContainer() |
VectorContainer |
StaticBatchBuilder.outputContainer() |
| Constructor and Description |
|---|
BatchSource(TupleMetadata schema,
VectorContainer container) |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
RecordBatchData.getContainer() |
| Modifier and Type | Method and Description |
|---|---|
List<VectorContainer> |
SortRecordBatchBuilder.getHeldRecordBatches() |
| Modifier and Type | Method and Description |
|---|---|
void |
SortRecordBatchBuilder.build(VectorContainer outputContainer) |
abstract void |
SortTemplate.doSetup(FragmentContext context,
VectorContainer incoming,
RecordBatch outgoing) |
void |
SortTemplate.setup(FragmentContext context,
SelectionVector4 vector4,
VectorContainer hyperBatch) |
void |
Sorter.setup(FragmentContext context,
SelectionVector4 vector4,
VectorContainer hyperBatch) |
void |
SortTemplate.sort(SelectionVector4 vector4,
VectorContainer container) |
void |
Sorter.sort(SelectionVector4 vector4,
VectorContainer container) |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
StatisticsMergeBatch.getOutgoingContainer() |
| Modifier and Type | Field and Description |
|---|---|
protected VectorContainer |
AbstractCopier.outgoing |
| Modifier and Type | Method and Description |
|---|---|
static 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) |
Copier |
GenericCopierTest.createCopier(RecordBatch incoming,
VectorContainer outputContainer,
SchemaChangeCallBack callback) |
Copier |
AbstractGenericCopierTest.createCopier(RecordBatch incoming,
VectorContainer outputContainer,
SchemaChangeCallBack callback) |
void |
AbstractSV2Copier.setup(VectorAccessible incoming,
VectorContainer outgoing) |
void |
GenericCopier.setup(VectorAccessible incoming,
VectorContainer outgoing) |
void |
Copier.setup(VectorAccessible incoming,
VectorContainer outgoing) |
void |
StraightCopier.setup(VectorAccessible incoming,
VectorContainer outgoing) |
void |
AbstractSV4Copier.setup(VectorAccessible incoming,
VectorContainer outgoing) |
void |
AbstractCopier.setup(VectorAccessible incoming,
VectorContainer outgoing) |
| Constructor and Description |
|---|
GenericSV2Copier(RecordBatch incomingBatch,
VectorContainer outputContainer,
SchemaChangeCallBack callBack) |
GenericSV4Copier(RecordBatch incomingBatch,
VectorContainer outputContainer,
SchemaChangeCallBack callBack) |
StraightCopier(RecordBatch incomingBatch,
VectorContainer outputContainer,
SchemaChangeCallBack callBack) |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
PriorityQueue.getHyperBatch()
Retrieves the final priority queue HyperBatch containing the results.
|
VectorContainer |
PriorityQueueTemplate.getHyperBatch() |
| Modifier and Type | Method and Description |
|---|---|
abstract 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 SelectionVector4
|
void |
PriorityQueueTemplate.resetQueue(VectorContainer container,
SelectionVector4 v4) |
| Constructor and Description |
|---|
SimpleSV4RecordBatch(VectorContainer container,
SelectionVector4 sv4,
FragmentContext context) |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
MockLateralJoinBatch.getContainer() |
VectorContainer |
MockLateralJoinBatch.getOutgoingContainer() |
VectorContainer |
UnnestRecordBatch.getOutgoingContainer() |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
UnorderedReceiverBatch.getContainer() |
VectorContainer |
UnorderedReceiverBatch.getOutgoingContainer() |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
UnpivotMapsRecordBatch.getOutgoingContainer() |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
IteratorValidatorBatchIterator.getContainer() |
VectorContainer |
IteratorValidatorBatchIterator.getOutgoingContainer() |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
WindowDataBatch.getContainer() |
| Modifier and Type | Method and Description |
|---|---|
void |
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) |
| Modifier and Type | Field and Description |
|---|---|
protected VectorContainer |
BatchGroup.currentContainer |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
SortImpl.SortResults.getContainer()
Container into which results are delivered.
|
VectorContainer |
SortImpl.EmptyResults.getContainer() |
VectorContainer |
SortImpl.SingleBatchResults.getContainer() |
VectorContainer |
PriorityQueueCopierWrapper.BatchMerger.getContainer() |
VectorContainer |
BatchGroup.getContainer() |
VectorContainer |
MergeSortWrapper.getContainer() |
| Modifier and Type | Method and Description |
|---|---|
abstract void |
MSortTemplate.doSetup(FragmentContext context,
VectorContainer incoming,
RecordBatch outgoing) |
SortImpl.SortResults |
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.BatchMerger |
PriorityQueueCopierWrapper.startMerge(BatchSchema schema,
List<? extends BatchGroup> batchGroupList,
VectorContainer outputContainer,
int targetRecordCount,
VectorInitializer allocHelper)
Start a merge operation using the specified vector container.
|
void |
SortImpl.SortResults.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 |
PriorityQueueCopierWrapper.BatchMerger.updateOutputContainer(VectorContainer container,
SelectionVector4 sv4,
RecordBatch.IterOutcome outcome,
BatchSchema schema) |
void |
MergeSortWrapper.updateOutputContainer(VectorContainer container,
SelectionVector4 sv4,
RecordBatch.IterOutcome outcome,
BatchSchema schema) |
protected void |
SortTestUtilities.CopierTester.verifyResults(PriorityQueueCopierWrapper.BatchMerger merger,
VectorContainer dest) |
| Constructor and Description |
|---|
BatchGroup(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) |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
ResultSetCopier.harvest()
Obtain the output batch.
|
VectorContainer |
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.
|
VectorContainer |
ResultSetLoader.outputContainer()
Returns the output container which holds (or will hold) batches
from this loader.
|
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
TestResultSetReader.BatchGenerator.batch() |
VectorContainer |
PushResultSetReaderImpl.UpstreamSource.batch() |
VectorContainer |
PushResultSetReaderImpl.BatchHolder.batch() |
VectorContainer |
ResultSetLoaderImpl.harvest() |
VectorContainer |
ResultSetCopierImpl.harvest() |
VectorContainer |
TupleState.RowState.outputContainer() |
VectorContainer |
ResultSetLoaderImpl.outputContainer() |
| Constructor and Description |
|---|
BatchHolder(VectorContainer container) |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
TupleModel.RowSetModel.container() |
| Modifier and Type | Method and Description |
|---|---|
R |
ContainerVisitor.apply(VectorContainer container,
A arg) |
R |
ContainerVisitor.visitChildren(VectorContainer container,
A arg) |
| Modifier and Type | Method and Description |
|---|---|
static 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) |
TupleMetadata |
HyperSchemaInference.infer(VectorContainer container) |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
BuildVectorsFromMetadata.build(TupleMetadata schema) |
| Modifier and Type | Method and Description |
|---|---|
static RowSetReaderImpl |
SimpleReaderBuilder.build(VectorContainer container,
ReaderIndex rowIndex) |
static RowSetReaderImpl |
SimpleReaderBuilder.build(VectorContainer container,
TupleMetadata schema,
ReaderIndex rowIndex) |
List<AbstractObjectReader> |
SimpleReaderBuilder.buildContainerChildren(VectorContainer container,
MetadataProvider mdProvider) |
protected List<AbstractObjectWriter> |
BaseWriterBuilder.buildContainerChildren(VectorContainer container,
MetadataProvider mdProvider) |
TupleMetadata |
SingleSchemaInference.infer(VectorContainer container) |
| Constructor and Description |
|---|
DirectRowIndex(VectorContainer container) |
VectorAllocator(VectorContainer container) |
| Modifier and Type | Field and Description |
|---|---|
protected VectorContainer |
AbstractRowSet.container |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
AbstractRowSet.container() |
VectorContainer |
RowSet.container() |
| Modifier and Type | Method and Description |
|---|---|
void |
HyperRowSetImpl.HyperRowSetBuilderImpl.addBatch(VectorContainer container) |
void |
RowSet.HyperRowSetBuilder.addBatch(VectorContainer container) |
static IndirectRowSet |
IndirectRowSet.fromContainer(VectorContainer container) |
static DirectRowSet |
DirectRowSet.fromContainer(VectorContainer container) |
static RowSet.HyperRowSet |
HyperRowSetImpl.fromContainer(VectorContainer container,
SelectionVector4 sv4) |
static IndirectRowSet |
IndirectRowSet.fromSv2(VectorContainer container,
SelectionVector2 sv2) |
static void |
RowSetFormatter.print(VectorContainer container) |
static RowSet |
RowSets.wrap(VectorContainer container) |
| Constructor and Description |
|---|
AbstractRowSet(VectorContainer container,
TupleMetadata schema) |
AbstractSingleRowSet(VectorContainer container,
TupleMetadata schema) |
HyperRowSetImpl(TupleMetadata schema,
VectorContainer container,
SelectionVector4 sv4) |
HyperRowSetImpl(VectorContainer container,
SelectionVector4 sv4) |
IndirectRowSet(VectorContainer container) |
| Modifier and Type | Method and Description |
|---|---|
protected LogicalExpression |
PruneScanRule.materializePruneExpr(org.apache.calcite.rex.RexNode pruneCondition,
PlannerSettings settings,
org.apache.calcite.rel.RelNode scanRel,
VectorContainer container) |
| Modifier and Type | Class and Description |
|---|---|
class |
ExpandableHyperContainer |
| Modifier and Type | Field and Description |
|---|---|
protected VectorContainer |
AbstractRecordBatch.container |
| Modifier and Type | Method and Description |
|---|---|
static 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 schema
|
VectorContainer |
SchemalessBatch.getContainer() |
VectorContainer |
RecordBatch.getContainer()
Return the internal vector container
|
VectorContainer |
SimpleRecordBatch.getContainer() |
VectorContainer |
RecordBatchLoader.getContainer() |
VectorContainer |
AbstractRecordBatch.getContainer() |
VectorContainer |
SchemalessBatch.getOutgoingContainer() |
VectorContainer |
RecordBatch.getOutgoingContainer() |
VectorContainer |
SimpleRecordBatch.getOutgoingContainer() |
VectorContainer |
AbstractRecordBatch.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 |
VectorContainer.merge(VectorContainer otherContainer)
Merge two batches to create a single, combined, batch.
|
| Modifier and Type | Method and Description |
|---|---|
void |
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-hyper
VectorContainers which have no selection vectors. |
void |
VectorContainer.exchange(VectorContainer other)
Exchange buffers between two identical vector containers.
|
static org.apache.drill.exec.vector.complex.writer.BaseWriter.ComplexWriter |
VectorAccessibleComplexWriter.getWriter(String name,
VectorContainer container) |
VectorContainer |
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 containerOut
|
| Constructor and Description |
|---|
SimpleRecordBatch(VectorContainer container,
FragmentContext context) |
VectorAccessibleComplexWriter(VectorContainer vc) |
| Modifier and Type | Method and Description |
|---|---|
SelectionVector2 |
SelectionVector2Builder.harvest(VectorContainer batch) |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
TestOutputMutator.getContainer() |
| Modifier and Type | Method and Description |
|---|---|
VectorContainer |
QueryBatchIterator.batch() |
| Modifier and Type | Method and Description |
|---|---|
RowSet |
OperatorFixture.wrap(VectorContainer container) |
RowSet |
OperatorFixture.wrap(VectorContainer container,
SelectionVector2 sv2) |
Copyright © 2021 The Apache Software Foundation. All rights reserved.