Modifier and Type | Method and Description |
---|---|
RecordBatch.IterOutcome |
LateralContract.getLeftOutcome()
Get the current outcome of left incoming batch.
|
Modifier and Type | Method and Description |
---|---|
RecordBatch.IterOutcome |
StatisticsWriterRecordBatch.innerNext() |
RecordBatch.IterOutcome |
WriterRecordBatch.innerNext() |
RecordBatch.IterOutcome |
ScanBatch.next() |
RecordBatch.IterOutcome |
BaseRootExec.next(RecordBatch b) |
Modifier and Type | Method and Description |
---|---|
RecordBatch.IterOutcome |
SpilledRecordBatch.getInitialOutcome()
Return the initial outcome (from the first next() call )
|
RecordBatch.IterOutcome |
HashAggregator.getOutcome() |
RecordBatch.IterOutcome |
HashAggTemplate.getOutcome() |
RecordBatch.IterOutcome |
StreamingAggregator.getOutcome() |
RecordBatch.IterOutcome |
StreamingAggTemplate.getOutcome() |
RecordBatch.IterOutcome |
HashAggBatch.innerNext() |
RecordBatch.IterOutcome |
StreamingAggBatch.innerNext() |
RecordBatch.IterOutcome |
BatchIterator.next() |
RecordBatch.IterOutcome |
SpilledRecordBatch.next()
Read the next batch from the spill file
|
Modifier and Type | Method and Description |
---|---|
StreamingAggregator.AggOutcome |
StreamingAggregator.doWork(RecordBatch.IterOutcome outerOutcome) |
StreamingAggregator.AggOutcome |
StreamingAggTemplate.doWork(RecordBatch.IterOutcome outerOutcome) |
Modifier and Type | Method and Description |
---|---|
protected RecordBatch.IterOutcome |
FilterRecordBatch.doWork() |
protected RecordBatch.IterOutcome |
RuntimeFilterRecordBatch.doWork() |
Modifier and Type | Method and Description |
---|---|
protected RecordBatch.IterOutcome |
FlattenRecordBatch.doWork() |
RecordBatch.IterOutcome |
FlattenRecordBatch.innerNext() |
Modifier and Type | Method and Description |
---|---|
RecordBatch.IterOutcome |
HashJoinBatch.executeBuildPhase()
Execute the BUILD phase; first read incoming and split rows into
partitions; may decide to spill some of the partitions
|
RecordBatch.IterOutcome |
LateralJoinBatch.getLeftOutcome()
Returns the current
RecordBatch.IterOutcome for the left incoming batch |
RecordBatch.IterOutcome |
JoinStatus.getLeftStatus() |
RecordBatch.IterOutcome |
JoinStatus.getRightStatus() |
RecordBatch.IterOutcome |
LateralJoinBatch.innerNext()
Gets the left and right incoming batch and produce the output batch.
|
RecordBatch.IterOutcome |
NestedLoopJoinBatch.innerNext()
Method drains the right side input of the NLJ and accumulates the data
in a hyper container.
|
RecordBatch.IterOutcome |
RowKeyJoinBatch.innerNext() |
RecordBatch.IterOutcome |
HashJoinBatch.innerNext() |
RecordBatch.IterOutcome |
MergeJoinBatch.innerNext() |
Modifier and Type | Method and Description |
---|---|
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 |
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
|
Modifier and Type | Method and Description |
---|---|
protected 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.
|
RecordBatch.IterOutcome |
LimitRecordBatch.innerNext() |
Modifier and Type | Method and Description |
---|---|
RecordBatch.IterOutcome |
MergingRecordBatch.innerNext() |
Modifier and Type | Method and Description |
---|---|
RecordBatch.IterOutcome |
MetadataHandlerBatch.doWork() |
RecordBatch.IterOutcome |
MetadataControllerBatch.innerNext() |
RecordBatch.IterOutcome |
MetadataHandlerBatch.innerNext() |
Modifier and Type | Method and Description |
---|---|
RecordBatch.IterOutcome |
OrderedPartitionRecordBatch.innerNext() |
Modifier and Type | Method and Description |
---|---|
RecordBatch.IterOutcome |
ProducerConsumerBatch.innerNext() |
Modifier and Type | Method and Description |
---|---|
protected 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.
|
RecordBatch.IterOutcome |
ProjectRecordBatch.innerNext() |
Modifier and Type | Method and Description |
---|---|
RecordBatch.IterOutcome |
OperatorDriver.next()
Get the next batch.
|
RecordBatch.IterOutcome |
OperatorRecordBatch.next() |
Modifier and Type | Method and Description |
---|---|
protected RecordBatch.IterOutcome |
RangePartitionRecordBatch.doWork() |
Modifier and Type | Method and Description |
---|---|
RecordBatch.IterOutcome |
SortBatch.innerNext() |
Modifier and Type | Method and Description |
---|---|
protected RecordBatch.IterOutcome |
StatisticsMergeBatch.doWork() |
RecordBatch.IterOutcome |
StatisticsMergeBatch.innerNext() |
Modifier and Type | Method and Description |
---|---|
protected RecordBatch.IterOutcome |
RemovingRecordBatch.doWork() |
Modifier and Type | Method and Description |
---|---|
RecordBatch.IterOutcome |
TopNBatch.innerNext() |
Modifier and Type | Method and Description |
---|---|
protected 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.
|
Modifier and Type | Method and Description |
---|---|
RecordBatch.IterOutcome |
UnionAllRecordBatch.innerNext() |
Modifier and Type | Method and Description |
---|---|
protected RecordBatch.IterOutcome |
UnnestRecordBatch.doWork() |
RecordBatch.IterOutcome |
UnnestRecordBatch.innerNext() |
Modifier and Type | Method and Description |
---|---|
RecordBatch.IterOutcome |
UnorderedReceiverBatch.next() |
Modifier and Type | Method and Description |
---|---|
protected RecordBatch.IterOutcome |
UnpivotMapsRecordBatch.doWork() |
RecordBatch.IterOutcome |
UnpivotMapsRecordBatch.innerNext() |
Modifier and Type | Method and Description |
---|---|
RecordBatch.IterOutcome |
IteratorValidatorBatchIterator.next() |
Modifier and Type | Method and Description |
---|---|
RecordBatch.IterOutcome |
WindowFrameRecordBatch.innerNext()
Hold incoming batches in memory until all window functions are ready to
process the batch on top of the queue
|
Modifier and Type | Method and Description |
---|---|
RecordBatch.IterOutcome |
ExternalSortBatch.innerNext()
Process each request for a batch.
|
Modifier and Type | Method and Description |
---|---|
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.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) |
Modifier and Type | Field and Description |
---|---|
protected RecordBatch.IterOutcome |
AbstractBinaryRecordBatch.leftUpstream |
protected RecordBatch.IterOutcome |
AbstractBinaryRecordBatch.rightUpstream |
Modifier and Type | Method and Description |
---|---|
protected 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() |
RecordBatch.IterOutcome |
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.
|
RecordBatch.IterOutcome |
AbstractUnaryRecordBatch.innerNext() |
abstract RecordBatch.IterOutcome |
AbstractRecordBatch.innerNext() |
RecordBatch.IterOutcome |
RecordBatch.next()
Updates the data in each Field reading interface for the next range of
records.
|
RecordBatch.IterOutcome |
RecordIterator.next()
Move iterator to next record.
|
RecordBatch.IterOutcome |
SchemalessBatch.next() |
RecordBatch.IterOutcome |
SimpleRecordBatch.next() |
RecordBatch.IterOutcome |
AbstractRecordBatch.next() |
RecordBatch.IterOutcome |
AbstractRecordBatch.next(int inputIndex,
RecordBatch b) |
RecordBatch.IterOutcome |
AbstractRecordBatch.next(RecordBatch b) |
static RecordBatch.IterOutcome |
RecordBatch.IterOutcome.valueOf(String name)
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 Type | Method and Description |
---|---|
protected 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 processing
|
protected boolean |
AbstractBinaryRecordBatch.verifyOutcomeToSetBatchState(RecordBatch.IterOutcome leftOutcome,
RecordBatch.IterOutcome rightOutcome) |
Copyright © 1970 The Apache Software Foundation. All rights reserved.