Uses of Interface
org.apache.drill.exec.record.RecordBatch
Packages that use RecordBatch
Package
Description
Interface for Drill's interaction with the local disk to persist data
temporarily during an operation.
Defines a revised implementation of the Drill RecordBatch protocol.
Provides a set of tools to work with row sets.
Drill storage plugin.
Kafka storage plugin.
Defines a mock data source which generates dummy test data for use
in testing.
MongoDB storage plugin.
-
Uses of RecordBatch in org.apache.drill.exec.disk
Methods in org.apache.drill.exec.disk with parameters of type RecordBatchModifier and TypeMethodDescriptionvoid
Spool.read
(RecordBatch batch) void
Spool.write
(RecordBatch batch) -
Uses of RecordBatch in org.apache.drill.exec.expr.fn.impl
Methods in org.apache.drill.exec.expr.fn.impl with parameters of type RecordBatchModifier and TypeMethodDescriptionvoid
ValueVectorHashHelper.Hash64.doSetup
(RecordBatch incoming) abstract void
ValueVectorHashHelper.Hash64Template.doSetup
(RecordBatch incoming) Constructors in org.apache.drill.exec.expr.fn.impl with parameters of type RecordBatchModifierConstructorDescriptionValueVectorHashHelper
(RecordBatch recordBatch, FragmentContext context) -
Uses of RecordBatch in org.apache.drill.exec.expr.fn.interpreter
Methods in org.apache.drill.exec.expr.fn.interpreter with parameters of type RecordBatchModifier and TypeMethodDescriptionstatic void
InterpreterEvaluator.evaluate
(RecordBatch incoming, ValueVector outVV, LogicalExpression expr) -
Uses of RecordBatch in org.apache.drill.exec.ops
Methods in org.apache.drill.exec.ops with parameters of type RecordBatchModifier and TypeMethodDescriptionvoid
FragmentContext.requestMemory
(RecordBatch requestor) An operator is experiencing memory pressure.void
FragmentContextImpl.requestMemory
(RecordBatch requestor) -
Uses of RecordBatch in org.apache.drill.exec.physical.base
Methods in org.apache.drill.exec.physical.base that return RecordBatchModifier and TypeMethodDescriptionLateralContract.getIncoming()
Get reference to left side incoming ofLateralJoinBatch
.Method parameters in org.apache.drill.exec.physical.base with type arguments of type RecordBatchModifier and TypeMethodDescriptionSchemalessBatchCreator.getBatch
(ExecutorFragmentContext context, SchemalessScan subScan, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl
Classes in org.apache.drill.exec.physical.impl that implement RecordBatchModifier and TypeClassDescriptionclass
class
Record batch used for a particular scan.class
class
Write the RecordBatch to the given RecordWriter.Methods in org.apache.drill.exec.physical.impl that return RecordBatchModifier and TypeMethodDescriptionprotected RecordBatch
ScreenCreator.ScreenRoot.getIncoming()
ImplCreator.getRecordBatch
(PhysicalOperator op, ExecutorFragmentContext context) Create a RecordBatch and its children for given PhysicalOperatorMethods in org.apache.drill.exec.physical.impl with parameters of type RecordBatchMethod parameters in org.apache.drill.exec.physical.impl with type arguments of type RecordBatchModifier and TypeMethodDescriptionBatchCreator.getBatch
(ExecutorFragmentContext context, T config, List<RecordBatch> children) MergingReceiverCreator.getBatch
(ExecutorFragmentContext context, MergingReceiverPOP receiver, List<RecordBatch> children) RootCreator.getRoot
(ExecutorFragmentContext context, T config, List<RecordBatch> children) ScreenCreator.getRoot
(ExecutorFragmentContext context, Screen config, List<RecordBatch> children) SingleSenderCreator.getRoot
(ExecutorFragmentContext context, SingleSender config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl with parameters of type RecordBatchModifierConstructorDescriptionInsertWriterRecordBatch
(Writer writer, RecordBatch incoming, FragmentContext context, RecordWriter recordWriter) 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) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.aggregate
Classes in org.apache.drill.exec.physical.impl.aggregate that implement RecordBatchModifier and TypeClassDescriptionclass
class
Replaces "incoming" - instead scanning a spilled partition fileclass
Fields in org.apache.drill.exec.physical.impl.aggregate declared as RecordBatchModifier and TypeFieldDescriptionprotected RecordBatch
HashAggBatch.incoming
protected final RecordBatch
StreamingAggBatch.incoming
Methods in org.apache.drill.exec.physical.impl.aggregate that return RecordBatchModifier and TypeMethodDescriptionHashAggregator.getNewIncoming()
HashAggTemplate.getNewIncoming()
get new incoming: (when reading spilled files like an "incoming")Methods in org.apache.drill.exec.physical.impl.aggregate with parameters of type RecordBatchModifier and TypeMethodDescriptionabstract 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) void
HashAggTemplate.BatchHolder.setupInterior
(RecordBatch incoming, RecordBatch outgoing, VectorContainer aggrValuesContainer) abstract void
StreamingAggTemplate.setupInterior
(RecordBatch incoming, RecordBatch outgoing) Method parameters in org.apache.drill.exec.physical.impl.aggregate with type arguments of type RecordBatchModifier and TypeMethodDescriptionHashAggBatchCreator.getBatch
(ExecutorFragmentContext context, HashAggregate config, List<RecordBatch> children) StreamingAggBatchCreator.getBatch
(ExecutorFragmentContext context, StreamingAggregate config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.aggregate with parameters of type RecordBatchModifierConstructorDescriptionHashAggBatch
(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) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.broadcastsender
Method parameters in org.apache.drill.exec.physical.impl.broadcastsender with type arguments of type RecordBatchModifier and TypeMethodDescriptionBroadcastSenderCreator.getRoot
(ExecutorFragmentContext context, BroadcastSender config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.broadcastsender with parameters of type RecordBatchModifierConstructorDescriptionBroadcastSenderRootExec
(RootFragmentContext context, RecordBatch incoming, BroadcastSender config) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.common
Methods in org.apache.drill.exec.physical.impl.common with parameters of type RecordBatchModifier and TypeMethodDescriptionprotected abstract void
HashTableTemplate.doSetup
(VectorContainer incomingBuild, RecordBatch incomingProbe) 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 theHashTable
.void
HashTableTemplate.setup
(HashTableConfig htConfig, BufferAllocator allocator, VectorContainer incomingBuild, RecordBatch incomingProbe, RecordBatch outgoing, VectorContainer htContainerOrig, FragmentContext context, ClassGenerator<?> cg) protected void
HashTableTemplate.BatchHolder.setupInterior
(VectorContainer incomingBuild, RecordBatch incomingProbe, RecordBatch outgoing, VectorContainer htContainer) void
ChainedHashTable.updateIncoming
(RecordBatch incomingBuild, RecordBatch incomingProbe) void
HashTable.updateIncoming
(VectorContainer newIncoming, RecordBatch newIncomingProbe) Changes the incoming probe and build side batches, and then updates all the value vector references in theHashTableTemplate.BatchHolder
s.void
HashTableTemplate.updateIncoming
(VectorContainer newIncoming, RecordBatch newIncomingProbe) Constructors in org.apache.drill.exec.physical.impl.common with parameters of type RecordBatchModifierConstructorDescriptionChainedHashTable
(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) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.filter
Classes in org.apache.drill.exec.physical.impl.filter that implement RecordBatchModifier and TypeClassDescriptionclass
class
A RuntimeFilterRecordBatch steps over the ScanBatch.Methods in org.apache.drill.exec.physical.impl.filter with parameters of type RecordBatchModifier and TypeMethodDescriptionvoid
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) Method parameters in org.apache.drill.exec.physical.impl.filter with type arguments of type RecordBatchModifier and TypeMethodDescriptionFilterBatchCreator.getBatch
(ExecutorFragmentContext context, Filter config, List<RecordBatch> children) RuntimeFilterBatchCreator.getBatch
(ExecutorFragmentContext context, RuntimeFilterPOP config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.filter with parameters of type RecordBatchModifierConstructorDescriptionFilterRecordBatch
(Filter pop, RecordBatch incoming, FragmentContext context) RuntimeFilterRecordBatch
(RuntimeFilterPOP pop, RecordBatch incoming, FragmentContext context) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.flatten
Classes in org.apache.drill.exec.physical.impl.flatten that implement RecordBatchMethods in org.apache.drill.exec.physical.impl.flatten with parameters of type RecordBatchModifier and TypeMethodDescriptionabstract void
FlattenTemplate.doSetup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) void
Flattener.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final void
FlattenTemplate.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) Method parameters in org.apache.drill.exec.physical.impl.flatten with type arguments of type RecordBatchModifier and TypeMethodDescriptionFlattenBatchCreator.getBatch
(ExecutorFragmentContext context, FlattenPOP config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.flatten with parameters of type RecordBatchModifierConstructorDescriptionFlattenRecordBatch
(FlattenPOP pop, RecordBatch incoming, FragmentContext context) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.join
Classes in org.apache.drill.exec.physical.impl.join that implement RecordBatchModifier and TypeClassDescriptionclass
AbstractHashBinaryRecordBatch<T extends PhysicalOperator>
Base class for the runtime execution implementation of the Hash-Join and Hash-SetOp operatorclass
Implements the runtime execution for the Hash-Join operator supporting INNER, LEFT OUTER, RIGHT OUTER, and FULL OUTER joinsclass
RecordBatch implementation for the lateral join operator.class
A join operator that merges two sorted streams using a record iterator.class
class
Fields in org.apache.drill.exec.physical.impl.join declared as RecordBatchModifier and TypeFieldDescriptionprotected RecordBatch
AbstractHashBinaryRecordBatch.buildBatch
protected RecordBatch
AbstractHashBinaryRecordBatch.probeBatch
protected RecordBatch
ProbeTemplate.probeBatch
Methods in org.apache.drill.exec.physical.impl.join that return RecordBatchModifier and TypeMethodDescriptionLateralJoinBatch.getIncoming()
Returns the left side incoming for the Lateral Join.Methods in org.apache.drill.exec.physical.impl.join with parameters of type RecordBatchModifier and TypeMethodDescriptionBatchSizePredictor.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.BatchSizePredictorImpl.Factory.create
(RecordBatch batch, double fragmentationFactor, double safetyFactor) 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
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
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
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
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) 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.Method parameters in org.apache.drill.exec.physical.impl.join with type arguments of type RecordBatchModifier and TypeMethodDescriptionHashJoinBatchCreator.getBatch
(ExecutorFragmentContext context, HashJoinPOP config, List<RecordBatch> children) LateralJoinBatchCreator.getBatch
(ExecutorFragmentContext context, LateralJoinPOP config, List<RecordBatch> children) MergeJoinCreator.getBatch
(ExecutorFragmentContext context, MergeJoinPOP config, List<RecordBatch> children) NestedLoopJoinBatchCreator.getBatch
(ExecutorFragmentContext context, NestedLoopJoinPOP config, List<RecordBatch> children) RowKeyJoinBatchCreator.getBatch
(ExecutorFragmentContext context, RowKeyJoinPOP config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.join with parameters of type RecordBatchModifierConstructorDescriptionAbstractHashBinaryRecordBatch
(T popConfig, FragmentContext context, RecordBatch left, RecordBatch right) The constructorBatchSizePredictorImpl
(RecordBatch batch, double fragmentationFactor, double safetyFactor) HashJoinBatch
(HashJoinPOP popConfig, FragmentContext context, RecordBatch left, RecordBatch right) The constructorLateralJoinBatch
(LateralJoinPOP popConfig, FragmentContext context, RecordBatch left, RecordBatch right) protected
MergeJoinBatch
(MergeJoinPOP popConfig, FragmentContext context, RecordBatch left, RecordBatch right) protected
NestedLoopJoinBatch
(NestedLoopJoinPOP popConfig, FragmentContext context, RecordBatch left, RecordBatch right) RowKeyJoinBatch
(RowKeyJoinPOP config, FragmentContext context, RecordBatch left, RecordBatch right) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.limit
Classes in org.apache.drill.exec.physical.impl.limit that implement RecordBatchModifier and TypeClassDescriptionclass
class
Helps to perform limit in a partition within a record batch.Method parameters in org.apache.drill.exec.physical.impl.limit with type arguments of type RecordBatchModifier and TypeMethodDescriptionLimitBatchCreator.getBatch
(ExecutorFragmentContext context, Limit config, List<RecordBatch> children) PartitionLimitBatchCreator.getBatch
(ExecutorFragmentContext context, PartitionLimit config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.limit with parameters of type RecordBatchModifierConstructorDescriptionLimitRecordBatch
(Limit popConfig, FragmentContext context, RecordBatch incoming) PartitionLimitRecordBatch
(PartitionLimit popConfig, FragmentContext context, RecordBatch incoming) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.materialize
Constructors in org.apache.drill.exec.physical.impl.materialize with parameters of type RecordBatchModifierConstructorDescriptionVectorRecordMaterializer
(FragmentContext context, OperatorContext oContext, RecordBatch batch) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.mergereceiver
Classes in org.apache.drill.exec.physical.impl.mergereceiver that implement RecordBatchModifier and TypeClassDescriptionclass
Merges pre-sorted record batches from remote senders. -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.metadata
Classes in org.apache.drill.exec.physical.impl.metadata that implement RecordBatchModifier and TypeClassDescriptionclass
Terminal operator for producing ANALYZE statement.class
Responsible for handling metadata returned by incoming aggregate operators and fetching required metadata form the Metastore.class
class
Operator which adds aggregate calls for all incoming columns to calculate required metadata and produces aggregations.Method parameters in org.apache.drill.exec.physical.impl.metadata with type arguments of type RecordBatchModifier and TypeMethodDescriptionMetadataControllerBatchCreator.getBatch
(ExecutorFragmentContext context, MetadataControllerPOP config, List<RecordBatch> children) MetadataHandlerBatchCreator.getBatch
(ExecutorFragmentContext context, MetadataHandlerPOP config, List<RecordBatch> children) MetadataHashAggBatchCreator.getBatch
(ExecutorFragmentContext context, MetadataHashAggPOP config, List<RecordBatch> children) MetadataStreamAggBatchCreator.getBatch
(ExecutorFragmentContext context, MetadataStreamAggPOP config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.metadata with parameters of type RecordBatchModifierConstructorDescriptionprotected
MetadataControllerBatch
(MetadataControllerPOP popConfig, FragmentContext context, RecordBatch left, RecordBatch right) protected
MetadataHandlerBatch
(MetadataHandlerPOP popConfig, FragmentContext context, RecordBatch incoming) MetadataHashAggBatch
(MetadataHashAggPOP popConfig, RecordBatch incoming, FragmentContext context) MetadataStreamAggBatch
(MetadataStreamAggPOP popConfig, RecordBatch incoming, FragmentContext context) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.orderedpartitioner
Classes in org.apache.drill.exec.physical.impl.orderedpartitioner that implement RecordBatchModifier and TypeClassDescriptionclass
Generates an ordered partition, rather than a random hash partition.Fields in org.apache.drill.exec.physical.impl.orderedpartitioner declared as RecordBatchModifier and TypeFieldDescriptionprotected final RecordBatch
OrderedPartitionRecordBatch.incoming
Methods in org.apache.drill.exec.physical.impl.orderedpartitioner with parameters of type RecordBatchModifier and TypeMethodDescriptionabstract 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) final void
OrderedPartitionProjectorTemplate.setup
(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, List<TransferPair> transfers, VectorContainer partitionVectors, int partitions, SchemaPath outputField) void
SampleSorter.setup
(FragmentContext context, RecordBatch hyperBatch) Method parameters in org.apache.drill.exec.physical.impl.orderedpartitioner with type arguments of type RecordBatchModifier and TypeMethodDescriptionOrderedPartitionSenderCreator.getRoot
(ExecutorFragmentContext context, OrderedPartitionSender config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.orderedpartitioner with parameters of type RecordBatchModifierConstructorDescriptionOrderedPartitionRecordBatch
(OrderedPartitionSender pop, RecordBatch incoming, FragmentContext context) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.partitionsender
Methods in org.apache.drill.exec.physical.impl.partitionsender with parameters of type RecordBatchModifier and TypeMethodDescriptionabstract void
PartitionerTemplate.doSetup
(FragmentContext context, RecordBatch incoming, PartitionerTemplate.OutgoingRecordBatch[] outgoing) protected void
PartitionerTemplate.OutgoingRecordBatch.doSetup
(RecordBatch incoming, VectorAccessible outgoing) void
Partitioner.partitionBatch
(RecordBatch incoming) 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 Partitionersvoid
PartitionerTemplate.partitionBatch
(RecordBatch incoming) void
Partitioner.setup
(ExchangeFragmentContext context, RecordBatch incoming, HashPartitionSender popConfig, OperatorStats stats, OperatorContext oContext, ClassGenerator<?> cg, int start, int count) final void
PartitionerTemplate.setup
(ExchangeFragmentContext context, RecordBatch incoming, HashPartitionSender popConfig, OperatorStats stats, OperatorContext oContext, ClassGenerator<?> cg, int start, int end) Method parameters in org.apache.drill.exec.physical.impl.partitionsender with type arguments of type RecordBatchModifier and TypeMethodDescriptionPartitionSenderCreator.getRoot
(ExecutorFragmentContext context, HashPartitionSender config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.partitionsender with parameters of type RecordBatchModifierConstructorDescriptionPartitionSenderRootExec
(RootFragmentContext context, RecordBatch incoming, HashPartitionSender operator) PartitionSenderRootExec
(RootFragmentContext context, RecordBatch incoming, HashPartitionSender operator, boolean closeIncoming) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.producer
Classes in org.apache.drill.exec.physical.impl.producer that implement RecordBatchMethod parameters in org.apache.drill.exec.physical.impl.producer with type arguments of type RecordBatchModifier and TypeMethodDescriptionProducerConsumerBatchCreator.getBatch
(ExecutorFragmentContext context, ProducerConsumer config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.producer with parameters of type RecordBatchModifierConstructorDescriptionprotected
ProducerConsumerBatch
(ProducerConsumer popConfig, FragmentContext context, RecordBatch incoming) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.project
Classes in org.apache.drill.exec.physical.impl.project that implement RecordBatchMethods in org.apache.drill.exec.physical.impl.project that return RecordBatchMethods in org.apache.drill.exec.physical.impl.project with parameters of type RecordBatchModifier and TypeMethodDescriptionabstract 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) final int
ProjectorTemplate.projectRecords
(RecordBatch incomingRecordBatch, int startIndex, int recordCount, int firstOutputIndex) void
Projector.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final void
ProjectorTemplate.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) Method parameters in org.apache.drill.exec.physical.impl.project with type arguments of type RecordBatchModifier and TypeMethodDescriptionComplexToJsonBatchCreator.getBatch
(ExecutorFragmentContext context, ComplexToJson flatten, List<RecordBatch> children) ProjectBatchCreator.getBatch
(ExecutorFragmentContext context, Project config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.project with parameters of type RecordBatchModifierConstructorDescriptionProjectBatchBuilder
(ProjectRecordBatch projectBatch, VectorContainer container, SchemaChangeCallBack callBack, RecordBatch incomingBatch) ProjectRecordBatch
(Project pop, RecordBatch incoming, FragmentContext context) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.protocol
Classes in org.apache.drill.exec.physical.impl.protocol that implement RecordBatchModifier and TypeClassDescriptionclass
Modular implementation of the standard Drill record batch iterator protocol.Methods in org.apache.drill.exec.physical.impl.protocol with parameters of type RecordBatchModifier and TypeMethodDescriptionvoid
IndirectContainerAccessor.addBatch
(RecordBatch batch) Add a record batch, performing schema checks and picking out a selection vector, if provided. -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.rangepartitioner
Classes in org.apache.drill.exec.physical.impl.rangepartitioner that implement RecordBatchModifier and TypeClassDescriptionclass
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).Method parameters in org.apache.drill.exec.physical.impl.rangepartitioner with type arguments of type RecordBatchModifier and TypeMethodDescriptionRangePartitionSenderCreator.getRoot
(ExecutorFragmentContext context, RangePartitionSender config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.rangepartitioner with parameters of type RecordBatchModifierConstructorDescriptionRangePartitionRecordBatch
(RangePartitionSender popConfig, RecordBatch incoming, FragmentContext context) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.setop
Classes in org.apache.drill.exec.physical.impl.setop that implement RecordBatchModifier and TypeClassDescriptionclass
Implements the runtime execution for the Hash-SetOp operator supporting EXCEPT, EXCEPT ALL, INTERSECT, and INTERSECT ALLMethods in org.apache.drill.exec.physical.impl.setop with parameters of type RecordBatchModifier 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 objectMethod parameters in org.apache.drill.exec.physical.impl.setop with type arguments of type RecordBatchModifier and TypeMethodDescriptionSetOpBatchCreator.getBatch
(ExecutorFragmentContext context, SetOp config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.setop with parameters of type RecordBatchModifierConstructorDescriptionHashSetOpRecordBatch
(SetOp popConfig, FragmentContext context, RecordBatch left, RecordBatch right) The constructor -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.sort
Classes in org.apache.drill.exec.physical.impl.sort that implement RecordBatchMethods in org.apache.drill.exec.physical.impl.sort with parameters of type RecordBatchModifier and TypeMethodDescriptionabstract void
SortTemplate.doSetup
(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) Method parameters in org.apache.drill.exec.physical.impl.sort with type arguments of type RecordBatchModifier and TypeMethodDescriptionSortBatchCreator.getBatch
(ExecutorFragmentContext context, Sort config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.sort with parameters of type RecordBatchModifierConstructorDescriptionSortBatch
(Sort popConfig, FragmentContext context, RecordBatch incoming) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.statistics
Classes in org.apache.drill.exec.physical.impl.statistics that implement RecordBatchModifier and TypeClassDescriptionclass
class
Example input and output: Schema of incoming batch:Method parameters in org.apache.drill.exec.physical.impl.statistics with type arguments of type RecordBatchModifier and TypeMethodDescriptionStatisticsAggBatchCreator.getBatch
(ExecutorFragmentContext context, StatisticsAggregate config, List<RecordBatch> children) StatisticsMergeBatchCreator.getBatch
(ExecutorFragmentContext context, StatisticsMerge config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.statistics with parameters of type RecordBatchModifierConstructorDescriptionStatisticsAggBatch
(StatisticsAggregate popConfig, RecordBatch incoming, FragmentContext context) StatisticsMergeBatch
(StatisticsMerge popConfig, RecordBatch incoming, FragmentContext context) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.svremover
Classes in org.apache.drill.exec.physical.impl.svremover that implement RecordBatchMethods in org.apache.drill.exec.physical.impl.svremover with parameters of type RecordBatchModifier and TypeMethodDescriptionstatic Copier
GenericCopierFactory.createAndSetupCopier
(RecordBatch incoming, VectorContainer outputContainer, SchemaChangeCallBack callBack) static Copier
GenericCopierFactory.createAndSetupNonSVGenericCopier
(RecordBatch incoming, VectorContainer outputContainer) Method parameters in org.apache.drill.exec.physical.impl.svremover with type arguments of type RecordBatchModifier and TypeMethodDescriptionSVRemoverCreator.getBatch
(ExecutorFragmentContext context, SelectionVectorRemover config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.svremover with parameters of type RecordBatchModifierConstructorDescriptionGenericSV2Copier
(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) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.TopN
Classes in org.apache.drill.exec.physical.impl.TopN that implement RecordBatchModifier and TypeClassDescriptionclass
Operator Batch which implements the TopN functionality.static class
Methods in org.apache.drill.exec.physical.impl.TopN with parameters of type RecordBatchModifier and TypeMethodDescriptionabstract void
PriorityQueueTemplate.doSetup
(VectorContainer incoming, RecordBatch outgoing) Stores the reference to the hyperBatch container which holds all the records across incoming batches in it.Method parameters in org.apache.drill.exec.physical.impl.TopN with type arguments of type RecordBatchModifier and TypeMethodDescriptionTopNSortBatchCreator.getBatch
(ExecutorFragmentContext context, TopN config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.TopN with parameters of type RecordBatchModifierConstructorDescriptionTopNBatch
(TopN popConfig, FragmentContext context, RecordBatch incoming) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.trace
Classes in org.apache.drill.exec.physical.impl.trace that implement RecordBatchModifier and TypeClassDescriptionclass
Contains value vectors which are exactly the same as the incoming record batch's value vectors.Method parameters in org.apache.drill.exec.physical.impl.trace with type arguments of type RecordBatchModifier and TypeMethodDescriptionTraceBatchCreator.getBatch
(ExecutorFragmentContext context, Trace config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.trace with parameters of type RecordBatchModifierConstructorDescriptionTraceRecordBatch
(Trace pop, RecordBatch incoming, FragmentContext context) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.union
Classes in org.apache.drill.exec.physical.impl.union that implement RecordBatchMethods in org.apache.drill.exec.physical.impl.union with parameters of type RecordBatchModifier and TypeMethodDescriptionabstract void
UnionAllerTemplate.doSetup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) void
UnionAller.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final void
UnionAllerTemplate.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) Method parameters in org.apache.drill.exec.physical.impl.union with type arguments of type RecordBatchModifier and TypeMethodDescriptionUnionAllBatchCreator.getBatch
(ExecutorFragmentContext context, UnionAll config, List<RecordBatch> children) Constructor parameters in org.apache.drill.exec.physical.impl.union with type arguments of type RecordBatchModifierConstructorDescriptionUnionAllRecordBatch
(UnionAll config, List<RecordBatch> children, FragmentContext context) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.unnest
Classes in org.apache.drill.exec.physical.impl.unnest that implement RecordBatchMethods in org.apache.drill.exec.physical.impl.unnest with parameters of type RecordBatchModifier and TypeMethodDescriptionvoid
Unnest.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final void
UnnestImpl.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) Method parameters in org.apache.drill.exec.physical.impl.unnest with type arguments of type RecordBatchModifier and TypeMethodDescriptionUnnestBatchCreator.getBatch
(ExecutorFragmentContext context, UnnestPOP config, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.unorderedreceiver
Classes in org.apache.drill.exec.physical.impl.unorderedreceiver that implement RecordBatchMethod parameters in org.apache.drill.exec.physical.impl.unorderedreceiver with type arguments of type RecordBatchModifier and TypeMethodDescriptionUnorderedReceiverCreator.getBatch
(ExecutorFragmentContext context, UnorderedReceiver receiver, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.unpivot
Classes in org.apache.drill.exec.physical.impl.unpivot that implement RecordBatchMethod parameters in org.apache.drill.exec.physical.impl.unpivot with type arguments of type RecordBatchModifier and TypeMethodDescriptionUnpivotMapsBatchCreator.getBatch
(ExecutorFragmentContext context, UnpivotMaps config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.unpivot with parameters of type RecordBatchModifierConstructorDescriptionUnpivotMapsRecordBatch
(UnpivotMaps pop, RecordBatch incoming, FragmentContext context) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.validate
Classes in org.apache.drill.exec.physical.impl.validate that implement RecordBatchMethods in org.apache.drill.exec.physical.impl.validate that return RecordBatchMethods in org.apache.drill.exec.physical.impl.validate with parameters of type RecordBatchMethod parameters in org.apache.drill.exec.physical.impl.validate with type arguments of type RecordBatchModifier and TypeMethodDescriptionIteratorValidatorCreator.getBatch
(ExecutorFragmentContext context, IteratorValidator config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.validate with parameters of type RecordBatchModifierConstructorDescriptionIteratorValidatorBatchIterator
(RecordBatch incoming) IteratorValidatorBatchIterator
(RecordBatch incoming, boolean isRepeatable) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.values
Method parameters in org.apache.drill.exec.physical.impl.values with type arguments of type RecordBatchModifier and TypeMethodDescriptionValuesBatchCreator.getBatch
(ExecutorFragmentContext context, Values subScan, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.window
Classes in org.apache.drill.exec.physical.impl.window that implement RecordBatchModifier and TypeClassDescriptionclass
support for OVER(PARTITION BY expression1,expression2,...Method parameters in org.apache.drill.exec.physical.impl.window with type arguments of type RecordBatchModifier and TypeMethodDescriptionWindowFrameBatchCreator.getBatch
(ExecutorFragmentContext context, WindowPOP config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.window with parameters of type RecordBatchModifierConstructorDescriptionWindowFrameRecordBatch
(WindowPOP popConfig, FragmentContext context, RecordBatch incoming) -
Uses of RecordBatch in org.apache.drill.exec.physical.impl.xsort
Classes in org.apache.drill.exec.physical.impl.xsort that implement RecordBatchModifier and TypeClassDescriptionclass
External sort batch: a sort batch which can spill to disk in order to operate within a defined memory footprint.Methods in org.apache.drill.exec.physical.impl.xsort with parameters of type RecordBatchModifier and TypeMethodDescriptionabstract void
MSortTemplate.doSetup
(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) abstract void
SingleBatchSorterTemplate.doSetup
(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing) static void
ExternalSortBatch.releaseBatches
(RecordBatch incoming) static void
ExternalSortBatch.retainSv4OnNone
(RecordBatch incoming) Workaround for DRILL-5656.Method parameters in org.apache.drill.exec.physical.impl.xsort with type arguments of type RecordBatchModifier and TypeMethodDescriptionExternalSortBatchCreator.getBatch
(ExecutorFragmentContext context, ExternalSort config, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl.xsort with parameters of type RecordBatchModifierConstructorDescriptionExternalSortBatch
(ExternalSort popConfig, FragmentContext context, RecordBatch incoming) -
Uses of RecordBatch in org.apache.drill.exec.physical.rowSet
Methods in org.apache.drill.exec.physical.rowSet with parameters of type RecordBatch -
Uses of RecordBatch in org.apache.drill.exec.record
Subinterfaces of RecordBatch in org.apache.drill.exec.recordClasses in org.apache.drill.exec.record that implement RecordBatchModifier and TypeClassDescriptionclass
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 creationclass
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
Empty batch without schema and data.class
Wrap a VectorContainer into a record batch.Fields in org.apache.drill.exec.record declared as RecordBatchModifier and TypeFieldDescriptionprotected final RecordBatch
AbstractSingleRecordBatch.incoming
protected RecordBatch
AbstractTableFunctionRecordBatch.incoming
protected final RecordBatch
AbstractBinaryRecordBatch.left
protected final RecordBatch
AbstractBinaryRecordBatch.right
Methods in org.apache.drill.exec.record that return RecordBatchModifier and TypeMethodDescriptionprotected RecordBatch
AbstractSingleRecordBatch.getIncoming()
protected RecordBatch
AbstractTableFunctionRecordBatch.getIncoming()
protected abstract RecordBatch
AbstractUnaryRecordBatch.getIncoming()
Methods in org.apache.drill.exec.record with parameters of type RecordBatchModifier and TypeMethodDescriptionstatic String
TypedFieldId.getPath
(TypedFieldId typeFieldId, RecordBatch recordBatch) Generates the full path to a field from the typefield idsfinal RecordBatch.IterOutcome
AbstractRecordBatch.next
(int inputIndex, RecordBatch b) final 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
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
JoinBatchMemoryManager.update
(RecordBatch batch, int inputIndex, int outputPosition, boolean useAggregate) Update the memory manager parameters based on the given (incoming) batchvoid
RecordBatchMemoryManager.update
(RecordBatch recordBatch) void
RecordBatchMemoryManager.update
(RecordBatch recordBatch, int index) void
RecordBatchMemoryManager.update
(RecordBatch batch, int inputIndex, int outputPosition) void
RecordBatchMemoryManager.update
(RecordBatch batch, int inputIndex, int outputPosition, boolean useAggregate) Constructors in org.apache.drill.exec.record with parameters of type RecordBatchModifierConstructorDescriptionprotected
AbstractBinaryRecordBatch
(T popConfig, FragmentContext context, boolean buildSchema, RecordBatch left, RecordBatch right) protected
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) -
Uses of RecordBatch in org.apache.drill.exec.record.selection
Methods in org.apache.drill.exec.record.selection with parameters of type RecordBatchModifier and TypeMethodDescriptionvoid
SelectionVector4Builder.add
(RecordBatch batch, boolean newSchema) -
Uses of RecordBatch in org.apache.drill.exec.store.delta.read
Method parameters in org.apache.drill.exec.store.delta.read with type arguments of type RecordBatchModifier and TypeMethodDescriptionDeltaScanBatchCreator.getBatch
(ExecutorFragmentContext context, DeltaRowGroupScan rowGroupScan, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.dfs.easy
Methods in org.apache.drill.exec.store.dfs.easy with parameters of type RecordBatchModifier and TypeMethodDescriptionEasyFormatPlugin.getWriterBatch
(FragmentContext context, RecordBatch incoming, EasyWriter writer) Method parameters in org.apache.drill.exec.store.dfs.easy with type arguments of type RecordBatchModifier and TypeMethodDescriptionEasyReaderBatchCreator.getBatch
(ExecutorFragmentContext context, EasySubScan config, List<RecordBatch> children) EasyWriterBatchCreator.getBatch
(ExecutorFragmentContext context, EasyWriter config, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.direct
Method parameters in org.apache.drill.exec.store.direct with type arguments of type RecordBatchModifier and TypeMethodDescriptionDirectBatchCreator.getBatch
(ExecutorFragmentContext context, DirectSubScan config, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.drill.plugin
Classes in org.apache.drill.exec.store.drill.plugin that implement RecordBatchMethod parameters in org.apache.drill.exec.store.drill.plugin with type arguments of type RecordBatchModifier and TypeMethodDescriptionDrillScanBatchCreator.getBatch
(ExecutorFragmentContext context, DrillSubScan subScan, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.druid
Method parameters in org.apache.drill.exec.store.druid with type arguments of type RecordBatchModifier and TypeMethodDescriptionDruidScanBatchCreator.getBatch
(ExecutorFragmentContext context, DruidSubScan subScan, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.enumerable
Method parameters in org.apache.drill.exec.store.enumerable with type arguments of type RecordBatchModifier and TypeMethodDescriptionEnumerableBatchCreator.getBatch
(ExecutorFragmentContext context, EnumerableSubScan subScan, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.googlesheets
Method parameters in org.apache.drill.exec.store.googlesheets with type arguments of type RecordBatchModifier and TypeMethodDescriptionGoogleSheetsInsertWriterBatchCreator.getBatch
(ExecutorFragmentContext context, GoogleSheetsInsertWriter config, List<RecordBatch> children) GoogleSheetsScanBatchCreator.getBatch
(ExecutorFragmentContext context, GoogleSheetsSubScan subScan, List<RecordBatch> children) GoogleSheetsWriterBatchCreator.getBatch
(ExecutorFragmentContext context, GoogleSheetsWriter config, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.hbase
Method parameters in org.apache.drill.exec.store.hbase with type arguments of type RecordBatchModifier and TypeMethodDescriptionHBaseScanBatchCreator.getBatch
(ExecutorFragmentContext context, HBaseSubScan subScan, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.hive
Method parameters in org.apache.drill.exec.store.hive with type arguments of type RecordBatchModifier and TypeMethodDescriptionHiveDrillNativeParquetScanBatchCreator.getBatch
(ExecutorFragmentContext context, HiveDrillNativeParquetRowGroupScan rowGroupScan, List<RecordBatch> children) HiveScanBatchCreator.getBatch
(ExecutorFragmentContext context, HiveSubScan config, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.http
Method parameters in org.apache.drill.exec.store.http with type arguments of type RecordBatchModifier and TypeMethodDescriptionHttpScanBatchCreator.getBatch
(ExecutorFragmentContext context, HttpSubScan subScan, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.iceberg.read
Method parameters in org.apache.drill.exec.store.iceberg.read with type arguments of type RecordBatchModifier and TypeMethodDescriptionIcebergScanBatchCreator.getBatch
(ExecutorFragmentContext context, IcebergSubScan subScan, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.ischema
Method parameters in org.apache.drill.exec.store.ischema with type arguments of type RecordBatchModifier and TypeMethodDescriptionInfoSchemaBatchCreator.getBatch
(ExecutorFragmentContext context, InfoSchemaSubScan config, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.jdbc
Method parameters in org.apache.drill.exec.store.jdbc with type arguments of type RecordBatchModifier and TypeMethodDescriptionJdbcInsertWriterBatchCreator.getBatch
(ExecutorFragmentContext context, JdbcInsertWriter config, List<RecordBatch> children) JdbcScanBatchCreator.getBatch
(ExecutorFragmentContext context, JdbcSubScan subScan, List<RecordBatch> children) JdbcWriterBatchCreator.getBatch
(ExecutorFragmentContext context, JdbcWriter config, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.kafka
Method parameters in org.apache.drill.exec.store.kafka with type arguments of type RecordBatchModifier and TypeMethodDescriptionKafkaScanBatchCreator.getBatch
(ExecutorFragmentContext context, KafkaSubScan subScan, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.kudu
Method parameters in org.apache.drill.exec.store.kudu with type arguments of type RecordBatchModifier and TypeMethodDescriptionKuduScanBatchCreator.getBatch
(ExecutorFragmentContext context, KuduSubScan subScan, List<RecordBatch> children) KuduWriterBatchCreator.getBatch
(ExecutorFragmentContext context, KuduWriter config, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.mock
Method parameters in org.apache.drill.exec.store.mock with type arguments of type RecordBatchModifier and TypeMethodDescriptionMockScanBatchCreator.getBatch
(ExecutorFragmentContext context, MockSubScanPOP config, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.mongo
Method parameters in org.apache.drill.exec.store.mongo with type arguments of type RecordBatchModifier and TypeMethodDescriptionMongoScanBatchCreator.getBatch
(ExecutorFragmentContext context, MongoSubScan subScan, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.openTSDB
Method parameters in org.apache.drill.exec.store.openTSDB with type arguments of type RecordBatchModifier and TypeMethodDescriptionOpenTSDBBatchCreator.getBatch
(ExecutorFragmentContext context, OpenTSDBSubScan subScan, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.parquet
Methods in org.apache.drill.exec.store.parquet with parameters of type RecordBatchModifier and TypeMethodDescriptionParquetFormatPlugin.getWriterBatch
(FragmentContext context, RecordBatch incoming, ParquetWriter writer) Method parameters in org.apache.drill.exec.store.parquet with type arguments of type RecordBatchModifier and TypeMethodDescriptionParquetScanBatchCreator.getBatch
(ExecutorFragmentContext context, ParquetRowGroupScan rowGroupScan, List<RecordBatch> children) ParquetWriterBatchCreator.getBatch
(ExecutorFragmentContext context, ParquetWriter config, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.phoenix
Method parameters in org.apache.drill.exec.store.phoenix with type arguments of type RecordBatchModifier and TypeMethodDescriptionPhoenixScanBatchCreator.getBatch
(ExecutorFragmentContext context, PhoenixSubScan subScan, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.splunk
Method parameters in org.apache.drill.exec.store.splunk with type arguments of type RecordBatchModifier and TypeMethodDescriptionSplunkInsertWriterBatchCreator.getBatch
(ExecutorFragmentContext context, SplunkInsertWriter config, List<RecordBatch> children) SplunkScanBatchCreator.getBatch
(ExecutorFragmentContext context, SplunkSubScan subScan, List<RecordBatch> children) SplunkWriterBatchCreator.getBatch
(ExecutorFragmentContext context, SplunkWriter config, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.store.sys
Method parameters in org.apache.drill.exec.store.sys with type arguments of type RecordBatchModifier and TypeMethodDescriptionSystemTableBatchCreator.getBatch
(ExecutorFragmentContext context, SystemTableScan scan, List<RecordBatch> children) -
Uses of RecordBatch in org.apache.drill.exec.util.record
Methods in org.apache.drill.exec.util.record with parameters of type RecordBatchModifier and TypeMethodDescriptionstatic void
RecordBatchStats.logRecordBatchStats
(RecordBatchStats.RecordBatchIOType ioType, String sourceId, RecordBatch recordBatch, RecordBatchStats.RecordBatchStatsContext batchStatsContext) static void
RecordBatchStats.logRecordBatchStats
(RecordBatchStats.RecordBatchIOType ioType, RecordBatch recordBatch, RecordBatchStats.RecordBatchStatsContext batchStatsContext) -
Uses of RecordBatch in org.apache.drill.exec.vector
Methods in org.apache.drill.exec.vector with parameters of type RecordBatch