Uses of Class
org.apache.drill.exec.exception.SchemaChangeException
Packages that use 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
Methods in org.apache.drill.exec.exception that return SchemaChangeExceptionModifier and TypeMethodDescriptionstatic SchemaChangeExceptionSchemaChangeException.schemaChanged(String message, BatchSchema priorSchema, BatchSchema newSchema) -
Uses of SchemaChangeException in org.apache.drill.exec.expr.fn.impl
Methods in org.apache.drill.exec.expr.fn.impl that throw SchemaChangeExceptionModifier and TypeMethodDescriptionvoidValueVectorHashHelper.Hash64.doSetup(RecordBatch incoming) abstract voidValueVectorHashHelper.Hash64Template.doSetup(RecordBatch incoming) ValueVectorHashHelper.getHash64(LogicalExpression[] hashFieldsExp, TypedFieldId[] hashFieldIds) longValueVectorHashHelper.Hash64.hash64Code(int incomingRowIdx, int seedValue, int fieldId) abstract longValueVectorHashHelper.Hash64Template.hash64Code(int incomingRowIdx, int seedValue, int fieldId) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl
Methods in org.apache.drill.exec.physical.impl that throw SchemaChangeExceptionModifier 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
Methods in org.apache.drill.exec.physical.impl.aggregate that throw SchemaChangeExceptionModifier and TypeMethodDescriptionabstract voidHashAggTemplate.doSetup(RecordBatch incoming) abstract intHashAggTemplate.getVectorIndex(int recordIndex) voidHashAggTemplate.BatchHolder.outputRecordValues(int htRowIdx, int outRowIdx) abstract booleanHashAggTemplate.resetValues()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) voidHashAggTemplate.BatchHolder.updateAggrValuesInternal(int incomingRowIdx, int htRowIdx) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.common
Methods in org.apache.drill.exec.physical.impl.common that throw SchemaChangeExceptionModifier and TypeMethodDescriptionprotected booleanHashTableTemplate.BatchHolder.areBothKeysNull(int incomingRowIdx, int htRowIdx) voidHashPartition.buildContainersHashTableAndHelper()Creates the hash table and join helper for this partition.ChainedHashTable.createAndSetupHashTable(TypedFieldId[] outKeyFieldIds) protected abstract voidHashTableTemplate.doSetup(VectorContainer incomingBuild, RecordBatch incomingProbe) intHashPartition.getBuildHashCode(int ind) intHashTable.getBuildHashCode(int incomingRowIdx) Computes the hash code for the record at the given index in the build side batch.intHashTableTemplate.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 intHashTableTemplate.getHashBuild(int incomingRowIdx, int seedValue) protected abstract intHashTableTemplate.getHashProbe(int incomingRowIdx, int seedValue) intHashPartition.getProbeHashCode(int ind) intHashTable.getProbeHashCode(int incomingRowIdx) Computes the hash code for the record at the given index in the probe side batch.intHashTableTemplate.getProbeHashCode(int incomingRowIdx) Return the Hash Value for the row in the Probe incoming batch at index:protected booleanHashTableTemplate.BatchHolder.isKeyMatchInternalBuild(int incomingRowIdx, int htRowIdx) protected booleanHashTableTemplate.BatchHolder.isKeyMatchInternalProbe(int incomingRowIdx, int htRowIdx) protected voidHashTableTemplate.BatchHolder.outputRecordKeys(int htRowIdx, int outRowIdx) intHashPartition.probeForKey(int recordsProcessed, int hashCode) intHashTable.probeForKey(int incomingRowIdx, int hashCode) intHashTableTemplate.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 voidHashTableTemplate.BatchHolder.setup()protected voidHashTableTemplate.BatchHolder.setupInterior(VectorContainer incomingBuild, RecordBatch incomingProbe, RecordBatch outgoing, VectorContainer htContainer) protected voidHashTableTemplate.BatchHolder.setValue(int incomingRowIdx, int htRowIdx) voidHashPartition.updateBatches()voidHashTable.updateBatches()Updates the incoming (build and probe side) value vectors references in theHashTableTemplate.BatchHolders.voidHashTableTemplate.updateBatches() -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.filter
Methods in org.apache.drill.exec.physical.impl.filter that throw SchemaChangeExceptionModifier and TypeMethodDescriptionabstract booleanFilterTemplate2.doEval(int inIndex, int outIndex) abstract voidFilterTemplate2.doSetup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) voidFilterer.filterBatch(int recordCount) voidFilterTemplate2.filterBatch(int recordCount) protected FiltererFilterRecordBatch.generateSV4Filterer()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) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.flatten
Methods in org.apache.drill.exec.physical.impl.flatten that throw SchemaChangeExceptionModifier and TypeMethodDescriptionabstract booleanFlattenTemplate.doEval(int inIndex, int outIndex) abstract 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) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.join
Methods in org.apache.drill.exec.physical.impl.join that throw SchemaChangeExceptionModifier and TypeMethodDescriptionvoidHashJoinHelper.addNewBatch(int recordCount) voidHashJoinHelper.addStartIndexBatch()abstract voidJoinTemplate.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) intNestedLoopJoin.outputRecords(org.apache.calcite.rel.core.JoinRelType joinType) intNestedLoopJoinTemplate.outputRecords(org.apache.calcite.rel.core.JoinRelType joinType) Main entry point for producing the output records.intProbe.probeAndProject()intProbeTemplate.probeAndProject()Perform the probe, till the outgoing is full, or no more rows to probe.voidHashJoinHelper.setCurrentIndex(int keyIndex, int batchIndex, int recordIndex) 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) voidJoinTemplate.setupJoin(FragmentContext context, JoinStatus status, VectorContainer outgoing) voidJoinWorker.setupJoin(FragmentContext context, JoinStatus status, VectorContainer outgoing) abstract voidAbstractHashBinaryRecordBatch.setupProbe()voidHashJoinBatch.setupProbe() -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.mergereceiver
Methods in org.apache.drill.exec.physical.impl.mergereceiver that throw SchemaChangeExceptionModifier and TypeMethodDescriptionvoidMergingReceiverGeneratorBase.doCopy(int inIndex, int outIndex) abstract voidMergingReceiverTemplate.doCopy(int inIndex, int outIndex) intMergingReceiverGeneratorBase.doEval(int leftIndex, int rightIndex) abstract intMergingReceiverTemplate.doEval(int leftIndex, int rightIndex) voidMergingReceiverGeneratorBase.doSetup(FragmentContext context, VectorAccessible incoming, VectorAccessible outgoing) abstract voidMergingReceiverTemplate.doSetup(FragmentContext context, VectorAccessible incoming, VectorAccessible outgoing) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.orderedpartitioner
Methods in org.apache.drill.exec.physical.impl.orderedpartitioner that throw SchemaChangeExceptionModifier and TypeMethodDescriptionabstract intOrderedPartitionProjectorTemplate.doEval(int inIndex, int partitionIndex) abstract voidOrderedPartitionProjectorTemplate.doSetup(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, VectorContainer partitionVectors) 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) voidSampleSortTemplate.setup(FragmentContext context, VectorContainer sampleBatch, SelectionVector2 vector2) voidSampleCopier.setupCopier(FragmentContext context, SelectionVector4 sv4, VectorAccessible incoming, VectorAccessible outgoing) voidSampleCopierTemplate.setupCopier(FragmentContext context, SelectionVector4 sv4, VectorAccessible incoming, VectorAccessible outgoing) Constructors in org.apache.drill.exec.physical.impl.orderedpartitioner that throw SchemaChangeException -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.partitionsender
Methods in org.apache.drill.exec.physical.impl.partitionsender that throw SchemaChangeExceptionModifier and TypeMethodDescriptionabstract intPartitionerTemplate.doEval(int inIndex) protected voidPartitionerTemplate.OutgoingRecordBatch.doEval(int inIndex, int outIndex) abstract voidPartitionerTemplate.doSetup(FragmentContext context, RecordBatch incoming, PartitionerTemplate.OutgoingRecordBatch[] outgoing) protected voidPartitionerTemplate.OutgoingRecordBatch.doSetup(RecordBatch incoming, VectorAccessible outgoing) 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) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.project
Methods in org.apache.drill.exec.physical.impl.project that throw SchemaChangeExceptionModifier and TypeMethodDescriptionabstract voidProjectorTemplate.doEval(int inIndex, int outIndex) abstract voidProjectorTemplate.doSetup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) voidProjector.setup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final voidProjectorTemplate.setup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.setop
Methods in org.apache.drill.exec.physical.impl.setop that throw SchemaChangeExceptionModifier 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 objectvoidHashSetOpRecordBatch.setupProbe() -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.sort
Methods in org.apache.drill.exec.physical.impl.sort that throw SchemaChangeExceptionModifier and TypeMethodDescriptionvoidSorter.setup(FragmentContext context, SelectionVector4 vector4, VectorContainer hyperBatch) voidSortTemplate.setup(FragmentContext context, SelectionVector4 vector4, VectorContainer hyperBatch) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.TopN
Methods in org.apache.drill.exec.physical.impl.TopN that throw SchemaChangeExceptionModifier and TypeMethodDescriptionvoidPriorityQueue.add(RecordBatchData batch) The elements in the given batch are added to the priority queue.voidPriorityQueueTemplate.add(RecordBatchData batch) intPriorityQueueTemplate.compare(int leftIndex, int rightIndex) abstract intPriorityQueueTemplate.doEval(int leftIndex, int rightIndex) Evaluates the value of record at leftIndex and rightIndex w.r.t min heap condition.abstract voidPriorityQueueTemplate.doSetup(VectorContainer incoming, RecordBatch outgoing) Stores the reference to the hyperBatch container which holds all the records across incoming batches in it.voidPriorityQueue.init(int limit, BufferAllocator allocator, boolean hasSv2) Initializes the priority queue.voidPriorityQueueTemplate.init(int limit, BufferAllocator allocator, boolean hasSv2) voidPriorityQueue.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 SelectionVector4voidPriorityQueueTemplate.resetQueue(VectorContainer container, SelectionVector4 v4) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.union
Methods in org.apache.drill.exec.physical.impl.union that throw SchemaChangeExceptionModifier and TypeMethodDescriptionabstract voidUnionAllerTemplate.doEval(int inIndex, int outIndex) abstract 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) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.unnest
Methods in org.apache.drill.exec.physical.impl.unnest that throw SchemaChangeExceptionModifier and TypeMethodDescriptionvoidUnnest.setup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final voidUnnestImpl.setup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.window
Methods in org.apache.drill.exec.physical.impl.window that throw SchemaChangeExceptionModifier and TypeMethodDescriptionabstract voidNoFrameSupportTemplate.copyFromInternal(int inIndex, int outIndex) abstract voidNoFrameSupportTemplate.copyNext(int inIndex, int outIndex) Copies value(s) from inIndex row to outIndex row.abstract voidNoFrameSupportTemplate.copyPrev(int inIndex, int outIndex) Copies value(s) from inIndex row to outIndex row.voidFrameSupportTemplate.doWork()processes all rows of the first batch.voidWindowFramer.doWork()process the inner batch and write the aggregated values in the containerabstract booleanNoFrameSupportTemplate.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 expressionbooleanWindowFramer.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 booleanNoFrameSupportTemplate.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 expressionbooleanWindowFramer.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 voidCalled once for each row after we evaluate all peer rows.abstract booleanNoFrameSupportTemplate.resetValues()Reset all window functionsvoidFrameSupportTemplate.setup(List<WindowDataBatch> batches, VectorContainer container, OperatorContext oContext, boolean requireFullPartition, WindowPOP popConfig) voidNoFrameSupportTemplate.setup(List<WindowDataBatch> batches, VectorContainer container, OperatorContext oContext, boolean requireFullPartition, WindowPOP popConfig) voidWindowFramer.setup(List<WindowDataBatch> batches, VectorContainer container, OperatorContext operatorContext, boolean requireFullPartition, WindowPOP popConfig) abstract voidNoFrameSupportTemplate.setupCopyFromInternal(VectorAccessible incoming, VectorAccessible outgoing) abstract voidNoFrameSupportTemplate.setupCopyNext(VectorAccessible incoming, VectorAccessible outgoing) abstract voidNoFrameSupportTemplate.setupCopyPrev(VectorAccessible incoming, VectorAccessible outgoing) abstract voidFrameSupportTemplate.setupEvaluatePeer(VectorAccessible incoming, VectorAccessible outgoing) abstract voidFrameSupportTemplate.setupPartition(WindowDataBatch incoming, VectorAccessible outgoing) Called once per partition, before processing the partition.abstract voidNoFrameSupportTemplate.setupPartition(WindowDataBatch incoming, VectorAccessible outgoing) Called once per partition, before processing the partition.abstract voidFrameSupportTemplate.setupReadLastValue(VectorAccessible incoming, VectorAccessible outgoing) abstract voidFrameSupportTemplate.setupSaveFirstValue(VectorAccessible incoming, VectorAccessible outgoing) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.impl.xsort
Methods in org.apache.drill.exec.physical.impl.xsort that throw SchemaChangeExceptionModifier and TypeMethodDescriptionintPriorityQueueCopierTemplate.compare(int leftIndex, int rightIndex) abstract voidPriorityQueueCopierTemplate.doCopy(int inIndex, int outIndex) abstract intMSortTemplate.doEval(int leftIndex, int rightIndex) abstract intPriorityQueueCopierTemplate.doEval(int leftIndex, int rightIndex) abstract intSingleBatchSorterTemplate.doEval(char leftIndex, char rightIndex) abstract voidMSortTemplate.doSetup(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) abstract voidPriorityQueueCopierTemplate.doSetup(VectorAccessible incoming, VectorAccessible outgoing) abstract voidSingleBatchSorterTemplate.doSetup(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing) voidMSorter.setup(FragmentContext context, BufferAllocator allocator, SelectionVector4 vector4, VectorContainer hyperBatch, int outputBatchSize, int desiredBatchSize) voidMSortTemplate.setup(FragmentContext context, BufferAllocator allocator, SelectionVector4 vector4, VectorContainer hyperBatch, int outputBatchSize, int desiredBatchSize) voidPriorityQueueCopier.setup(BufferAllocator allocator, VectorAccessible hyperBatch, List<BatchGroup> batchGroups, VectorAccessible outgoing) voidPriorityQueueCopierTemplate.setup(BufferAllocator allocator, VectorAccessible hyperBatch, List<BatchGroup> batchGroups, VectorAccessible outgoing) voidSingleBatchSorter.setup(FragmentContext context, SelectionVector2 vector2, VectorAccessible incoming) voidSingleBatchSorterTemplate.setup(FragmentContext context, SelectionVector2 vector2, VectorAccessible incoming) voidSingleBatchSorter.sort(SelectionVector2 vector2) -
Uses of SchemaChangeException in org.apache.drill.exec.physical.resultSet.model.hyper
Methods in org.apache.drill.exec.physical.resultSet.model.hyper that throw SchemaChangeExceptionModifier and TypeMethodDescriptionstatic RowSetReaderImplHyperReaderBuilder.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
Methods in org.apache.drill.exec.physical.rowSet that throw SchemaChangeExceptionModifier and TypeMethodDescriptionHyperRowSetImpl.HyperRowSetBuilderImpl.build()RowSet.HyperRowSetBuilder.build()Constructors in org.apache.drill.exec.physical.rowSet that throw SchemaChangeException -
Uses of SchemaChangeException in org.apache.drill.exec.record
Methods in org.apache.drill.exec.record with parameters of type SchemaChangeExceptionModifier and TypeMethodDescriptionstatic UserExceptionAbstractRecordBatch.schemaChangeException(SchemaChangeException e, String operator, org.slf4j.Logger logger) protected UserExceptionAbstractRecordBatch.schemaChangeException(SchemaChangeException e, org.slf4j.Logger logger) Methods in org.apache.drill.exec.record that throw SchemaChangeException -
Uses of SchemaChangeException in org.apache.drill.exec.record.selection
Methods in org.apache.drill.exec.record.selection that throw SchemaChangeExceptionModifier and TypeMethodDescriptionvoidSelectionVector4Builder.add(RecordBatch batch, boolean newSchema) -
Uses of SchemaChangeException in org.apache.drill.exec.store.parquet.columnreaders
Methods in org.apache.drill.exec.store.parquet.columnreaders that throw SchemaChangeExceptionModifier and TypeMethodDescriptionvoidParquetSchema.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
Methods in org.apache.drill.exec.store.pojo that throw SchemaChangeExceptionModifier and TypeMethodDescriptionvoidAbstractPojoWriter.init(OutputMutator output) voidPojoWriter.init(OutputMutator output) Initializes value vector.