Uses of Enum
org.apache.drill.exec.record.RecordBatch.IterOutcome
Packages that use 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
Methods in org.apache.drill.exec.physical.base that return RecordBatch.IterOutcomeModifier and TypeMethodDescriptionLateralContract.getLeftOutcome()Get the current outcome of left incoming batch. -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl
Methods in org.apache.drill.exec.physical.impl that return RecordBatch.IterOutcomeModifier and TypeMethodDescriptionStatisticsWriterRecordBatch.innerNext()WriterRecordBatch.innerNext()final RecordBatch.IterOutcomeBaseRootExec.next(RecordBatch b) ScanBatch.next() -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.aggregate
Methods in org.apache.drill.exec.physical.impl.aggregate that return RecordBatch.IterOutcomeModifier 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 fileMethods in org.apache.drill.exec.physical.impl.aggregate with parameters of type RecordBatch.IterOutcomeModifier and TypeMethodDescriptionStreamingAggregator.doWork(RecordBatch.IterOutcome outerOutcome) StreamingAggTemplate.doWork(RecordBatch.IterOutcome outerOutcome) -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.filter
Methods in org.apache.drill.exec.physical.impl.filter that return RecordBatch.IterOutcomeModifier and TypeMethodDescriptionprotected RecordBatch.IterOutcomeFilterRecordBatch.doWork()protected RecordBatch.IterOutcomeRuntimeFilterRecordBatch.doWork() -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.flatten
Methods in org.apache.drill.exec.physical.impl.flatten that return RecordBatch.IterOutcomeModifier and TypeMethodDescriptionprotected RecordBatch.IterOutcomeFlattenRecordBatch.doWork()FlattenRecordBatch.innerNext() -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.join
Methods in org.apache.drill.exec.physical.impl.join that return RecordBatch.IterOutcomeModifier 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.IterOutcomefor 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()Methods in org.apache.drill.exec.physical.impl.join with parameters of type RecordBatch.IterOutcomeModifier and TypeMethodDescriptionvoidHashJoinProbeTemplate.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) voidNestedLoopJoin.setupNestedLoopJoin(FragmentContext context, RecordBatch left, RecordBatch.IterOutcome leftOutcome, ExpandableHyperContainer rightContainer, LinkedList<Integer> rightCounts, NestedLoopJoinBatch outgoing) voidNestedLoopJoinTemplate.setupNestedLoopJoin(FragmentContext context, RecordBatch left, RecordBatch.IterOutcome leftOutcome, ExpandableHyperContainer rightContainer, LinkedList<Integer> rightCounts, NestedLoopJoinBatch outgoing) Method initializes necessary state and invokes the doSetup() to set the input and output value vector references. -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.limit
Methods in org.apache.drill.exec.physical.impl.limit that return RecordBatch.IterOutcomeModifier and TypeMethodDescriptionprotected RecordBatch.IterOutcomeLimitRecordBatch.doWork()protected RecordBatch.IterOutcomePartitionLimitRecordBatch.doWork()protected RecordBatch.IterOutcomeLimitRecordBatch.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.IterOutcomePartitionLimitRecordBatch.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
Methods in org.apache.drill.exec.physical.impl.mergereceiver that return RecordBatch.IterOutcome -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.metadata
Methods in org.apache.drill.exec.physical.impl.metadata that return RecordBatch.IterOutcome -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.orderedpartitioner
Methods in org.apache.drill.exec.physical.impl.orderedpartitioner that return RecordBatch.IterOutcome -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.producer
Methods in org.apache.drill.exec.physical.impl.producer that return RecordBatch.IterOutcome -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.project
Methods in org.apache.drill.exec.physical.impl.project that return RecordBatch.IterOutcomeModifier and TypeMethodDescriptionprotected RecordBatch.IterOutcomeProjectRecordBatch.doWork()protected RecordBatch.IterOutcomeProjectRecordBatch.getFinalOutcome(boolean hasMoreRecordInBoundary) protected RecordBatch.IterOutcomeProjectRecordBatch.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
Methods in org.apache.drill.exec.physical.impl.protocol that return RecordBatch.IterOutcome -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.rangepartitioner
Methods in org.apache.drill.exec.physical.impl.rangepartitioner that return RecordBatch.IterOutcomeModifier and TypeMethodDescriptionprotected RecordBatch.IterOutcomeRangePartitionRecordBatch.doWork() -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.setop
Methods in org.apache.drill.exec.physical.impl.setop with parameters of type RecordBatch.IterOutcomeModifier 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 RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.sort
Methods in org.apache.drill.exec.physical.impl.sort that return RecordBatch.IterOutcome -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.statistics
Methods in org.apache.drill.exec.physical.impl.statistics that return RecordBatch.IterOutcomeModifier and TypeMethodDescriptionprotected RecordBatch.IterOutcomeStatisticsMergeBatch.doWork()StatisticsMergeBatch.innerNext() -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.svremover
Methods in org.apache.drill.exec.physical.impl.svremover that return RecordBatch.IterOutcome -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.TopN
Methods in org.apache.drill.exec.physical.impl.TopN that return RecordBatch.IterOutcome -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.trace
Methods in org.apache.drill.exec.physical.impl.trace that return RecordBatch.IterOutcomeModifier and TypeMethodDescriptionprotected RecordBatch.IterOutcomeTraceRecordBatch.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
Methods in org.apache.drill.exec.physical.impl.union that return RecordBatch.IterOutcome -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.unnest
Methods in org.apache.drill.exec.physical.impl.unnest that return RecordBatch.IterOutcomeModifier and TypeMethodDescriptionprotected RecordBatch.IterOutcomeUnnestRecordBatch.doWork()UnnestRecordBatch.innerNext() -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.unorderedreceiver
Methods in org.apache.drill.exec.physical.impl.unorderedreceiver that return RecordBatch.IterOutcome -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.unpivot
Methods in org.apache.drill.exec.physical.impl.unpivot that return RecordBatch.IterOutcomeModifier and TypeMethodDescriptionprotected RecordBatch.IterOutcomeUnpivotMapsRecordBatch.doWork()UnpivotMapsRecordBatch.innerNext() -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.validate
Methods in org.apache.drill.exec.physical.impl.validate that return RecordBatch.IterOutcome -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.physical.impl.window
Methods in org.apache.drill.exec.physical.impl.window that return RecordBatch.IterOutcomeModifier 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
Methods in org.apache.drill.exec.physical.impl.xsort that return RecordBatch.IterOutcomeModifier and TypeMethodDescriptionExternalSortBatch.innerNext()Process each request for a batch.Methods in org.apache.drill.exec.physical.impl.xsort with parameters of type RecordBatch.IterOutcomeModifier and TypeMethodDescriptionvoidMergeSortWrapper.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) -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.record
Fields in org.apache.drill.exec.record declared as RecordBatch.IterOutcomeModifier and TypeFieldDescriptionprotected RecordBatch.IterOutcomeAbstractBinaryRecordBatch.leftUpstreamprotected RecordBatch.IterOutcomeAbstractBinaryRecordBatch.rightUpstreamMethods in org.apache.drill.exec.record that return RecordBatch.IterOutcomeModifier and TypeMethodDescriptionprotected abstract RecordBatch.IterOutcomeAbstractUnaryRecordBatch.doWork()protected RecordBatch.IterOutcomeAbstractSingleRecordBatch.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.IterOutcomeAbstractUnaryRecordBatch.getLastKnownOutcome()RecordIterator.getLastOutcome()protected RecordBatch.IterOutcomeAbstractUnaryRecordBatch.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.IterOutcomeAbstractRecordBatch.innerNext()AbstractUnaryRecordBatch.innerNext()final RecordBatch.IterOutcomeAbstractRecordBatch.next()final RecordBatch.IterOutcomeAbstractRecordBatch.next(int inputIndex, RecordBatch b) final RecordBatch.IterOutcomeAbstractRecordBatch.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.IterOutcomeReturns 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.Methods in org.apache.drill.exec.record with parameters of type RecordBatch.IterOutcomeModifier and TypeMethodDescriptionprotected booleanAbstractBinaryRecordBatch.checkForEarlyFinish(RecordBatch.IterOutcome leftOutcome, RecordBatch.IterOutcome rightOutcome) Checks for the operator specific early terminal condition.protected voidAbstractUnaryRecordBatch.setLastKnownOutcome(RecordBatch.IterOutcome outcome) Set's the outcome received with current input batch in processingprotected booleanAbstractBinaryRecordBatch.verifyOutcomeToSetBatchState(RecordBatch.IterOutcome leftOutcome, RecordBatch.IterOutcome rightOutcome) -
Uses of RecordBatch.IterOutcome in org.apache.drill.exec.store.drill.plugin
Methods in org.apache.drill.exec.store.drill.plugin that return RecordBatch.IterOutcome