Modifier and Type | Method and Description |
---|---|
void |
Spool.read(RecordBatch batch) |
void |
Spool.write(RecordBatch batch) |
Modifier and Type | Method and Description |
---|---|
void |
ValueVectorHashHelper.Hash64.doSetup(RecordBatch incoming) |
abstract void |
ValueVectorHashHelper.Hash64Template.doSetup(RecordBatch incoming) |
Constructor and Description |
---|
ValueVectorHashHelper(RecordBatch recordBatch,
FragmentContext context) |
Modifier and Type | Method and Description |
---|---|
static void |
InterpreterEvaluator.evaluate(RecordBatch incoming,
ValueVector outVV,
LogicalExpression expr) |
Modifier and Type | Method and Description |
---|---|
void |
FragmentContext.requestMemory(RecordBatch requestor)
An operator is experiencing memory pressure.
|
void |
FragmentContextImpl.requestMemory(RecordBatch requestor) |
Modifier and Type | Method and Description |
---|---|
RecordBatch |
LateralContract.getIncoming()
Get reference to left side incoming of
LateralJoinBatch . |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
SchemalessBatchCreator.getBatch(ExecutorFragmentContext context,
SchemalessScan subScan,
List<RecordBatch> children) |
Modifier and Type | Class and Description |
---|---|
class |
ScanBatch
Record batch used for a particular scan.
|
class |
StatisticsWriterRecordBatch |
class |
WriterRecordBatch
Write the RecordBatch to the given RecordWriter.
|
Modifier and Type | Method and Description |
---|---|
protected RecordBatch |
ScreenCreator.ScreenRoot.getIncoming() |
RecordBatch |
ImplCreator.getRecordBatch(PhysicalOperator op,
ExecutorFragmentContext context)
Create a RecordBatch and its children for given PhysicalOperator
|
Modifier and Type | Method and Description |
---|---|
RecordBatch.IterOutcome |
BaseRootExec.next(RecordBatch b) |
Modifier and Type | Method and Description |
---|---|
MergingRecordBatch |
MergingReceiverCreator.getBatch(ExecutorFragmentContext context,
MergingReceiverPOP receiver,
List<RecordBatch> children) |
CloseableRecordBatch |
BatchCreator.getBatch(ExecutorFragmentContext context,
T config,
List<RecordBatch> children) |
RootExec |
ScreenCreator.getRoot(ExecutorFragmentContext context,
Screen config,
List<RecordBatch> children) |
RootExec |
SingleSenderCreator.getRoot(ExecutorFragmentContext context,
SingleSender config,
List<RecordBatch> children) |
RootExec |
RootCreator.getRoot(ExecutorFragmentContext context,
T config,
List<RecordBatch> children) |
Constructor and Description |
---|
ScreenRoot(RootFragmentContext context,
RecordBatch incoming,
Screen config) |
SingleSenderRootExec(RootFragmentContext context,
RecordBatch batch,
SingleSender config) |
StatisticsWriterRecordBatch(Writer writer,
RecordBatch incoming,
FragmentContext context,
StatisticsRecordWriter recordWriter) |
WriterRecordBatch(Writer writer,
RecordBatch incoming,
FragmentContext context,
RecordWriter recordWriter) |
Modifier and Type | Class and Description |
---|---|
class |
HashAggBatch |
class |
SpilledRecordBatch
Replaces "incoming" - instead scanning a spilled partition file
|
class |
StreamingAggBatch |
Modifier and Type | Field and Description |
---|---|
protected RecordBatch |
HashAggBatch.incoming |
protected RecordBatch |
StreamingAggBatch.incoming |
Modifier and Type | Method and Description |
---|---|
RecordBatch |
HashAggregator.getNewIncoming() |
RecordBatch |
HashAggTemplate.getNewIncoming()
get new incoming: (when reading spilled files like an "incoming")
|
Modifier and Type | Method and Description |
---|---|
abstract void |
HashAggTemplate.doSetup(RecordBatch incoming) |
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.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 |
StreamingAggregator.setup(OperatorContext context,
RecordBatch incoming,
StreamingAggBatch outgoing,
int outputRowCount) |
void |
StreamingAggTemplate.setup(OperatorContext context,
RecordBatch incoming,
StreamingAggBatch outgoing,
int outputRowCount) |
abstract void |
StreamingAggTemplate.setupInterior(RecordBatch incoming,
RecordBatch outgoing) |
void |
HashAggTemplate.BatchHolder.setupInterior(RecordBatch incoming,
RecordBatch outgoing,
VectorContainer aggrValuesContainer) |
Modifier and Type | Method and Description |
---|---|
HashAggBatch |
HashAggBatchCreator.getBatch(ExecutorFragmentContext context,
HashAggregate config,
List<RecordBatch> children) |
StreamingAggBatch |
StreamingAggBatchCreator.getBatch(ExecutorFragmentContext context,
StreamingAggregate config,
List<RecordBatch> children) |
Constructor and Description |
---|
HashAggBatch(HashAggregate popConfig,
RecordBatch incoming,
FragmentContext context) |
InternalBatch(RecordBatch incoming,
OperatorContext oContext) |
InternalBatch(RecordBatch incoming,
VectorWrapper<?>[] ignoreWrappers,
OperatorContext oContext) |
StreamingAggBatch(StreamingAggregate popConfig,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Method and Description |
---|---|
RootExec |
BroadcastSenderCreator.getRoot(ExecutorFragmentContext context,
BroadcastSender config,
List<RecordBatch> children) |
Constructor and Description |
---|
BroadcastSenderRootExec(RootFragmentContext context,
RecordBatch incoming,
BroadcastSender config) |
Constructor and Description |
---|
ChainedHashTable(HashTableConfig htConfig,
FragmentContext context,
BufferAllocator allocator,
RecordBatch incomingBuild,
RecordBatch incomingProbe,
RecordBatch outgoing) |
HashPartition(FragmentContext context,
BufferAllocator allocator,
ChainedHashTable baseHashTable,
RecordBatch buildBatch,
RecordBatch probeBatch,
boolean semiJoin,
int recordsPerBatch,
SpillSet spillSet,
int partNum,
int cycleNum,
int numPartitions) |
Modifier and Type | Class and Description |
---|---|
class |
FilterRecordBatch |
class |
RuntimeFilterRecordBatch
A RuntimeFilterRecordBatch steps over the ScanBatch.
|
Modifier and Type | Method and Description |
---|---|
void |
FilterSignature.doSetup(FragmentContextImpl context,
RecordBatch incoming,
RecordBatch outgoing) |
abstract void |
FilterTemplate2.doSetup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing) |
abstract void |
FilterTemplate4.doSetup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing) |
void |
Filterer.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
TransferPair[] transfers) |
void |
FilterTemplate2.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
TransferPair[] transfers) |
void |
FilterTemplate4.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
TransferPair[] transfers) |
Modifier and Type | Method and Description |
---|---|
FilterRecordBatch |
FilterBatchCreator.getBatch(ExecutorFragmentContext context,
Filter config,
List<RecordBatch> children) |
CloseableRecordBatch |
RuntimeFilterBatchCreator.getBatch(ExecutorFragmentContext context,
RuntimeFilterPOP config,
List<RecordBatch> children) |
Constructor and Description |
---|
FilterRecordBatch(Filter pop,
RecordBatch incoming,
FragmentContext context) |
RuntimeFilterRecordBatch(RuntimeFilterPOP pop,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Class and Description |
---|---|
class |
FlattenRecordBatch |
Modifier and Type | Method and Description |
---|---|
abstract void |
FlattenTemplate.doSetup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing) |
void |
Flattener.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
void |
FlattenTemplate.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
Modifier and Type | Method and Description |
---|---|
FlattenRecordBatch |
FlattenBatchCreator.getBatch(ExecutorFragmentContext context,
FlattenPOP config,
List<RecordBatch> children) |
Constructor and Description |
---|
FlattenRecordBatch(FlattenPOP pop,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Class and Description |
---|---|
class |
HashJoinBatch
Implements the runtime execution for the Hash-Join operator supporting INNER,
LEFT OUTER, RIGHT OUTER, and FULL OUTER joins
|
class |
LateralJoinBatch
RecordBatch implementation for the lateral join operator.
|
class |
MergeJoinBatch
A join operator that merges two sorted streams using a record iterator.
|
class |
NestedLoopJoinBatch |
class |
RowKeyJoinBatch |
Modifier and Type | Method and Description |
---|---|
RecordBatch |
LateralJoinBatch.getIncoming()
Returns the left side incoming for the Lateral Join.
|
Modifier and Type | Method and Description |
---|---|
BatchSizePredictor |
BatchSizePredictorImpl.Factory.create(RecordBatch batch,
double fragmentationFactor,
double safetyFactor) |
BatchSizePredictor |
BatchSizePredictor.Factory.create(RecordBatch batch,
double fragmentationFactor,
double safetyFactor)
Creates a predictor with a batch whose data needs to be used to predict other batch sizes.
|
void |
NestedLoopJoin.doSetup(FragmentContext context,
VectorContainer rightContainer,
RecordBatch leftBatch,
RecordBatch outgoing) |
abstract void |
NestedLoopJoinTemplate.doSetup(FragmentContext context,
VectorContainer rightContainer,
RecordBatch leftBatch,
RecordBatch outgoing) |
static long |
BatchSizePredictorImpl.getBatchSizeEstimate(RecordBatch recordBatch) |
void |
HashJoinMechanicalMemoryCalculator.MechanicalBuildSidePartitioning.initialize(boolean autoTune,
boolean reserveHash,
RecordBatch buildSideBatch,
RecordBatch probeSideBatch,
Set<String> joinColumns,
boolean probeEmpty,
long memoryAvailable,
int initialPartitions,
int recordsPerPartitionBatchBuild,
int recordsPerPartitionBatchProbe,
int maxBatchNumRecordsBuild,
int maxBatchNumRecordsProbe,
int outputBatchSize,
double loadFactor) |
void |
HashJoinMemoryCalculatorImpl.NoopBuildSidePartitioningImpl.initialize(boolean firstCycle,
boolean reserveHash,
RecordBatch buildSideBatch,
RecordBatch probeSideBatch,
Set<String> joinColumns,
boolean probeEmpty,
long memoryAvailable,
int initialPartitions,
int recordsPerPartitionBatchBuild,
int recordsPerPartitionBatchProbe,
int maxBatchNumRecordsBuild,
int maxBatchNumRecordsProbe,
int outputBatchSize,
double loadFactor) |
void |
HashJoinMemoryCalculatorImpl.BuildSidePartitioningImpl.initialize(boolean firstCycle,
boolean reserveHash,
RecordBatch buildBatch,
RecordBatch probeBatch,
Set<String> joinColumns,
boolean probeEmpty,
long memoryAvailable,
int initialPartitions,
int recordsPerPartitionBatchBuild,
int recordsPerPartitionBatchProbe,
int maxBatchNumRecordsBuild,
int maxBatchNumRecordsProbe,
int outputBatchSize,
double loadFactor) |
void |
HashJoinMemoryCalculator.BuildSidePartitioning.initialize(boolean firstCycle,
boolean reserveHash,
RecordBatch buildSideBatch,
RecordBatch probeSideBatch,
Set<String> joinColumns,
boolean probeEmpty,
long memoryAvailable,
int initialPartitions,
int recordsPerPartitionBatchBuild,
int recordsPerPartitionBatchProbe,
int maxBatchNumRecordsBuild,
int maxBatchNumRecordsProbe,
int outputBatchSize,
double loadFactor) |
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
|
void |
NestedLoopJoin.setupNestedLoopJoin(FragmentContext context,
RecordBatch left,
ExpandableHyperContainer rightContainer,
LinkedList<Integer> rightCounts,
NestedLoopJoinBatch outgoing) |
void |
NestedLoopJoinTemplate.setupNestedLoopJoin(FragmentContext context,
RecordBatch left,
ExpandableHyperContainer rightContainer,
LinkedList<Integer> rightCounts,
NestedLoopJoinBatch outgoing)
Method initializes necessary state and invokes the doSetup() to set the
input and output value vector references.
|
Modifier and Type | Method and Description |
---|---|
HashJoinBatch |
HashJoinBatchCreator.getBatch(ExecutorFragmentContext context,
HashJoinPOP config,
List<RecordBatch> children) |
LateralJoinBatch |
LateralJoinBatchCreator.getBatch(ExecutorFragmentContext context,
LateralJoinPOP config,
List<RecordBatch> children) |
MergeJoinBatch |
MergeJoinCreator.getBatch(ExecutorFragmentContext context,
MergeJoinPOP config,
List<RecordBatch> children) |
NestedLoopJoinBatch |
NestedLoopJoinBatchCreator.getBatch(ExecutorFragmentContext context,
NestedLoopJoinPOP config,
List<RecordBatch> children) |
RowKeyJoinBatch |
RowKeyJoinBatchCreator.getBatch(ExecutorFragmentContext context,
RowKeyJoinPOP config,
List<RecordBatch> children) |
Constructor and Description |
---|
BatchSizePredictorImpl(RecordBatch batch,
double fragmentationFactor,
double safetyFactor) |
HashJoinBatch(HashJoinPOP popConfig,
FragmentContext context,
RecordBatch left,
RecordBatch right)
The constructor
|
LateralJoinBatch(LateralJoinPOP popConfig,
FragmentContext context,
RecordBatch left,
RecordBatch right) |
MergeJoinBatch(MergeJoinPOP popConfig,
FragmentContext context,
RecordBatch left,
RecordBatch right) |
NestedLoopJoinBatch(NestedLoopJoinPOP popConfig,
FragmentContext context,
RecordBatch left,
RecordBatch right) |
RowKeyJoinBatch(RowKeyJoinPOP config,
FragmentContext context,
RecordBatch left,
RecordBatch right) |
Modifier and Type | Class and Description |
---|---|
class |
LimitRecordBatch |
class |
PartitionLimitRecordBatch
Helps to perform limit in a partition within a record batch.
|
Modifier and Type | Method and Description |
---|---|
LimitRecordBatch |
LimitBatchCreator.getBatch(ExecutorFragmentContext context,
Limit config,
List<RecordBatch> children) |
PartitionLimitRecordBatch |
PartitionLimitBatchCreator.getBatch(ExecutorFragmentContext context,
PartitionLimit config,
List<RecordBatch> children) |
Constructor and Description |
---|
LimitRecordBatch(Limit popConfig,
FragmentContext context,
RecordBatch incoming) |
PartitionLimitRecordBatch(PartitionLimit popConfig,
FragmentContext context,
RecordBatch incoming) |
Constructor and Description |
---|
VectorRecordMaterializer(FragmentContext context,
OperatorContext oContext,
RecordBatch batch) |
Modifier and Type | Class and Description |
---|---|
class |
MergingRecordBatch
Merges pre-sorted record batches from remote senders.
|
Modifier and Type | Class and Description |
---|---|
class |
MetadataControllerBatch
Terminal operator for producing ANALYZE statement.
|
class |
MetadataHandlerBatch
Responsible for handling metadata returned by incoming aggregate operators
and fetching required metadata form the Metastore.
|
class |
MetadataHashAggBatch |
class |
MetadataStreamAggBatch
Operator which adds aggregate calls for all incoming columns to calculate
required metadata and produces aggregations.
|
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
MetadataControllerBatchCreator.getBatch(ExecutorFragmentContext context,
MetadataControllerPOP config,
List<RecordBatch> children) |
CloseableRecordBatch |
MetadataHandlerBatchCreator.getBatch(ExecutorFragmentContext context,
MetadataHandlerPOP config,
List<RecordBatch> children) |
CloseableRecordBatch |
MetadataHashAggBatchCreator.getBatch(ExecutorFragmentContext context,
MetadataHashAggPOP config,
List<RecordBatch> children) |
CloseableRecordBatch |
MetadataStreamAggBatchCreator.getBatch(ExecutorFragmentContext context,
MetadataStreamAggPOP config,
List<RecordBatch> children) |
Constructor and Description |
---|
MetadataControllerBatch(MetadataControllerPOP popConfig,
FragmentContext context,
RecordBatch left,
RecordBatch right) |
MetadataHandlerBatch(MetadataHandlerPOP popConfig,
FragmentContext context,
RecordBatch incoming) |
MetadataHashAggBatch(MetadataHashAggPOP popConfig,
RecordBatch incoming,
FragmentContext context) |
MetadataStreamAggBatch(MetadataStreamAggPOP popConfig,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Class and Description |
---|---|
class |
OrderedPartitionRecordBatch
Generates an ordered partition, rather than a random hash partition.
|
Modifier and Type | Field and Description |
---|---|
protected RecordBatch |
OrderedPartitionRecordBatch.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 |
SampleSorter.setup(FragmentContext context,
RecordBatch hyperBatch) |
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) |
Modifier and Type | Method and Description |
---|---|
RootExec |
OrderedPartitionSenderCreator.getRoot(ExecutorFragmentContext context,
OrderedPartitionSender config,
List<RecordBatch> children) |
Constructor and Description |
---|
OrderedPartitionRecordBatch(OrderedPartitionSender pop,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Method and Description |
---|---|
abstract void |
PartitionerTemplate.doSetup(FragmentContext context,
RecordBatch incoming,
PartitionerTemplate.OutgoingRecordBatch[] outgoing) |
protected void |
PartitionerTemplate.OutgoingRecordBatch.doSetup(RecordBatch incoming,
VectorAccessible outgoing) |
void |
PartitionerDecorator.partitionBatch(RecordBatch incoming)
partitionBatch - decorator method to call real Partitioner(s) to process incoming batch
uses either threading or not threading approach based on number Partitioners
|
void |
Partitioner.partitionBatch(RecordBatch incoming) |
void |
PartitionerTemplate.partitionBatch(RecordBatch incoming) |
void |
Partitioner.setup(ExchangeFragmentContext context,
RecordBatch incoming,
HashPartitionSender popConfig,
OperatorStats stats,
OperatorContext oContext,
ClassGenerator<?> cg,
int start,
int count) |
void |
PartitionerTemplate.setup(ExchangeFragmentContext context,
RecordBatch incoming,
HashPartitionSender popConfig,
OperatorStats stats,
OperatorContext oContext,
ClassGenerator<?> cg,
int start,
int end) |
Modifier and Type | Method and Description |
---|---|
RootExec |
PartitionSenderCreator.getRoot(ExecutorFragmentContext context,
HashPartitionSender config,
List<RecordBatch> children) |
Constructor and Description |
---|
PartitionSenderRootExec(RootFragmentContext context,
RecordBatch incoming,
HashPartitionSender operator) |
PartitionSenderRootExec(RootFragmentContext context,
RecordBatch incoming,
HashPartitionSender operator,
boolean closeIncoming) |
Modifier and Type | Class and Description |
---|---|
class |
ProducerConsumerBatch |
Modifier and Type | Method and Description |
---|---|
ProducerConsumerBatch |
ProducerConsumerBatchCreator.getBatch(ExecutorFragmentContext context,
ProducerConsumer config,
List<RecordBatch> children) |
Constructor and Description |
---|
ProducerConsumerBatch(ProducerConsumer popConfig,
FragmentContext context,
RecordBatch incoming) |
Modifier and Type | Class and Description |
---|---|
class |
ProjectRecordBatch |
Modifier and Type | Method and Description |
---|---|
RecordBatch |
ProjectMemoryManager.incomingBatch() |
Modifier and Type | Method and Description |
---|---|
abstract void |
ProjectorTemplate.doSetup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing) |
void |
ProjectMemoryManager.init(RecordBatch incomingBatch,
ProjectRecordBatch outgoingBatch) |
int |
Projector.projectRecords(RecordBatch incomingBatch,
int startIndex,
int recordCount,
int firstOutputIndex) |
int |
ProjectorTemplate.projectRecords(RecordBatch incomingRecordBatch,
int startIndex,
int recordCount,
int firstOutputIndex) |
void |
Projector.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
void |
ProjectorTemplate.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
Modifier and Type | Method and Description |
---|---|
ProjectRecordBatch |
ComplexToJsonBatchCreator.getBatch(ExecutorFragmentContext context,
ComplexToJson flatten,
List<RecordBatch> children) |
ProjectRecordBatch |
ProjectBatchCreator.getBatch(ExecutorFragmentContext context,
Project config,
List<RecordBatch> children) |
Constructor and Description |
---|
ProjectBatchBuilder(ProjectRecordBatch projectBatch,
VectorContainer container,
SchemaChangeCallBack callBack,
RecordBatch incomingBatch) |
ProjectRecordBatch(Project pop,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Class and Description |
---|---|
class |
OperatorRecordBatch
Modular implementation of the standard Drill record batch iterator
protocol.
|
Modifier and Type | Method and Description |
---|---|
void |
IndirectContainerAccessor.addBatch(RecordBatch batch)
Add a record batch, performing schema checks and picking out a
selection vector, if provided.
|
Modifier and Type | Class and Description |
---|---|
class |
RangePartitionRecordBatch
Provides the ability to divide up the input rows into a fixed number of
separate ranges or 'buckets' based on the values of a set of columns (the
range partitioning columns).
|
Modifier and Type | Method and Description |
---|---|
RootExec |
RangePartitionSenderCreator.getRoot(ExecutorFragmentContext context,
RangePartitionSender config,
List<RecordBatch> children) |
Constructor and Description |
---|
RangePartitionRecordBatch(RangePartitionSender popConfig,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Class and Description |
---|---|
class |
SortBatch |
Modifier and Type | Method and Description |
---|---|
abstract void |
SortTemplate.doSetup(FragmentContext context,
VectorContainer incoming,
RecordBatch outgoing) |
Modifier and Type | Method and Description |
---|---|
SortBatch |
SortBatchCreator.getBatch(ExecutorFragmentContext context,
Sort config,
List<RecordBatch> children) |
Constructor and Description |
---|
SortBatch(Sort popConfig,
FragmentContext context,
RecordBatch incoming) |
Modifier and Type | Class and Description |
---|---|
class |
StatisticsAggBatch |
class |
StatisticsMergeBatch
Example input and output:
Schema of incoming batch:
|
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
StatisticsAggBatchCreator.getBatch(ExecutorFragmentContext context,
StatisticsAggregate config,
List<RecordBatch> children) |
CloseableRecordBatch |
StatisticsMergeBatchCreator.getBatch(ExecutorFragmentContext context,
StatisticsMerge config,
List<RecordBatch> children) |
Constructor and Description |
---|
StatisticsAggBatch(StatisticsAggregate popConfig,
RecordBatch incoming,
FragmentContext context) |
StatisticsMergeBatch(StatisticsMerge popConfig,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Class and Description |
---|---|
class |
RemovingRecordBatch |
Modifier and Type | Method and Description |
---|---|
static Copier |
GenericCopierFactory.createAndSetupCopier(RecordBatch incoming,
VectorContainer outputContainer,
SchemaChangeCallBack callBack) |
static Copier |
GenericCopierFactory.createAndSetupNonSVGenericCopier(RecordBatch incoming,
VectorContainer outputContainer) |
Modifier and Type | Method and Description |
---|---|
RemovingRecordBatch |
SVRemoverCreator.getBatch(ExecutorFragmentContext context,
SelectionVectorRemover config,
List<RecordBatch> children) |
Constructor and Description |
---|
GenericSV2Copier(RecordBatch incomingBatch,
VectorContainer outputContainer,
SchemaChangeCallBack callBack) |
GenericSV4Copier(RecordBatch incomingBatch,
VectorContainer outputContainer,
SchemaChangeCallBack callBack) |
RemovingRecordBatch(SelectionVectorRemover popConfig,
FragmentContext context,
RecordBatch incoming) |
StraightCopier(RecordBatch incomingBatch,
VectorContainer outputContainer,
SchemaChangeCallBack callBack) |
Modifier and Type | Class and Description |
---|---|
class |
TopNBatch
Operator Batch which implements the TopN functionality.
|
static class |
TopNBatch.SimpleSV4RecordBatch |
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.
|
Modifier and Type | Method and Description |
---|---|
TopNBatch |
TopNSortBatchCreator.getBatch(ExecutorFragmentContext context,
TopN config,
List<RecordBatch> children) |
Constructor and Description |
---|
TopNBatch(TopN popConfig,
FragmentContext context,
RecordBatch incoming) |
Modifier and Type | Class and Description |
---|---|
class |
TraceRecordBatch
Contains value vectors which are exactly the same
as the incoming record batch's value vectors.
|
Modifier and Type | Method and Description |
---|---|
TraceRecordBatch |
TraceBatchCreator.getBatch(ExecutorFragmentContext context,
Trace config,
List<RecordBatch> children) |
Constructor and Description |
---|
TraceRecordBatch(Trace pop,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Class and Description |
---|---|
class |
UnionAllRecordBatch |
Modifier and Type | Method and Description |
---|---|
abstract void |
UnionAllerTemplate.doSetup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing) |
void |
UnionAller.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
void |
UnionAllerTemplate.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
Modifier and Type | Method and Description |
---|---|
UnionAllRecordBatch |
UnionAllBatchCreator.getBatch(ExecutorFragmentContext context,
UnionAll config,
List<RecordBatch> children) |
Constructor and Description |
---|
UnionAllRecordBatch(UnionAll config,
List<RecordBatch> children,
FragmentContext context) |
Modifier and Type | Class and Description |
---|---|
class |
UnnestRecordBatch |
Modifier and Type | Method and Description |
---|---|
void |
UnnestImpl.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
void |
Unnest.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
Modifier and Type | Method and Description |
---|---|
UnnestRecordBatch |
UnnestBatchCreator.getBatch(ExecutorFragmentContext context,
UnnestPOP config,
List<RecordBatch> children) |
Modifier and Type | Class and Description |
---|---|
class |
UnorderedReceiverBatch |
Modifier and Type | Method and Description |
---|---|
UnorderedReceiverBatch |
UnorderedReceiverCreator.getBatch(ExecutorFragmentContext context,
UnorderedReceiver receiver,
List<RecordBatch> children) |
Modifier and Type | Class and Description |
---|---|
class |
UnpivotMapsRecordBatch
Unpivot maps.
|
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
UnpivotMapsBatchCreator.getBatch(ExecutorFragmentContext context,
UnpivotMaps config,
List<RecordBatch> children) |
Constructor and Description |
---|
UnpivotMapsRecordBatch(UnpivotMaps pop,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Class and Description |
---|---|
class |
IteratorValidatorBatchIterator |
Modifier and Type | Method and Description |
---|---|
RecordBatch |
IteratorValidatorBatchIterator.getIncoming() |
Modifier and Type | Method and Description |
---|---|
static boolean |
BatchValidator.validate(RecordBatch batch) |
Modifier and Type | Method and Description |
---|---|
IteratorValidatorBatchIterator |
IteratorValidatorCreator.getBatch(ExecutorFragmentContext context,
IteratorValidator config,
List<RecordBatch> children) |
Constructor and Description |
---|
IteratorValidatorBatchIterator(RecordBatch incoming) |
IteratorValidatorBatchIterator(RecordBatch incoming,
boolean isRepeatable) |
Modifier and Type | Method and Description |
---|---|
ScanBatch |
ValuesBatchCreator.getBatch(ExecutorFragmentContext context,
Values config,
List<RecordBatch> children) |
Modifier and Type | Class and Description |
---|---|
class |
WindowFrameRecordBatch
support for OVER(PARTITION BY expression1,expression2,...
|
Modifier and Type | Method and Description |
---|---|
WindowFrameRecordBatch |
WindowFrameBatchCreator.getBatch(ExecutorFragmentContext context,
WindowPOP config,
List<RecordBatch> children) |
Constructor and Description |
---|
WindowFrameRecordBatch(WindowPOP popConfig,
FragmentContext context,
RecordBatch incoming) |
Modifier and Type | Class and Description |
---|---|
class |
ExternalSortBatch
External sort batch: a sort batch which can spill to disk in
order to operate within a defined memory footprint.
|
Modifier and Type | Method and Description |
---|---|
abstract void |
SingleBatchSorterTemplate.doSetup(FragmentContext context,
VectorAccessible incoming,
RecordBatch outgoing) |
abstract void |
MSortTemplate.doSetup(FragmentContext context,
VectorContainer incoming,
RecordBatch outgoing) |
static void |
ExternalSortBatch.releaseBatches(RecordBatch incoming) |
static void |
ExternalSortBatch.retainSv4OnNone(RecordBatch incoming)
Workaround for DRILL-5656.
|
Modifier and Type | Method and Description |
---|---|
AbstractRecordBatch<ExternalSort> |
ExternalSortBatchCreator.getBatch(ExecutorFragmentContext context,
ExternalSort config,
List<RecordBatch> children) |
Constructor and Description |
---|
ExternalSortBatch(ExternalSort popConfig,
FragmentContext context,
RecordBatch incoming) |
Modifier and Type | Method and Description |
---|---|
static RowSet |
RowSets.wrap(RecordBatch batch) |
Modifier and Type | Interface and Description |
---|---|
interface |
CloseableRecordBatch |
Modifier and Type | Class and Description |
---|---|
class |
AbstractBinaryRecordBatch<T extends PhysicalOperator> |
class |
AbstractRecordBatch<T extends PhysicalOperator> |
class |
AbstractSingleRecordBatch<T extends PhysicalOperator>
Implements an AbstractUnaryRecordBatch where the incoming record batch is
known at the time of creation
|
class |
AbstractTableFunctionRecordBatch<T extends PhysicalOperator>
Implements AbstractUnaryRecodBatch for operators that do not have an incoming
record batch available at creation time; the input is typically set up a few
steps after creation.
|
class |
AbstractUnaryRecordBatch<T extends PhysicalOperator>
Base class for operators that have a single input.
|
class |
SchemalessBatch
Empty batch without schema and data.
|
class |
SimpleRecordBatch
Wrap a VectorContainer into a record batch.
|
Modifier and Type | Field and Description |
---|---|
protected RecordBatch |
AbstractSingleRecordBatch.incoming |
protected RecordBatch |
AbstractTableFunctionRecordBatch.incoming |
protected RecordBatch |
AbstractBinaryRecordBatch.left |
protected RecordBatch |
AbstractBinaryRecordBatch.right |
Modifier and Type | Method and Description |
---|---|
protected RecordBatch |
AbstractSingleRecordBatch.getIncoming() |
protected RecordBatch |
AbstractTableFunctionRecordBatch.getIncoming() |
protected abstract RecordBatch |
AbstractUnaryRecordBatch.getIncoming() |
Modifier and Type | Method and Description |
---|---|
static String |
TypedFieldId.getPath(TypedFieldId typeFieldId,
RecordBatch recordBatch)
Generates the full path to a field from the typefield ids
|
RecordBatch.IterOutcome |
AbstractRecordBatch.next(int inputIndex,
RecordBatch b) |
RecordBatch.IterOutcome |
AbstractRecordBatch.next(RecordBatch b) |
void |
AbstractTableFunctionRecordBatch.setIncoming(RecordBatch incoming) |
void |
TableFunctionContract.setIncoming(RecordBatch incoming)
sets the incoming record batch for the operator.
|
void |
RecordBatchMemoryManager.update(RecordBatch recordBatch) |
void |
RecordBatchMemoryManager.update(RecordBatch recordBatch,
int index) |
void |
JoinBatchMemoryManager.update(RecordBatch batch,
int inputIndex,
int outputPosition)
Update the memory manager parameters based on the given (incoming) batch (based on allocated sizes, not average row size)
|
void |
RecordBatchMemoryManager.update(RecordBatch batch,
int inputIndex,
int outputPosition) |
void |
JoinBatchMemoryManager.update(RecordBatch batch,
int inputIndex,
int outputPosition,
boolean useAggregate)
Update the memory manager parameters based on the given (incoming) batch
|
void |
RecordBatchMemoryManager.update(RecordBatch batch,
int inputIndex,
int outputPosition,
boolean useAggregate) |
Constructor and Description |
---|
AbstractBinaryRecordBatch(T popConfig,
FragmentContext context,
boolean buildSchema,
RecordBatch left,
RecordBatch right) |
AbstractBinaryRecordBatch(T popConfig,
FragmentContext context,
RecordBatch left,
RecordBatch right) |
AbstractSingleRecordBatch(T popConfig,
FragmentContext context,
RecordBatch incoming) |
JoinBatchMemoryManager(int outputBatchSize,
RecordBatch leftBatch,
RecordBatch rightBatch,
Set<String> excludedColumns) |
RecordBatchSizer(RecordBatch batch) |
RecordIterator(RecordBatch incoming,
AbstractRecordBatch<?> outgoing,
OperatorContext oContext,
int inputIndex,
boolean enableMarkAndReset,
RecordBatchMemoryManager callBack) |
RecordIterator(RecordBatch incoming,
AbstractRecordBatch<?> outgoing,
OperatorContext oContext,
int inputIndex,
RecordBatchMemoryManager callBack) |
Modifier and Type | Method and Description |
---|---|
void |
SelectionVector4Builder.add(RecordBatch batch,
boolean newSchema) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
EasyFormatPlugin.getWriterBatch(FragmentContext context,
RecordBatch incoming,
EasyWriter writer) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
EasyReaderBatchCreator.getBatch(ExecutorFragmentContext context,
EasySubScan config,
List<RecordBatch> children) |
CloseableRecordBatch |
EasyWriterBatchCreator.getBatch(ExecutorFragmentContext context,
EasyWriter config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
ScanBatch |
DirectBatchCreator.getBatch(ExecutorFragmentContext context,
DirectSubScan config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
DruidScanBatchCreator.getBatch(ExecutorFragmentContext context,
DruidSubScan subScan,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
EnumerableBatchCreator.getBatch(ExecutorFragmentContext context,
EnumerableSubScan subScan,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
ScanBatch |
HBaseScanBatchCreator.getBatch(ExecutorFragmentContext context,
HBaseSubScan subScan,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
HiveDrillNativeParquetScanBatchCreator.getBatch(ExecutorFragmentContext context,
HiveDrillNativeParquetRowGroupScan rowGroupScan,
List<RecordBatch> children) |
ScanBatch |
HiveScanBatchCreator.getBatch(ExecutorFragmentContext context,
HiveSubScan config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
HttpScanBatchCreator.getBatch(ExecutorFragmentContext context,
HttpSubScan subScan,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
IcebergScanBatchCreator.getBatch(ExecutorFragmentContext context,
IcebergSubScan subScan,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
ScanBatch |
InfoSchemaBatchCreator.getBatch(ExecutorFragmentContext context,
InfoSchemaSubScan config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
JdbcScanBatchCreator.getBatch(ExecutorFragmentContext context,
JdbcSubScan subScan,
List<RecordBatch> children) |
CloseableRecordBatch |
JdbcWriterBatchCreator.getBatch(ExecutorFragmentContext context,
JdbcWriter config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
KafkaScanBatchCreator.getBatch(ExecutorFragmentContext context,
KafkaSubScan subScan,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
ScanBatch |
KuduScanBatchCreator.getBatch(ExecutorFragmentContext context,
KuduSubScan subScan,
List<RecordBatch> children) |
CloseableRecordBatch |
KuduWriterBatchCreator.getBatch(ExecutorFragmentContext context,
KuduWriter config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
ScanBatch |
MapRDBScanBatchCreator.getBatch(ExecutorFragmentContext context,
MapRDBSubScan subScan,
List<RecordBatch> children) |
ScanBatch |
MapRDBRestrictedScanBatchCreator.getBatch(ExecutorFragmentContext context,
RestrictedMapRDBSubScan subScan,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
MockScanBatchCreator.getBatch(ExecutorFragmentContext context,
MockSubScanPOP config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
ScanBatch |
MongoScanBatchCreator.getBatch(ExecutorFragmentContext context,
MongoSubScan subScan,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
OpenTSDBBatchCreator.getBatch(ExecutorFragmentContext context,
OpenTSDBSubScan subScan,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
WriterRecordBatch |
ParquetFormatPlugin.getWriterBatch(FragmentContext context,
RecordBatch incoming,
ParquetWriter writer) |
Modifier and Type | Method and Description |
---|---|
ScanBatch |
ParquetScanBatchCreator.getBatch(ExecutorFragmentContext context,
ParquetRowGroupScan rowGroupScan,
List<RecordBatch> children) |
WriterRecordBatch |
ParquetWriterBatchCreator.getBatch(ExecutorFragmentContext context,
ParquetWriter config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
PhoenixScanBatchCreator.getBatch(ExecutorFragmentContext context,
PhoenixSubScan subScan,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
SplunkScanBatchCreator.getBatch(ExecutorFragmentContext context,
SplunkSubScan subScan,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
ScanBatch |
SystemTableBatchCreator.getBatch(ExecutorFragmentContext context,
SystemTableScan scan,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
static void |
RecordBatchStats.logRecordBatchStats(RecordBatchStats.RecordBatchIOType ioType,
RecordBatch recordBatch,
RecordBatchStats.RecordBatchStatsContext batchStatsContext) |
static void |
RecordBatchStats.logRecordBatchStats(RecordBatchStats.RecordBatchIOType ioType,
String sourceId,
RecordBatch recordBatch,
RecordBatchStats.RecordBatchStatsContext batchStatsContext) |
Modifier and Type | Method and Description |
---|---|
static void |
VectorValidator.validate(RecordBatch batch) |
Copyright © 1970 The Apache Software Foundation. All rights reserved.