| Modifier and Type | Method and Description |
|---|---|
VectorAccessible |
CachedVectorContainer.get() |
| Modifier and Type | Method and Description |
|---|---|
int |
VectorSerializer.Writer.write(VectorAccessible va) |
int |
VectorSerializer.Writer.write(VectorAccessible va,
SelectionVector2 sv2) |
| Modifier and Type | Method and Description |
|---|---|
static LogicalExpression |
ExpressionTreeMaterializer.materialize(LogicalExpression expr,
VectorAccessible batch,
ErrorCollector errorCollector,
FunctionLookupContext functionLookupContext) |
static LogicalExpression |
ExpressionTreeMaterializer.materialize(LogicalExpression expr,
VectorAccessible batch,
ErrorCollector errorCollector,
FunctionLookupContext functionLookupContext,
boolean allowComplexWriterExpr) |
static LogicalExpression |
ExpressionTreeMaterializer.materialize(LogicalExpression expr,
VectorAccessible batch,
ErrorCollector errorCollector,
FunctionLookupContext functionLookupContext,
boolean allowComplexWriterExpr,
boolean unionTypeEnabled)
Materializes logical expression taking into account passed parameters.
|
static LogicalExpression |
ExpressionTreeMaterializer.materializeAndCheckErrors(LogicalExpression expr,
VectorAccessible batch,
FunctionLookupContext functionLookupContext) |
| Modifier and Type | Method and Description |
|---|---|
static LogicalExpression |
ExpressionTreeMaterializer.materialize(LogicalExpression expr,
Map<VectorAccessible,BatchReference> batches,
ErrorCollector errorCollector,
FunctionLookupContext functionLookupContext,
boolean allowComplexWriterExpr,
boolean unionTypeEnabled)
Materializes logical expression taking into account passed parameters.
|
| Modifier and Type | Method and Description |
|---|---|
static void |
InterpreterEvaluator.evaluate(int recordCount,
UdfUtilities udfUtilities,
VectorAccessible incoming,
ValueVector outVV,
LogicalExpression expr) |
| Constructor and Description |
|---|
EvalVisitor(VectorAccessible incoming,
UdfUtilities udfUtilities) |
| Modifier and Type | Method and Description |
|---|---|
static LogicalExpression |
PhysicalOperatorUtil.materializeExpression(LogicalExpression expr,
VectorAccessible incoming,
FragmentContext context)
Helper method to materialize the given logical expression using the
ExpressionTreeMaterializer. |
| Modifier and Type | Class and Description |
|---|---|
class |
MockRecordBatch |
class |
ScanBatch
Record batch used for a particular scan.
|
class |
StatisticsWriterRecordBatch |
class |
WriterRecordBatch
Write the RecordBatch to the given RecordWriter.
|
| Modifier and Type | Class and Description |
|---|---|
class |
HashAggBatch |
class |
SpilledRecordBatch
Replaces "incoming" - instead scanning a spilled partition file
|
class |
StreamingAggBatch |
| Modifier and Type | Method and Description |
|---|---|
void |
HashPartition.appendBatch(VectorAccessible batch)
Append the incoming batch (actually only the vectors of that batch) into the tmp list
|
| Modifier and Type | Class and Description |
|---|---|
class |
FilterRecordBatch |
class |
RuntimeFilterRecordBatch
A RuntimeFilterRecordBatch steps over the ScanBatch.
|
| Modifier and Type | Class and Description |
|---|---|
class |
FlattenRecordBatch |
| Modifier and Type | Class and Description |
|---|---|
class |
HashJoinBatch
Implements the runtime execution for the Hash-Join operator supporting INNER,
LEFT OUTER, RIGHT OUTER, and FULL OUTER joins
|
class |
LateralJoinBatch
RecordBatch implementation for the lateral join operator.
|
class |
MergeJoinBatch
A join operator that merges two sorted streams using a record iterator.
|
class |
NestedLoopJoinBatch |
class |
RowKeyJoinBatch |
| Modifier and Type | Method and Description |
|---|---|
static void |
JoinUtils.addLeastRestrictiveCasts(LogicalExpression[] leftExpressions,
VectorAccessible leftBatch,
LogicalExpression[] rightExpressions,
VectorAccessible rightBatch,
FragmentContext context)
Utility method used by joins to add implicit casts on one of the sides of the join condition in case the two
expressions have different types.
|
| Modifier and Type | Class and Description |
|---|---|
class |
LimitRecordBatch |
class |
PartitionLimitRecordBatch
Helps to perform limit in a partition within a record batch.
|
| Modifier and Type | Class and Description |
|---|---|
class |
MergingRecordBatch
Merges pre-sorted record batches from remote senders.
|
| Modifier and Type | Method and Description |
|---|---|
abstract void |
MergingReceiverTemplate.doSetup(FragmentContext context,
VectorAccessible incoming,
VectorAccessible outgoing) |
void |
MergingReceiverGeneratorBase.doSetup(FragmentContext context,
VectorAccessible incoming,
VectorAccessible outgoing) |
| Modifier and Type | Class and Description |
|---|---|
class |
MetadataControllerBatch
Terminal operator for producing ANALYZE statement.
|
class |
MetadataHandlerBatch
Responsible for handling metadata returned by incoming aggregate operators
and fetching required metadata form the Metastore.
|
class |
MetadataHashAggBatch |
class |
MetadataStreamAggBatch
Operator which adds aggregate calls for all incoming columns to calculate
required metadata and produces aggregations.
|
| Modifier and Type | Class and Description |
|---|---|
class |
OrderedPartitionRecordBatch
Generates an ordered partition, rather than a random hash partition.
|
| Modifier and Type | Method and Description |
|---|---|
abstract void |
OrderedPartitionProjectorTemplate.doSetup(FragmentContext context,
VectorAccessible incoming,
RecordBatch outgoing,
VectorContainer partitionVectors) |
abstract void |
SampleCopierTemplate.doSetup(FragmentContext context,
VectorAccessible incoming,
VectorAccessible outgoing) |
protected void |
OrderedPartitionRecordBatch.doWork(VectorAccessible batch) |
void |
OrderedPartitionProjector.setup(FragmentContext context,
VectorAccessible incoming,
RecordBatch outgoing,
List<TransferPair> transfers,
VectorContainer partitionVectors,
int partitions,
SchemaPath outputField) |
void |
OrderedPartitionProjectorTemplate.setup(FragmentContext context,
VectorAccessible incoming,
RecordBatch outgoing,
List<TransferPair> transfers,
VectorContainer partitionVectors,
int partitions,
SchemaPath outputField) |
void |
SampleCopier.setupCopier(FragmentContext context,
SelectionVector4 sv4,
VectorAccessible incoming,
VectorAccessible outgoing) |
void |
SampleCopierTemplate.setupCopier(FragmentContext context,
SelectionVector4 sv4,
VectorAccessible incoming,
VectorAccessible outgoing) |
protected void |
OrderedPartitionRecordBatch.setupNewSchema(VectorAccessible batch)
Sets up projection that will transfer all of the columns in batch, and also
populate the partition column based on which partition a record falls into
in the partition table
|
| Modifier and Type | Class and Description |
|---|---|
class |
PartitionerTemplate.OutgoingRecordBatch |
| Modifier and Type | Method and Description |
|---|---|
protected void |
PartitionerTemplate.OutgoingRecordBatch.doSetup(RecordBatch incoming,
VectorAccessible outgoing) |
| Modifier and Type | Class and Description |
|---|---|
class |
ProducerConsumerBatch |
| Modifier and Type | Class and Description |
|---|---|
class |
ProjectRecordBatch |
| Modifier and Type | Class and Description |
|---|---|
class |
OperatorRecordBatch
Modular implementation of the standard Drill record batch iterator
protocol.
|
| Modifier and Type | Class and Description |
|---|---|
class |
RangePartitionRecordBatch
Provides the ability to divide up the input rows into a fixed number of
separate ranges or 'buckets' based on the values of a set of columns (the
range partitioning columns).
|
| Modifier and Type | Class and Description |
|---|---|
class |
SortBatch |
| Modifier and Type | Method and Description |
|---|---|
boolean |
SortRecordBatchBuilder.add(VectorAccessible batch)
Add another record batch to the set of record batches.
|
static Sorter |
SortBatch.createNewSorter(FragmentContext context,
List<Order.Ordering> orderings,
VectorAccessible batch) |
static Sorter |
SortBatch.createNewSorter(FragmentContext context,
List<Order.Ordering> orderings,
VectorAccessible batch,
MappingSet mainMapping,
MappingSet leftMapping,
MappingSet rightMapping) |
| Constructor and Description |
|---|
RecordBatchData(VectorAccessible batch,
BufferAllocator allocator) |
| Modifier and Type | Class and Description |
|---|---|
class |
StatisticsAggBatch |
class |
StatisticsMergeBatch
Example input and output:
Schema of incoming batch:
|
| Modifier and Type | Class and Description |
|---|---|
class |
RemovingRecordBatch |
| Modifier and Type | Method and Description |
|---|---|
void |
AbstractSV2Copier.setup(VectorAccessible incoming,
VectorContainer outgoing) |
void |
GenericCopier.setup(VectorAccessible incoming,
VectorContainer outgoing) |
void |
Copier.setup(VectorAccessible incoming,
VectorContainer outgoing) |
void |
StraightCopier.setup(VectorAccessible incoming,
VectorContainer outgoing) |
void |
AbstractSV4Copier.setup(VectorAccessible incoming,
VectorContainer outgoing) |
void |
AbstractCopier.setup(VectorAccessible incoming,
VectorContainer outgoing) |
| Modifier and Type | Class and Description |
|---|---|
class |
TopNBatch
Operator Batch which implements the TopN functionality.
|
static class |
TopNBatch.SimpleSV4RecordBatch |
| Modifier and Type | Method and Description |
|---|---|
static PriorityQueue |
TopNBatch.createNewPriorityQueue(MappingSet mainMapping,
MappingSet leftMapping,
MappingSet rightMapping,
List<Order.Ordering> orderings,
VectorAccessible batch,
boolean unionTypeEnabled,
boolean codegenDump,
int limit,
BufferAllocator allocator,
BatchSchema.SelectionVectorMode mode,
FragmentContext context) |
| Modifier and Type | Class and Description |
|---|---|
class |
TraceRecordBatch
Contains value vectors which are exactly the same
as the incoming record batch's value vectors.
|
| Modifier and Type | Class and Description |
|---|---|
class |
UnionAllRecordBatch |
| Modifier and Type | Class and Description |
|---|---|
class |
MockLateralJoinBatch
A mock lateral join implementation for testing unnest.
|
class |
UnnestRecordBatch |
| Modifier and Type | Class and Description |
|---|---|
class |
UnorderedReceiverBatch |
| Modifier and Type | Class and Description |
|---|---|
class |
UnpivotMapsRecordBatch
Unpivot maps.
|
| Modifier and Type | Class and Description |
|---|---|
class |
IteratorValidatorBatchIterator |
| Modifier and Type | Method and Description |
|---|---|
static boolean |
BatchValidator.validate(VectorAccessible batch) |
void |
BatchValidator.validateBatch(VectorAccessible batch,
int rowCount) |
| Modifier and Type | Class and Description |
|---|---|
class |
WindowDataBatch |
class |
WindowFrameRecordBatch
support for OVER(PARTITION BY expression1,expression2,...
|
| Modifier and Type | Method and Description |
|---|---|
abstract boolean |
FrameSupportTemplate.isPeer(int b1Index,
VectorAccessible b1,
int b2Index,
VectorAccessible b2)
compares two rows from different batches (can be the same), if they have the same value for the order by
expression
|
abstract boolean |
NoFrameSupportTemplate.isPeer(int b1Index,
VectorAccessible b1,
int b2Index,
VectorAccessible b2)
Compares two rows from different batches (can be the same), if they have the same value for the order by
expression
|
boolean |
WindowFramer.isPeer(int b1Index,
VectorAccessible b1,
int b2Index,
VectorAccessible b2)
compares two rows from different batches (can be the same), if they have the same value for the order by
expression
|
abstract boolean |
FrameSupportTemplate.isSamePartition(int b1Index,
VectorAccessible b1,
int b2Index,
VectorAccessible b2)
compares two rows from different batches (can be the same), if they have the same value for the partition by
expression
|
abstract boolean |
NoFrameSupportTemplate.isSamePartition(int b1Index,
VectorAccessible b1,
int b2Index,
VectorAccessible b2)
Compares two rows from different batches (can be the same), if they have the same value for the partition by
expression
|
boolean |
WindowFramer.isSamePartition(int b1Index,
VectorAccessible b1,
int b2Index,
VectorAccessible b2)
compares two rows from different batches (can be the same), if they have the same value for the partition by
expression
|
abstract void |
NoFrameSupportTemplate.setupCopyFromInternal(VectorAccessible incoming,
VectorAccessible outgoing) |
abstract void |
NoFrameSupportTemplate.setupCopyNext(VectorAccessible incoming,
VectorAccessible outgoing) |
abstract void |
NoFrameSupportTemplate.setupCopyPrev(VectorAccessible incoming,
VectorAccessible outgoing) |
abstract void |
FrameSupportTemplate.setupEvaluatePeer(VectorAccessible incoming,
VectorAccessible outgoing) |
abstract void |
FrameSupportTemplate.setupPartition(WindowDataBatch incoming,
VectorAccessible outgoing)
Called once per partition, before processing the partition.
|
abstract void |
NoFrameSupportTemplate.setupPartition(WindowDataBatch incoming,
VectorAccessible outgoing)
Called once per partition, before processing the partition.
|
abstract void |
FrameSupportTemplate.setupReadLastValue(VectorAccessible incoming,
VectorAccessible outgoing) |
abstract void |
FrameSupportTemplate.setupSaveFirstValue(VectorAccessible incoming,
VectorAccessible outgoing) |
abstract void |
FrameSupportTemplate.setupWriteFirstValue(VectorAccessible incoming,
VectorAccessible outgoing) |
| Constructor and Description |
|---|
WindowDataBatch(VectorAccessible batch,
OperatorContext oContext) |
| Modifier and Type | Class and Description |
|---|---|
class |
BatchGroup
Represents a group of batches spilled to disk.
|
class |
ExternalSortBatch
External sort batch: a sort batch which can spill to disk in
order to operate within a defined memory footprint.
|
class |
InputBatch
The input batch group gathers batches buffered in memory before
spilling.
|
class |
SpilledRun
Holds a set of spilled batches, represented by a file on disk.
|
| Modifier and Type | Method and Description |
|---|---|
void |
BufferedBatches.add(VectorAccessible incoming,
long batchSize) |
void |
SortImpl.addBatch(VectorAccessible incoming)
Process the converted incoming batch by adding it to the in-memory store
of data, or spilling data to disk when necessary.
|
abstract void |
SingleBatchSorterTemplate.doSetup(FragmentContext context,
VectorAccessible incoming,
RecordBatch outgoing) |
abstract void |
PriorityQueueCopierTemplate.doSetup(VectorAccessible incoming,
VectorAccessible outgoing) |
protected void |
BaseSortWrapper.generateComparisons(ClassGenerator<?> g,
VectorAccessible batch,
org.slf4j.Logger logger) |
PriorityQueueCopier |
PriorityQueueCopierWrapper.getCopier(VectorAccessible batch) |
void |
PriorityQueueCopierTemplate.setup(BufferAllocator allocator,
VectorAccessible hyperBatch,
List<BatchGroup> batchGroups,
VectorAccessible outgoing) |
void |
PriorityQueueCopier.setup(BufferAllocator allocator,
VectorAccessible hyperBatch,
List<BatchGroup> batchGroups,
VectorAccessible outgoing) |
void |
SingleBatchSorterTemplate.setup(FragmentContext context,
SelectionVector2 vector2,
VectorAccessible incoming) |
void |
SingleBatchSorter.setup(FragmentContext context,
SelectionVector2 vector2,
VectorAccessible incoming) |
| Modifier and Type | Method and Description |
|---|---|
VectorAccessible |
AbstractRowSet.vectorAccessible() |
VectorAccessible |
RowSet.vectorAccessible() |
| Modifier and Type | Method and Description |
|---|---|
static DirectRowSet |
DirectRowSet.fromVectorAccessible(BufferAllocator allocator,
VectorAccessible va) |
| Modifier and Type | Interface and Description |
|---|---|
interface |
CloseableRecordBatch |
interface |
RecordBatch
A record batch contains a set of field values for a particular range of
records.
|
| Modifier and Type | Class and Description |
|---|---|
class |
AbstractBinaryRecordBatch<T extends PhysicalOperator> |
class |
AbstractRecordBatch<T extends PhysicalOperator> |
class |
AbstractSingleRecordBatch<T extends PhysicalOperator>
Implements an AbstractUnaryRecordBatch where the incoming record batch is
known at the time of creation
|
class |
AbstractTableFunctionRecordBatch<T extends PhysicalOperator>
Implements AbstractUnaryRecodBatch for operators that do not have an incoming
record batch available at creation time; the input is typically set up a few
steps after creation.
|
class |
AbstractUnaryRecordBatch<T extends PhysicalOperator>
Base class for operators that have a single input.
|
class |
ExpandableHyperContainer |
class |
RecordBatchLoader
Holds record batch loaded from record batch message.
|
class |
RecordIterator
RecordIterator iterates over incoming record batches one record at a time.
|
class |
SchemalessBatch
Empty batch without schema and data.
|
class |
SimpleRecordBatch
Wrap a VectorContainer into a record batch.
|
class |
VectorContainer |
| Modifier and Type | Method and Description |
|---|---|
void |
ExpandableHyperContainer.addBatch(VectorAccessible batch) |
void |
VectorInitializer.allocateBatch(VectorAccessible va,
int recordCount) |
static void |
VectorAccessibleUtilities.allocateVectors(VectorAccessible va,
int targetRecordCount) |
static void |
VectorAccessibleUtilities.clear(VectorAccessible va) |
static VectorContainer |
SchemaUtil.coerceContainer(VectorAccessible in,
BatchSchema toSchema,
BufferAllocator allocator) |
static VectorContainer |
SchemaUtil.coerceContainer(VectorAccessible in,
BatchSchema toSchema,
OperatorContext context)
Creates a copy a record batch, converting any fields as necessary to coerce it into the provided schema
|
void |
VectorContainer.copySchemaFrom(VectorAccessible other) |
static WritableBatch |
WritableBatch.get(VectorAccessible batch) |
static VectorContainer |
VectorContainer.getTransferClone(VectorAccessible incoming,
BufferAllocator allocator) |
static VectorContainer |
VectorContainer.getTransferClone(VectorAccessible incoming,
OperatorContext oContext)
Get a set of transferred clones of this container.
|
static VectorContainer |
VectorContainer.getTransferClone(VectorAccessible incoming,
VectorWrapper<?>[] ignoreWrappers,
OperatorContext oContext) |
static void |
VectorAccessibleUtilities.setValueCount(VectorAccessible va,
int count) |
| Constructor and Description |
|---|
ExpandableHyperContainer(VectorAccessible batch) |
RecordBatchSizer(VectorAccessible va)
Create empirical metadata for a record batch given a vector accessible
(basically, an iterator over the vectors in the batch.)
|
RecordBatchSizer(VectorAccessible va,
SelectionVector2 sv2)
Create empirical metadata for a record batch given a vector accessible
(basically, an iterator over the vectors in the batch) along with a
selection vector for those records.
|
| Modifier and Type | Method and Description |
|---|---|
void |
StatisticsRecordWriter.updateSchema(VectorAccessible batch)
Update the schema in RecordWriter.
|
| Modifier and Type | Method and Description |
|---|---|
void |
JsonStatisticsRecordWriter.updateSchema(VectorAccessible batch) |
void |
JsonRecordWriter.updateSchema(VectorAccessible batch) |
| Modifier and Type | Method and Description |
|---|---|
void |
KuduRecordWriterImpl.updateSchema(VectorAccessible batch) |
| Modifier and Type | Method and Description |
|---|---|
void |
ParquetRecordWriter.updateSchema(VectorAccessible batch) |
| Modifier and Type | Method and Description |
|---|---|
static void |
VectorUtil.appendVectorAccessibleContent(VectorAccessible va,
StringBuilder formattedResults,
String delimiter,
boolean includeHeader) |
static void |
VectorUtil.logVectorAccessibleContent(VectorAccessible va) |
static void |
VectorUtil.logVectorAccessibleContent(VectorAccessible va,
int columnWidth) |
static void |
VectorUtil.logVectorAccessibleContent(VectorAccessible va,
int[] columnWidths) |
static void |
VectorUtil.logVectorAccessibleContent(VectorAccessible va,
String delimiter) |
static void |
BatchPrinter.printBatch(VectorAccessible batch) |
static void |
BatchPrinter.printBatch(VectorAccessible batch,
SelectionVector2 sv2) |
static void |
BatchPrinter.printHyperBatch(VectorAccessible batch,
SelectionVector4 sv4) |
| Modifier and Type | Method and Description |
|---|---|
static void |
CopyUtil.generateCopies(ClassGenerator<?> g,
VectorAccessible batch,
boolean hyper) |
| Modifier and Type | Method and Description |
|---|---|
Iterator<VectorAccessible> |
PhysicalOpUnitTestBase.BatchIterator.iterator() |
| Modifier and Type | Method and Description |
|---|---|
static int |
DrillTestWrapper.addToCombinedVectorResults(Iterable<VectorAccessible> batches,
BatchSchema expectedSchema,
Long expectedBatchSize,
Integer expectedNumBatches,
Map<String,List<Object>> combinedVectors,
Integer expectedTotalRecords)
Add to result vectors and compare batch schema against expected schema while iterating batches.
|
static Map<String,List<Object>> |
DrillTestWrapper.addToCombinedVectorResults(Iterable<VectorAccessible> batches,
Long expectedBatchSize,
Integer expectedNumBatches,
Integer expectedTotalRecords)
Iterate over batches, and combine the batches into a map, where key is schema path, and value is
the list of column values across all the batches.
|
Copyright © 2021 The Apache Software Foundation. All rights reserved.