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 TypeMethodDescriptionvoidSpool.read(RecordBatch batch) voidSpool.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 TypeMethodDescriptionvoidValueVectorHashHelper.Hash64.doSetup(RecordBatch incoming) abstract voidValueVectorHashHelper.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 voidInterpreterEvaluator.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 TypeMethodDescriptionvoidFragmentContext.requestMemory(RecordBatch requestor) An operator is experiencing memory pressure.voidFragmentContextImpl.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 TypeClassDescriptionclassclassRecord batch used for a particular scan.classclassWrite the RecordBatch to the given RecordWriter.Methods in org.apache.drill.exec.physical.impl that return RecordBatchModifier and TypeMethodDescriptionprotected RecordBatchScreenCreator.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 TypeClassDescriptionclassclassReplaces "incoming" - instead scanning a spilled partition fileclassFields in org.apache.drill.exec.physical.impl.aggregate declared as RecordBatchModifier and TypeFieldDescriptionprotected RecordBatchHashAggBatch.incomingprotected final RecordBatchStreamingAggBatch.incomingMethods 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 voidHashAggTemplate.doSetup(RecordBatch incoming) voidHashAggregator.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) voidHashAggTemplate.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) voidStreamingAggregator.setup(OperatorContext context, RecordBatch incoming, StreamingAggBatch outgoing, int outputRowCount) voidStreamingAggTemplate.setup(OperatorContext context, RecordBatch incoming, StreamingAggBatch outgoing, int outputRowCount) voidHashAggTemplate.BatchHolder.setupInterior(RecordBatch incoming, RecordBatch outgoing, VectorContainer aggrValuesContainer) abstract voidStreamingAggTemplate.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 voidHashTableTemplate.doSetup(VectorContainer incomingBuild, RecordBatch incomingProbe) voidHashTable.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.voidHashTableTemplate.setup(HashTableConfig htConfig, BufferAllocator allocator, VectorContainer incomingBuild, RecordBatch incomingProbe, RecordBatch outgoing, VectorContainer htContainerOrig, FragmentContext context, ClassGenerator<?> cg) protected voidHashTableTemplate.BatchHolder.setupInterior(VectorContainer incomingBuild, RecordBatch incomingProbe, RecordBatch outgoing, VectorContainer htContainer) voidChainedHashTable.updateIncoming(RecordBatch incomingBuild, RecordBatch incomingProbe) voidHashTable.updateIncoming(VectorContainer newIncoming, RecordBatch newIncomingProbe) Changes the incoming probe and build side batches, and then updates all the value vector references in theHashTableTemplate.BatchHolders.voidHashTableTemplate.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 TypeClassDescriptionclassclassA RuntimeFilterRecordBatch steps over the ScanBatch.Methods in org.apache.drill.exec.physical.impl.filter with parameters of type RecordBatchModifier and TypeMethodDescriptionvoidFilterSignature.doSetup(FragmentContextImpl context, RecordBatch incoming, RecordBatch outgoing) abstract voidFilterTemplate2.doSetup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) abstract voidFilterTemplate4.doSetup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) voidFilterer.setup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, TransferPair[] transfers) voidFilterTemplate2.setup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, TransferPair[] transfers) voidFilterTemplate4.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 voidFlattenTemplate.doSetup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) voidFlattener.setup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final voidFlattenTemplate.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 TypeClassDescriptionclassAbstractHashBinaryRecordBatch<T extends PhysicalOperator>Base class for the runtime execution implementation of the Hash-Join and Hash-SetOp operatorclassImplements the runtime execution for the Hash-Join operator supporting INNER, LEFT OUTER, RIGHT OUTER, and FULL OUTER joinsclassRecordBatch implementation for the lateral join operator.classA join operator that merges two sorted streams using a record iterator.classclassFields in org.apache.drill.exec.physical.impl.join declared as RecordBatchModifier and TypeFieldDescriptionprotected RecordBatchAbstractHashBinaryRecordBatch.buildBatchprotected RecordBatchAbstractHashBinaryRecordBatch.probeBatchprotected RecordBatchProbeTemplate.probeBatchMethods 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) voidNestedLoopJoin.doSetup(FragmentContext context, VectorContainer rightContainer, RecordBatch leftBatch, RecordBatch outgoing) abstract voidNestedLoopJoinTemplate.doSetup(FragmentContext context, VectorContainer rightContainer, RecordBatch leftBatch, RecordBatch outgoing) static longBatchSizePredictorImpl.getBatchSizeEstimate(RecordBatch recordBatch) voidHashJoinMechanicalMemoryCalculator.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) voidHashJoinMemoryCalculator.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) voidHashJoinMemoryCalculatorImpl.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) voidHashJoinMemoryCalculatorImpl.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) voidHashJoinProbeTemplate.setup(RecordBatch probeBatch, HashJoinBatch outgoing, org.apache.calcite.rel.core.JoinRelType joinRelType, boolean semiJoin, RecordBatch.IterOutcome leftStartState, HashPartition[] partitions, int cycleNum, VectorContainer container, AbstractHashBinaryRecordBatch.SpilledPartition[] spilledInners, boolean buildSideIsEmpty, int numPartitions, int rightHVColPosition) Setup the Hash Join Probe objectdefault voidProbe.setup(RecordBatch probeBatch, HashJoinBatch outgoing, org.apache.calcite.rel.core.JoinRelType joinRelType, boolean semiJoin, RecordBatch.IterOutcome leftStartState, HashPartition[] partitions, int cycleNum, VectorContainer container, AbstractHashBinaryRecordBatch.SpilledPartition[] spilledInners, boolean buildSideIsEmpty, int numPartitions, int rightHVColPosition) default voidProbe.setup(RecordBatch probeBatch, HashSetOpRecordBatch outgoing, org.apache.calcite.sql.SqlKind opType, boolean isAll, RecordBatch.IterOutcome leftStartState, HashPartition[] partitions, int cycleNum, VectorContainer container, AbstractHashBinaryRecordBatch.SpilledPartition[] spilledInners, boolean buildSideIsEmpty, int numPartitions) protected voidProbeTemplate.setup(RecordBatch probeBatch, RecordBatch.IterOutcome leftStartState, HashPartition[] partitions, int cycleNum, VectorContainer container, AbstractHashBinaryRecordBatch.SpilledPartition[] spilledInners, boolean buildSideIsEmpty, int numPartitions) voidNestedLoopJoin.setupNestedLoopJoin(FragmentContext context, RecordBatch left, RecordBatch.IterOutcome leftOutcome, ExpandableHyperContainer rightContainer, LinkedList<Integer> rightCounts, NestedLoopJoinBatch outgoing) voidNestedLoopJoinTemplate.setupNestedLoopJoin(FragmentContext context, RecordBatch left, RecordBatch.IterOutcome leftOutcome, ExpandableHyperContainer rightContainer, LinkedList<Integer> rightCounts, NestedLoopJoinBatch outgoing) Method initializes necessary state and invokes the doSetup() to set the input and output value vector references.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) protectedMergeJoinBatch(MergeJoinPOP popConfig, FragmentContext context, RecordBatch left, RecordBatch right) protectedNestedLoopJoinBatch(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 TypeClassDescriptionclassclassHelps 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 TypeClassDescriptionclassMerges 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 TypeClassDescriptionclassTerminal operator for producing ANALYZE statement.classResponsible for handling metadata returned by incoming aggregate operators and fetching required metadata form the Metastore.classclassOperator 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 RecordBatchModifierConstructorDescriptionprotectedMetadataControllerBatch(MetadataControllerPOP popConfig, FragmentContext context, RecordBatch left, RecordBatch right) protectedMetadataHandlerBatch(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 TypeClassDescriptionclassGenerates an ordered partition, rather than a random hash partition.Fields in org.apache.drill.exec.physical.impl.orderedpartitioner declared as RecordBatchModifier and TypeFieldDescriptionprotected final RecordBatchOrderedPartitionRecordBatch.incomingMethods in org.apache.drill.exec.physical.impl.orderedpartitioner with parameters of type RecordBatchModifier and TypeMethodDescriptionabstract voidOrderedPartitionProjectorTemplate.doSetup(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, VectorContainer partitionVectors) abstract voidSampleSortTemplate.doSetup(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) voidOrderedPartitionProjector.setup(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, List<TransferPair> transfers, VectorContainer partitionVectors, int partitions, SchemaPath outputField) final voidOrderedPartitionProjectorTemplate.setup(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, List<TransferPair> transfers, VectorContainer partitionVectors, int partitions, SchemaPath outputField) voidSampleSorter.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 voidPartitionerTemplate.doSetup(FragmentContext context, RecordBatch incoming, PartitionerTemplate.OutgoingRecordBatch[] outgoing) protected voidPartitionerTemplate.OutgoingRecordBatch.doSetup(RecordBatch incoming, VectorAccessible outgoing) voidPartitioner.partitionBatch(RecordBatch incoming) voidPartitionerDecorator.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 PartitionersvoidPartitionerTemplate.partitionBatch(RecordBatch incoming) voidPartitioner.setup(ExchangeFragmentContext context, RecordBatch incoming, HashPartitionSender popConfig, OperatorStats stats, OperatorContext oContext, ClassGenerator<?> cg, int start, int count) final voidPartitionerTemplate.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 RecordBatchModifierConstructorDescriptionprotectedProducerConsumerBatch(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 voidProjectorTemplate.doSetup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) voidProjectMemoryManager.init(RecordBatch incomingBatch, ProjectRecordBatch outgoingBatch) intProjector.projectRecords(RecordBatch incomingBatch, int startIndex, int recordCount, int firstOutputIndex) final intProjectorTemplate.projectRecords(RecordBatch incomingRecordBatch, int startIndex, int recordCount, int firstOutputIndex) voidProjector.setup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final voidProjectorTemplate.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 TypeClassDescriptionclassModular implementation of the standard Drill record batch iterator protocol.Methods in org.apache.drill.exec.physical.impl.protocol with parameters of type RecordBatchModifier and TypeMethodDescriptionvoidIndirectContainerAccessor.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 TypeClassDescriptionclassProvides 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 TypeClassDescriptionclassImplements 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 TypeMethodDescriptionvoidHashSetOpProbeTemplate.setup(RecordBatch probeBatch, HashSetOpRecordBatch outgoing, org.apache.calcite.sql.SqlKind opType, boolean isAll, RecordBatch.IterOutcome leftStartState, HashPartition[] partitions, int cycleNum, VectorContainer container, AbstractHashBinaryRecordBatch.SpilledPartition[] spilledInners, boolean buildSideIsEmpty, int numPartitions) Setup the Hash Set Op Probe 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 voidSortTemplate.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 TypeClassDescriptionclassclassExample 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 CopierGenericCopierFactory.createAndSetupCopier(RecordBatch incoming, VectorContainer outputContainer, SchemaChangeCallBack callBack) static CopierGenericCopierFactory.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 TypeClassDescriptionclassOperator Batch which implements the TopN functionality.static classMethods in org.apache.drill.exec.physical.impl.TopN with parameters of type RecordBatchModifier and TypeMethodDescriptionabstract voidPriorityQueueTemplate.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 TypeClassDescriptionclassContains 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 voidUnionAllerTemplate.doSetup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) voidUnionAller.setup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final voidUnionAllerTemplate.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 TypeMethodDescriptionvoidUnnest.setup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final voidUnnestImpl.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 TypeClassDescriptionclasssupport 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 TypeClassDescriptionclassExternal 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 voidMSortTemplate.doSetup(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) abstract voidSingleBatchSorterTemplate.doSetup(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing) static voidExternalSortBatch.releaseBatches(RecordBatch incoming) static voidExternalSortBatch.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 TypeClassDescriptionclassAbstractBinaryRecordBatch<T extends PhysicalOperator>classAbstractRecordBatch<T extends PhysicalOperator>classAbstractSingleRecordBatch<T extends PhysicalOperator>Implements an AbstractUnaryRecordBatch where the incoming record batch is known at the time of creationclassAbstractTableFunctionRecordBatch<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.classAbstractUnaryRecordBatch<T extends PhysicalOperator>Base class for operators that have a single input.classEmpty batch without schema and data.classWrap a VectorContainer into a record batch.Fields in org.apache.drill.exec.record declared as RecordBatchModifier and TypeFieldDescriptionprotected final RecordBatchAbstractSingleRecordBatch.incomingprotected RecordBatchAbstractTableFunctionRecordBatch.incomingprotected final RecordBatchAbstractBinaryRecordBatch.leftprotected final RecordBatchAbstractBinaryRecordBatch.rightMethods in org.apache.drill.exec.record that return RecordBatchModifier and TypeMethodDescriptionprotected RecordBatchAbstractSingleRecordBatch.getIncoming()protected RecordBatchAbstractTableFunctionRecordBatch.getIncoming()protected abstract RecordBatchAbstractUnaryRecordBatch.getIncoming()Methods in org.apache.drill.exec.record with parameters of type RecordBatchModifier and TypeMethodDescriptionstatic StringTypedFieldId.getPath(TypedFieldId typeFieldId, RecordBatch recordBatch) Generates the full path to a field from the typefield idsfinal RecordBatch.IterOutcomeAbstractRecordBatch.next(int inputIndex, RecordBatch b) final RecordBatch.IterOutcomeAbstractRecordBatch.next(RecordBatch b) voidAbstractTableFunctionRecordBatch.setIncoming(RecordBatch incoming) voidTableFunctionContract.setIncoming(RecordBatch incoming) sets the incoming record batch for the operator.voidJoinBatchMemoryManager.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)voidJoinBatchMemoryManager.update(RecordBatch batch, int inputIndex, int outputPosition, boolean useAggregate) Update the memory manager parameters based on the given (incoming) batchvoidRecordBatchMemoryManager.update(RecordBatch recordBatch) voidRecordBatchMemoryManager.update(RecordBatch recordBatch, int index) voidRecordBatchMemoryManager.update(RecordBatch batch, int inputIndex, int outputPosition) voidRecordBatchMemoryManager.update(RecordBatch batch, int inputIndex, int outputPosition, boolean useAggregate) Constructors in org.apache.drill.exec.record with parameters of type RecordBatchModifierConstructorDescriptionprotectedAbstractBinaryRecordBatch(T popConfig, FragmentContext context, boolean buildSchema, RecordBatch left, RecordBatch right) protectedAbstractBinaryRecordBatch(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 TypeMethodDescriptionvoidSelectionVector4Builder.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 voidRecordBatchStats.logRecordBatchStats(RecordBatchStats.RecordBatchIOType ioType, String sourceId, RecordBatch recordBatch, RecordBatchStats.RecordBatchStatsContext batchStatsContext) static voidRecordBatchStats.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