Uses of Class
org.apache.drill.exec.exception.SchemaChangeException
Package
Description
Execution-time exceptions.
Implementation of a row set model for hyper-batches.
Provides a set of tools to work with row sets.
-
Uses of SchemaChangeException in org.apache.drill.exec.exception
Modifier and TypeMethodDescriptionstatic SchemaChangeException
SchemaChangeException.schemaChanged
(String message, BatchSchema priorSchema, BatchSchema newSchema) -
Uses of SchemaChangeException in org.apache.drill.exec.expr.fn.impl
Modifier and TypeMethodDescriptionvoid
ValueVectorHashHelper.Hash64.doSetup
(RecordBatch incoming) abstract void
ValueVectorHashHelper.Hash64Template.doSetup
(RecordBatch incoming) 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) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl
Modifier and TypeMethodDescription<T extends ValueVector>
TOutputMutator.addField
(MaterializedField field, Class<T> clazz) Add a ValueVector for new (or existing) field.<T extends ValueVector>
TScanBatch.Mutator.addField
(MaterializedField field, Class<T> clazz) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.aggregate
Modifier and TypeMethodDescriptionabstract 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) void
HashAggTemplate.BatchHolder.setupInterior
(RecordBatch incoming, RecordBatch outgoing, VectorContainer aggrValuesContainer) abstract void
StreamingAggTemplate.setupInterior
(RecordBatch incoming, RecordBatch outgoing) void
HashAggTemplate.BatchHolder.updateAggrValuesInternal
(int incomingRowIdx, int htRowIdx) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.common
Modifier and TypeMethodDescriptionprotected boolean
HashTableTemplate.BatchHolder.areBothKeysNull
(int incomingRowIdx, int htRowIdx) void
HashPartition.buildContainersHashTableAndHelper()
Creates the hash table and join helper for this partition.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.put
(int incomingRowIdx, IndexPointer htIdxHolder, int hashCode, int batchSize) 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 theHashTableTemplate.BatchHolder
s.void
HashTableTemplate.updateBatches()
-
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.filter
Modifier and TypeMethodDescriptionabstract 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) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.flatten
Modifier and TypeMethodDescriptionabstract 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) final void
FlattenTemplate.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.join
Modifier and TypeMethodDescriptionvoid
HashJoinHelper.addNewBatch
(int recordCount) void
HashJoinHelper.addStartIndexBatch()
abstract void
JoinTemplate.doSetup
(FragmentContext context, JoinStatus status, VectorContainer outgoing) AbstractHashBinaryRecordBatch.executeBuildPhase()
Execute the BUILD phase; first read incoming and split rows into partitions; may decide to spill some of the partitionsHashJoinHelper.getNewSV4
(int recordCount) int
Probe.probeAndProject()
int
ProbeTemplate.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
HashJoinProbeTemplate.setup
(RecordBatch probeBatch, HashJoinBatch outgoing, org.apache.calcite.rel.core.JoinRelType joinRelType, boolean semiJoin, RecordBatch.IterOutcome leftStartState, HashPartition[] partitions, int cycleNum, VectorContainer container, AbstractHashBinaryRecordBatch.SpilledPartition[] spilledInners, boolean buildSideIsEmpty, int numPartitions, int rightHVColPosition) Setup the Hash Join Probe objectdefault void
Probe.setup
(RecordBatch probeBatch, HashJoinBatch outgoing, org.apache.calcite.rel.core.JoinRelType joinRelType, boolean semiJoin, RecordBatch.IterOutcome leftStartState, HashPartition[] partitions, int cycleNum, VectorContainer container, AbstractHashBinaryRecordBatch.SpilledPartition[] spilledInners, boolean buildSideIsEmpty, int numPartitions, int rightHVColPosition) default void
Probe.setup
(RecordBatch probeBatch, HashSetOpRecordBatch outgoing, org.apache.calcite.sql.SqlKind opType, boolean isAll, RecordBatch.IterOutcome leftStartState, HashPartition[] partitions, int cycleNum, VectorContainer container, AbstractHashBinaryRecordBatch.SpilledPartition[] spilledInners, boolean buildSideIsEmpty, int numPartitions) protected void
ProbeTemplate.setup
(RecordBatch probeBatch, RecordBatch.IterOutcome leftStartState, HashPartition[] partitions, int cycleNum, VectorContainer container, AbstractHashBinaryRecordBatch.SpilledPartition[] spilledInners, boolean buildSideIsEmpty, int numPartitions) void
JoinTemplate.setupJoin
(FragmentContext context, JoinStatus status, VectorContainer outgoing) void
JoinWorker.setupJoin
(FragmentContext context, JoinStatus status, VectorContainer outgoing) abstract void
AbstractHashBinaryRecordBatch.setupProbe()
void
HashJoinBatch.setupProbe()
-
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.mergereceiver
Modifier and TypeMethodDescriptionvoid
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) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.orderedpartitioner
Modifier and TypeMethodDescriptionabstract int
OrderedPartitionProjectorTemplate.doEval
(int inIndex, int partitionIndex) abstract void
OrderedPartitionProjectorTemplate.doSetup
(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, VectorContainer partitionVectors) void
OrderedPartitionProjector.setup
(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, List<TransferPair> transfers, VectorContainer partitionVectors, int partitions, SchemaPath outputField) final void
OrderedPartitionProjectorTemplate.setup
(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, List<TransferPair> transfers, VectorContainer partitionVectors, int partitions, SchemaPath outputField) void
SampleSorter.setup
(FragmentContext context, RecordBatch hyperBatch) 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) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.partitionsender
Modifier and TypeMethodDescriptionabstract 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) final void
PartitionerTemplate.setup
(ExchangeFragmentContext context, RecordBatch incoming, HashPartitionSender popConfig, OperatorStats stats, OperatorContext oContext, ClassGenerator<?> cg, int start, int end) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.project
Modifier and TypeMethodDescriptionabstract 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) final void
ProjectorTemplate.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.setop
Modifier and TypeMethodDescriptionvoid
HashSetOpProbeTemplate.setup
(RecordBatch probeBatch, HashSetOpRecordBatch outgoing, org.apache.calcite.sql.SqlKind opType, boolean isAll, RecordBatch.IterOutcome leftStartState, HashPartition[] partitions, int cycleNum, VectorContainer container, AbstractHashBinaryRecordBatch.SpilledPartition[] spilledInners, boolean buildSideIsEmpty, int numPartitions) Setup the Hash Set Op Probe objectvoid
HashSetOpRecordBatch.setupProbe()
-
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.sort
Modifier and TypeMethodDescriptionvoid
Sorter.setup
(FragmentContext context, SelectionVector4 vector4, VectorContainer hyperBatch) void
SortTemplate.setup
(FragmentContext context, SelectionVector4 vector4, VectorContainer hyperBatch) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.TopN
Modifier and TypeMethodDescriptionvoid
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 SelectionVector4void
PriorityQueueTemplate.resetQueue
(VectorContainer container, SelectionVector4 v4) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.union
Modifier and TypeMethodDescriptionabstract 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) final void
UnionAllerTemplate.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.unnest
Modifier and TypeMethodDescriptionvoid
Unnest.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final void
UnnestImpl.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.window
Modifier and TypeMethodDescriptionabstract 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 containerabstract 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 expressionboolean
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 expressionabstract 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 expressionboolean
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 expressionabstract void
Called once for each row after we evaluate all peer rows.abstract boolean
NoFrameSupportTemplate.resetValues()
Reset all window functionsvoid
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) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.xsort
Modifier and TypeMethodDescriptionint
PriorityQueueCopierTemplate.compare
(int leftIndex, int rightIndex) abstract void
PriorityQueueCopierTemplate.doCopy
(int inIndex, int outIndex) abstract int
MSortTemplate.doEval
(int leftIndex, int rightIndex) abstract int
PriorityQueueCopierTemplate.doEval
(int leftIndex, int rightIndex) abstract int
SingleBatchSorterTemplate.doEval
(char leftIndex, char rightIndex) abstract void
MSortTemplate.doSetup
(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) abstract void
PriorityQueueCopierTemplate.doSetup
(VectorAccessible incoming, VectorAccessible outgoing) abstract void
SingleBatchSorterTemplate.doSetup
(FragmentContext context, VectorAccessible incoming, RecordBatch 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
PriorityQueueCopier.setup
(BufferAllocator allocator, VectorAccessible hyperBatch, List<BatchGroup> batchGroups, VectorAccessible outgoing) void
PriorityQueueCopierTemplate.setup
(BufferAllocator allocator, VectorAccessible hyperBatch, List<BatchGroup> batchGroups, VectorAccessible outgoing) void
SingleBatchSorter.setup
(FragmentContext context, SelectionVector2 vector2, VectorAccessible incoming) void
SingleBatchSorterTemplate.setup
(FragmentContext context, SelectionVector2 vector2, VectorAccessible incoming) void
SingleBatchSorter.sort
(SelectionVector2 vector2) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.resultSet.model.hyper
Modifier and TypeMethodDescriptionstatic RowSetReaderImpl
HyperReaderBuilder.build
(BatchAccessor batch) Build a hyper-batch reader given a batch accessor.protected List<AbstractObjectReader>
HyperReaderBuilder.buildContainerChildren
(VectorContainer container) HyperSchemaInference.infer
(VectorContainer container) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.rowSet
-
Uses of SchemaChangeException in org.apache.drill.exec.record
Modifier and TypeMethodDescriptionstatic UserException
AbstractRecordBatch.schemaChangeException
(SchemaChangeException e, String operator, org.slf4j.Logger logger) protected UserException
AbstractRecordBatch.schemaChangeException
(SchemaChangeException e, org.slf4j.Logger logger) -
Uses of SchemaChangeException in org.apache.drill.exec.record.selection
Modifier and TypeMethodDescriptionvoid
SelectionVector4Builder.add
(RecordBatch batch, boolean newSchema) -
Uses of SchemaChangeException in org.apache.drill.exec.store.parquet.columnreaders
Modifier and TypeMethodDescriptionvoid
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. -
Uses of SchemaChangeException in org.apache.drill.exec.store.pojo
Modifier and TypeMethodDescriptionvoid
AbstractPojoWriter.init
(OutputMutator output) void
PojoWriter.init
(OutputMutator output) Initializes value vector.