Modifier and Type | Method and Description |
---|---|
static SchemaChangeException |
SchemaChangeException.schemaChanged(String message,
BatchSchema priorSchema,
BatchSchema newSchema) |
Modifier and Type | Method and Description |
---|---|
void |
ValueVectorHashHelper.Hash64.doSetup(RecordBatch incoming) |
abstract void |
ValueVectorHashHelper.Hash64Template.doSetup(RecordBatch incoming) |
ValueVectorHashHelper.Hash64 |
ValueVectorHashHelper.getHash64(LogicalExpression[] hashFieldsExp,
TypedFieldId[] hashFieldIds) |
long |
ValueVectorHashHelper.Hash64.hash64Code(int incomingRowIdx,
int seedValue,
int fieldId) |
abstract long |
ValueVectorHashHelper.Hash64Template.hash64Code(int incomingRowIdx,
int seedValue,
int fieldId) |
Modifier and Type | Method and Description |
---|---|
<T extends ValueVector> |
OutputMutator.addField(MaterializedField field,
Class<T> clazz)
Add a ValueVector for new (or existing) field.
|
<T extends ValueVector> |
ScanBatch.Mutator.addField(MaterializedField field,
Class<T> clazz) |
Modifier and Type | Method and Description |
---|---|
abstract void |
HashAggTemplate.doSetup(RecordBatch incoming) |
abstract int |
HashAggTemplate.getVectorIndex(int recordIndex) |
void |
HashAggTemplate.BatchHolder.outputRecordValues(int htRowIdx,
int outRowIdx) |
abstract boolean |
HashAggTemplate.resetValues() |
void |
StreamingAggregator.setup(OperatorContext context,
RecordBatch incoming,
StreamingAggBatch outgoing,
int outputRowCount) |
void |
StreamingAggTemplate.setup(OperatorContext context,
RecordBatch incoming,
StreamingAggBatch outgoing,
int outputRowCount) |
abstract void |
StreamingAggTemplate.setupInterior(RecordBatch incoming,
RecordBatch outgoing) |
void |
HashAggTemplate.BatchHolder.setupInterior(RecordBatch incoming,
RecordBatch outgoing,
VectorContainer aggrValuesContainer) |
void |
HashAggTemplate.BatchHolder.updateAggrValuesInternal(int incomingRowIdx,
int htRowIdx) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
HashTableTemplate.BatchHolder.areBothKeysNull(int incomingRowIdx,
int htRowIdx) |
void |
HashPartition.buildContainersHashTableAndHelper()
Creates the hash table and join helper for this partition.
|
HashTable |
ChainedHashTable.createAndSetupHashTable(TypedFieldId[] outKeyFieldIds) |
protected abstract void |
HashTableTemplate.doSetup(VectorContainer incomingBuild,
RecordBatch incomingProbe) |
int |
HashPartition.getBuildHashCode(int ind) |
int |
HashTable.getBuildHashCode(int incomingRowIdx)
Computes the hash code for the record at the given index in the build side batch.
|
int |
HashTableTemplate.getBuildHashCode(int incomingRowIdx)
Return the Hash Value for the row in the Build incoming batch at index:
(For Hash Aggregate there's no "Build" side -- only one batch - this one)
|
protected abstract int |
HashTableTemplate.getHashBuild(int incomingRowIdx,
int seedValue) |
protected abstract int |
HashTableTemplate.getHashProbe(int incomingRowIdx,
int seedValue) |
int |
HashPartition.getProbeHashCode(int ind) |
int |
HashTable.getProbeHashCode(int incomingRowIdx)
Computes the hash code for the record at the given index in the probe side batch.
|
int |
HashTableTemplate.getProbeHashCode(int incomingRowIdx)
Return the Hash Value for the row in the Probe incoming batch at index:
|
protected boolean |
HashTableTemplate.BatchHolder.isKeyMatchInternalBuild(int incomingRowIdx,
int htRowIdx) |
protected boolean |
HashTableTemplate.BatchHolder.isKeyMatchInternalProbe(int incomingRowIdx,
int htRowIdx) |
protected void |
HashTableTemplate.BatchHolder.outputRecordKeys(int htRowIdx,
int outRowIdx) |
int |
HashPartition.probeForKey(int recordsProcessed,
int hashCode) |
int |
HashTable.probeForKey(int incomingRowIdx,
int hashCode) |
int |
HashTableTemplate.probeForKey(int incomingRowIdx,
int hashCode)
Return -1 if Probe-side key is not found in the (build-side) hash table.
|
HashTable.PutStatus |
HashTable.put(int incomingRowIdx,
IndexPointer htIdxHolder,
int hashCode,
int batchSize) |
HashTable.PutStatus |
HashTableTemplate.put(int incomingRowIdx,
IndexPointer htIdxHolder,
int hashCode,
int targetBatchRowCount)
put() uses the hash code (from gethashCode() above) to insert the key(s) from the incoming
row into the hash table.
|
protected void |
HashTableTemplate.BatchHolder.setup() |
protected void |
HashTableTemplate.BatchHolder.setupInterior(VectorContainer incomingBuild,
RecordBatch incomingProbe,
RecordBatch outgoing,
VectorContainer htContainer) |
protected void |
HashTableTemplate.BatchHolder.setValue(int incomingRowIdx,
int htRowIdx) |
void |
HashPartition.updateBatches() |
void |
HashTable.updateBatches()
Updates the incoming (build and probe side) value vectors references in the
HashTableTemplate.BatchHolder s. |
void |
HashTableTemplate.updateBatches() |
Modifier and Type | Method and Description |
---|---|
abstract boolean |
FilterTemplate2.doEval(int inIndex,
int outIndex) |
abstract void |
FilterTemplate2.doSetup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing) |
void |
Filterer.filterBatch(int recordCount) |
void |
FilterTemplate2.filterBatch(int recordCount) |
protected Filterer |
FilterRecordBatch.generateSV4Filterer() |
void |
Filterer.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
TransferPair[] transfers) |
void |
FilterTemplate2.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
TransferPair[] transfers) |
void |
FilterTemplate4.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
TransferPair[] transfers) |
Modifier and Type | Method and Description |
---|---|
abstract boolean |
FlattenTemplate.doEval(int inIndex,
int outIndex) |
abstract void |
FlattenTemplate.doSetup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing) |
void |
Flattener.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
void |
FlattenTemplate.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
Modifier and Type | Method and Description |
---|---|
void |
HashJoinHelper.addNewBatch(int recordCount) |
void |
HashJoinHelper.addStartIndexBatch() |
abstract void |
JoinTemplate.doSetup(FragmentContext context,
JoinStatus status,
VectorContainer outgoing) |
RecordBatch.IterOutcome |
HashJoinBatch.executeBuildPhase()
Execute the BUILD phase; first read incoming and split rows into
partitions; may decide to spill some of the partitions
|
SelectionVector4 |
HashJoinHelper.getNewSV4(int recordCount) |
int |
HashJoinProbe.probeAndProject() |
int |
HashJoinProbeTemplate.probeAndProject()
Perform the probe, till the outgoing is full, or no more rows to probe.
|
void |
HashJoinHelper.setCurrentIndex(int keyIndex,
int batchIndex,
int recordIndex) |
void |
JoinTemplate.setupJoin(FragmentContext context,
JoinStatus status,
VectorContainer outgoing) |
void |
JoinWorker.setupJoin(FragmentContext context,
JoinStatus status,
VectorContainer outgoing) |
Modifier and Type | Method and Description |
---|---|
void |
MergingReceiverGeneratorBase.doCopy(int inIndex,
int outIndex) |
abstract void |
MergingReceiverTemplate.doCopy(int inIndex,
int outIndex) |
int |
MergingReceiverGeneratorBase.doEval(int leftIndex,
int rightIndex) |
abstract int |
MergingReceiverTemplate.doEval(int leftIndex,
int rightIndex) |
void |
MergingReceiverGeneratorBase.doSetup(FragmentContext context,
VectorAccessible incoming,
VectorAccessible outgoing) |
abstract void |
MergingReceiverTemplate.doSetup(FragmentContext context,
VectorAccessible incoming,
VectorAccessible outgoing) |
Modifier and Type | Method and Description |
---|---|
abstract int |
OrderedPartitionProjectorTemplate.doEval(int inIndex,
int partitionIndex) |
abstract void |
OrderedPartitionProjectorTemplate.doSetup(FragmentContext context,
VectorAccessible incoming,
RecordBatch outgoing,
VectorContainer partitionVectors) |
void |
SampleSorter.setup(FragmentContext context,
RecordBatch hyperBatch) |
void |
OrderedPartitionProjector.setup(FragmentContext context,
VectorAccessible incoming,
RecordBatch outgoing,
List<TransferPair> transfers,
VectorContainer partitionVectors,
int partitions,
SchemaPath outputField) |
void |
OrderedPartitionProjectorTemplate.setup(FragmentContext context,
VectorAccessible incoming,
RecordBatch outgoing,
List<TransferPair> transfers,
VectorContainer partitionVectors,
int partitions,
SchemaPath outputField) |
void |
SampleSortTemplate.setup(FragmentContext context,
VectorContainer sampleBatch,
SelectionVector2 vector2) |
void |
SampleCopier.setupCopier(FragmentContext context,
SelectionVector4 sv4,
VectorAccessible incoming,
VectorAccessible outgoing) |
void |
SampleCopierTemplate.setupCopier(FragmentContext context,
SelectionVector4 sv4,
VectorAccessible incoming,
VectorAccessible outgoing) |
Constructor and Description |
---|
OrderedPartitionProjectorTemplate() |
Modifier and Type | Method and Description |
---|---|
abstract int |
PartitionerTemplate.doEval(int inIndex) |
protected void |
PartitionerTemplate.OutgoingRecordBatch.doEval(int inIndex,
int outIndex) |
abstract void |
PartitionerTemplate.doSetup(FragmentContext context,
RecordBatch incoming,
PartitionerTemplate.OutgoingRecordBatch[] outgoing) |
protected void |
PartitionerTemplate.OutgoingRecordBatch.doSetup(RecordBatch incoming,
VectorAccessible outgoing) |
void |
Partitioner.setup(ExchangeFragmentContext context,
RecordBatch incoming,
HashPartitionSender popConfig,
OperatorStats stats,
OperatorContext oContext,
ClassGenerator<?> cg,
int start,
int count) |
void |
PartitionerTemplate.setup(ExchangeFragmentContext context,
RecordBatch incoming,
HashPartitionSender popConfig,
OperatorStats stats,
OperatorContext oContext,
ClassGenerator<?> cg,
int start,
int end) |
Modifier and Type | Method and Description |
---|---|
abstract void |
ProjectorTemplate.doEval(int inIndex,
int outIndex) |
abstract void |
ProjectorTemplate.doSetup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing) |
void |
Projector.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
void |
ProjectorTemplate.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
Modifier and Type | Method and Description |
---|---|
void |
Sorter.setup(FragmentContext context,
SelectionVector4 vector4,
VectorContainer hyperBatch) |
void |
SortTemplate.setup(FragmentContext context,
SelectionVector4 vector4,
VectorContainer hyperBatch) |
Modifier and Type | Method and Description |
---|---|
void |
PriorityQueue.add(RecordBatchData batch)
The elements in the given batch are added to the priority queue.
|
void |
PriorityQueueTemplate.add(RecordBatchData batch) |
int |
PriorityQueueTemplate.compare(int leftIndex,
int rightIndex) |
abstract int |
PriorityQueueTemplate.doEval(int leftIndex,
int rightIndex)
Evaluates the value of record at leftIndex and rightIndex w.r.t min heap condition.
|
abstract void |
PriorityQueueTemplate.doSetup(VectorContainer incoming,
RecordBatch outgoing)
Stores the reference to the hyperBatch container which holds all the records across incoming batches in it.
|
void |
PriorityQueue.init(int limit,
BufferAllocator allocator,
boolean hasSv2)
Initializes the priority queue.
|
void |
PriorityQueueTemplate.init(int limit,
BufferAllocator allocator,
boolean hasSv2) |
void |
PriorityQueue.resetQueue(VectorContainer container,
SelectionVector4 vector4)
Cleanup the old state of queue and recreate a new one with HyperContainer containing vectors in input container
and the corresponding indexes (in SV4 format) from input SelectionVector4
|
void |
PriorityQueueTemplate.resetQueue(VectorContainer container,
SelectionVector4 v4) |
Modifier and Type | Method and Description |
---|---|
abstract void |
UnionAllerTemplate.doEval(int inIndex,
int outIndex) |
abstract void |
UnionAllerTemplate.doSetup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing) |
void |
UnionAller.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
void |
UnionAllerTemplate.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
Modifier and Type | Method and Description |
---|---|
void |
UnnestImpl.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
void |
Unnest.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
Modifier and Type | Method and Description |
---|---|
abstract void |
NoFrameSupportTemplate.copyFromInternal(int inIndex,
int outIndex) |
abstract void |
NoFrameSupportTemplate.copyNext(int inIndex,
int outIndex)
Copies value(s) from inIndex row to outIndex row.
|
abstract void |
NoFrameSupportTemplate.copyPrev(int inIndex,
int outIndex)
Copies value(s) from inIndex row to outIndex row.
|
void |
FrameSupportTemplate.doWork()
processes all rows of the first batch.
|
void |
WindowFramer.doWork()
process the inner batch and write the aggregated values in the container
|
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 |
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.outputRow(int outIndex,
Partition partition)
Called once for each row after we evaluate all peer rows.
|
abstract boolean |
NoFrameSupportTemplate.resetValues()
Reset all window functions
|
void |
FrameSupportTemplate.setup(List<WindowDataBatch> batches,
VectorContainer container,
OperatorContext oContext,
boolean requireFullPartition,
WindowPOP popConfig) |
void |
NoFrameSupportTemplate.setup(List<WindowDataBatch> batches,
VectorContainer container,
OperatorContext oContext,
boolean requireFullPartition,
WindowPOP popConfig) |
void |
WindowFramer.setup(List<WindowDataBatch> batches,
VectorContainer container,
OperatorContext operatorContext,
boolean requireFullPartition,
WindowPOP popConfig) |
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) |
Modifier and Type | Method and Description |
---|---|
int |
PriorityQueueCopierTemplate.compare(int leftIndex,
int rightIndex) |
abstract void |
PriorityQueueCopierTemplate.doCopy(int inIndex,
int outIndex) |
abstract int |
SingleBatchSorterTemplate.doEval(char leftIndex,
char rightIndex) |
abstract int |
MSortTemplate.doEval(int leftIndex,
int rightIndex) |
abstract int |
PriorityQueueCopierTemplate.doEval(int leftIndex,
int rightIndex) |
abstract void |
SingleBatchSorterTemplate.doSetup(FragmentContext context,
VectorAccessible incoming,
RecordBatch outgoing) |
abstract void |
MSortTemplate.doSetup(FragmentContext context,
VectorContainer incoming,
RecordBatch outgoing) |
abstract void |
PriorityQueueCopierTemplate.doSetup(VectorAccessible incoming,
VectorAccessible outgoing) |
void |
PriorityQueueCopier.setup(BufferAllocator allocator,
VectorAccessible hyperBatch,
List<BatchGroup> batchGroups,
VectorAccessible outgoing) |
void |
PriorityQueueCopierTemplate.setup(BufferAllocator allocator,
VectorAccessible hyperBatch,
List<BatchGroup> batchGroups,
VectorAccessible outgoing) |
void |
MSorter.setup(FragmentContext context,
BufferAllocator allocator,
SelectionVector4 vector4,
VectorContainer hyperBatch,
int outputBatchSize,
int desiredBatchSize) |
void |
MSortTemplate.setup(FragmentContext context,
BufferAllocator allocator,
SelectionVector4 vector4,
VectorContainer hyperBatch,
int outputBatchSize,
int desiredBatchSize) |
void |
SingleBatchSorter.setup(FragmentContext context,
SelectionVector2 vector2,
VectorAccessible incoming) |
void |
SingleBatchSorterTemplate.setup(FragmentContext context,
SelectionVector2 vector2,
VectorAccessible incoming) |
void |
SingleBatchSorter.sort(SelectionVector2 vector2) |
Modifier and Type | Method and Description |
---|---|
static RowSetReaderImpl |
HyperReaderBuilder.build(BatchAccessor batch)
Build a hyper-batch reader given a batch accessor.
|
protected List<AbstractObjectReader> |
HyperReaderBuilder.buildContainerChildren(VectorContainer container) |
TupleMetadata |
HyperSchemaInference.infer(VectorContainer container) |
Modifier and Type | Method and Description |
---|---|
RowSet.HyperRowSet |
HyperRowSetImpl.HyperRowSetBuilderImpl.build() |
RowSet.HyperRowSet |
RowSet.HyperRowSetBuilder.build() |
Constructor and Description |
---|
HyperRowSetImpl(VectorContainer container,
SelectionVector4 sv4) |
Modifier and Type | Method and Description |
---|---|
protected UserException |
AbstractRecordBatch.schemaChangeException(SchemaChangeException e,
org.slf4j.Logger logger) |
static UserException |
AbstractRecordBatch.schemaChangeException(SchemaChangeException e,
String operator,
org.slf4j.Logger logger) |
Modifier and Type | Method and Description |
---|---|
SchemaBuilder |
SchemaBuilder.removeField(MaterializedField f) |
Modifier and Type | Method and Description |
---|---|
void |
SelectionVector4Builder.add(RecordBatch batch,
boolean newSchema) |
Modifier and Type | Method and Description |
---|---|
static SchemaChangeException |
PluginErrorHandler.schemaChangeException(org.slf4j.Logger logger,
Throwable t,
String format,
Object... args) |
Modifier and Type | Method and Description |
---|---|
protected void |
OjaiValueWriter.writeToListOrMap(MapOrListWriterImpl writer,
org.ojai.DocumentReader reader) |
Modifier and Type | Method and Description |
---|---|
void |
ParquetSchema.createNonExistentColumns(OutputMutator output,
List<NullableIntVector> nullFilledVectors)
Create "dummy" fields for columns which are selected in the SELECT clause, but not
present in the Parquet schema.
|
Modifier and Type | Method and Description |
---|---|
void |
AbstractPojoWriter.init(OutputMutator output) |
void |
PojoWriter.init(OutputMutator output)
Initializes value vector.
|
Copyright © 1970 The Apache Software Foundation. All rights reserved.