Uses of Enum
org.apache.drill.exec.record.RecordBatch.IterOutcome
Package
Description
Defines a revised implementation of the Drill RecordBatch protocol.
Drill storage plugin.
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.base
Modifier and TypeMethodDescriptionLateralContract.getLeftOutcome()
Get the current outcome of left incoming batch. -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl
Modifier and TypeMethodDescriptionStatisticsWriterRecordBatch.innerNext()
WriterRecordBatch.innerNext()
final RecordBatch.IterOutcome
BaseRootExec.next
(RecordBatch b) ScanBatch.next()
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.aggregate
Modifier and TypeMethodDescriptionSpilledRecordBatch.getInitialOutcome()
Return the initial outcome (from the first next() call )HashAggregator.getOutcome()
HashAggTemplate.getOutcome()
StreamingAggregator.getOutcome()
StreamingAggTemplate.getOutcome()
HashAggBatch.innerNext()
StreamingAggBatch.innerNext()
BatchIterator.next()
SpilledRecordBatch.next()
Read the next batch from the spill fileModifier and TypeMethodDescriptionStreamingAggregator.doWork
(RecordBatch.IterOutcome outerOutcome) StreamingAggTemplate.doWork
(RecordBatch.IterOutcome outerOutcome) -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.filter
Modifier and TypeMethodDescriptionprotected RecordBatch.IterOutcome
FilterRecordBatch.doWork()
protected RecordBatch.IterOutcome
RuntimeFilterRecordBatch.doWork()
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.flatten
Modifier and TypeMethodDescriptionprotected RecordBatch.IterOutcome
FlattenRecordBatch.doWork()
FlattenRecordBatch.innerNext()
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.join
Modifier and TypeMethodDescriptionAbstractHashBinaryRecordBatch.executeBuildPhase()
Execute the BUILD phase; first read incoming and split rows into partitions; may decide to spill some of the partitionsLateralJoinBatch.getLeftOutcome()
Returns the currentRecordBatch.IterOutcome
for the left incoming batchJoinStatus.getLeftStatus()
JoinStatus.getRightStatus()
AbstractHashBinaryRecordBatch.innerNext()
LateralJoinBatch.innerNext()
Gets the left and right incoming batch and produce the output batch.MergeJoinBatch.innerNext()
NestedLoopJoinBatch.innerNext()
Method drains the right side input of the NLJ and accumulates the data in a hyper container.RowKeyJoinBatch.innerNext()
Modifier and TypeMethodDescriptionvoid
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) -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.limit
Modifier and TypeMethodDescriptionprotected RecordBatch.IterOutcome
LimitRecordBatch.doWork()
protected RecordBatch.IterOutcome
PartitionLimitRecordBatch.doWork()
protected RecordBatch.IterOutcome
LimitRecordBatch.getFinalOutcome
(boolean hasRemainder) Gets the outcome to return from super implementation and then in case of EMIT outcome it refreshes the state of operator.protected RecordBatch.IterOutcome
PartitionLimitRecordBatch.getFinalOutcome
(boolean hasRemainder) Gets the outcome to return from super implementation and then in case of EMIT outcome it refreshes the state of operator.LimitRecordBatch.innerNext()
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.mergereceiver
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.metadata
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.orderedpartitioner
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.producer
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.project
Modifier and TypeMethodDescriptionprotected RecordBatch.IterOutcome
ProjectRecordBatch.doWork()
protected RecordBatch.IterOutcome
ProjectRecordBatch.getFinalOutcome
(boolean hasMoreRecordInBoundary) protected RecordBatch.IterOutcome
ProjectRecordBatch.handleNullInput()
Handle Null input specially when Project operator is for query output.ProjectRecordBatch.innerNext()
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.protocol
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.rangepartitioner
Modifier and TypeMethodDescriptionprotected RecordBatch.IterOutcome
RangePartitionRecordBatch.doWork()
-
Uses of RecordBatch.IterOutcome 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 RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.sort
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.statistics
Modifier and TypeMethodDescriptionprotected RecordBatch.IterOutcome
StatisticsMergeBatch.doWork()
StatisticsMergeBatch.innerNext()
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.svremover
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.TopN
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.trace
Modifier and TypeMethodDescriptionprotected RecordBatch.IterOutcome
TraceRecordBatch.doWork()
Invoked for every record batch and it simply dumps the buffers associated with all the value vectors in this record batch to a log file. -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.union
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.unnest
Modifier and TypeMethodDescriptionprotected RecordBatch.IterOutcome
UnnestRecordBatch.doWork()
UnnestRecordBatch.innerNext()
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.unorderedreceiver
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.unpivot
Modifier and TypeMethodDescriptionprotected RecordBatch.IterOutcome
UnpivotMapsRecordBatch.doWork()
UnpivotMapsRecordBatch.innerNext()
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.validate
-
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.window
Modifier and TypeMethodDescriptionWindowFrameRecordBatch.innerNext()
Hold incoming batches in memory until all window functions are ready to process the batch on top of the queue -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.xsort
Modifier and TypeMethodDescriptionExternalSortBatch.innerNext()
Process each request for a batch.Modifier and TypeMethodDescriptionvoid
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) -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.record
Modifier and TypeFieldDescriptionprotected RecordBatch.IterOutcome
AbstractBinaryRecordBatch.leftUpstream
protected RecordBatch.IterOutcome
AbstractBinaryRecordBatch.rightUpstream
Modifier and TypeMethodDescriptionprotected abstract RecordBatch.IterOutcome
AbstractUnaryRecordBatch.doWork()
protected RecordBatch.IterOutcome
AbstractSingleRecordBatch.getFinalOutcome
(boolean hasMoreRecordInBoundary) Based on lastKnownOutcome and if there are more records to be output for current record boundary detected by EMIT outcome, this method returns EMIT or OK outcome.protected RecordBatch.IterOutcome
AbstractUnaryRecordBatch.getLastKnownOutcome()
RecordIterator.getLastOutcome()
protected RecordBatch.IterOutcome
AbstractUnaryRecordBatch.handleNullInput()
Default behavior to handle NULL input (aka FAST NONE): incoming return NONE before return a OK_NEW_SCHEMA: This could happen when the underneath Scan operators do not produce any batch with schema.abstract RecordBatch.IterOutcome
AbstractRecordBatch.innerNext()
AbstractUnaryRecordBatch.innerNext()
final RecordBatch.IterOutcome
AbstractRecordBatch.next()
final RecordBatch.IterOutcome
AbstractRecordBatch.next
(int inputIndex, RecordBatch b) final RecordBatch.IterOutcome
AbstractRecordBatch.next
(RecordBatch b) RecordBatch.next()
Updates the data in each Field reading interface for the next range of records.RecordIterator.next()
Move iterator to next record.SchemalessBatch.next()
SimpleRecordBatch.next()
static RecordBatch.IterOutcome
Returns the enum constant of this type with the specified name.static RecordBatch.IterOutcome[]
RecordBatch.IterOutcome.values()
Returns an array containing the constants of this enum type, in the order they are declared.Modifier and TypeMethodDescriptionprotected boolean
AbstractBinaryRecordBatch.checkForEarlyFinish
(RecordBatch.IterOutcome leftOutcome, RecordBatch.IterOutcome rightOutcome) Checks for the operator specific early terminal condition.protected void
AbstractUnaryRecordBatch.setLastKnownOutcome
(RecordBatch.IterOutcome outcome) Set's the outcome received with current input batch in processingprotected boolean
AbstractBinaryRecordBatch.verifyOutcomeToSetBatchState
(RecordBatch.IterOutcome leftOutcome, RecordBatch.IterOutcome rightOutcome) -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.store.drill.plugin