Uses of Interface
org.apache.drill.exec.record.VectorAccessible
Packages that use VectorAccessible
Package
Description
Distributed cache for syncing state and data between Drillbits.
Drill expression materialization and evaluation facilities.
Defines a revised implementation of the Drill RecordBatch protocol.
Provides a set of tools to work with row sets.
Drill storage plugin.
-
Uses of VectorAccessible in org.apache.drill.exec.cache
Methods in org.apache.drill.exec.cache that return VectorAccessibleMethods in org.apache.drill.exec.cache with parameters of type VectorAccessibleModifier and TypeMethodDescriptionint
VectorSerializer.Writer.write
(VectorAccessible va) int
VectorSerializer.Writer.write
(VectorAccessible va, SelectionVector2 sv2) -
Uses of VectorAccessible in org.apache.drill.exec.expr
Methods in org.apache.drill.exec.expr with parameters of type VectorAccessibleModifier and TypeMethodDescriptionstatic 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) Method parameters in org.apache.drill.exec.expr with type arguments of type VectorAccessibleModifier and TypeMethodDescriptionstatic 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. -
Uses of VectorAccessible in org.apache.drill.exec.expr.fn.interpreter
Methods in org.apache.drill.exec.expr.fn.interpreter with parameters of type VectorAccessibleModifier and TypeMethodDescriptionstatic void
InterpreterEvaluator.evaluate
(int recordCount, UdfUtilities udfUtilities, VectorAccessible incoming, ValueVector outVV, LogicalExpression expr) Constructors in org.apache.drill.exec.expr.fn.interpreter with parameters of type VectorAccessibleModifierConstructorDescriptionprotected
EvalVisitor
(VectorAccessible incoming, UdfUtilities udfUtilities) -
Uses of VectorAccessible in org.apache.drill.exec.physical.base
Methods in org.apache.drill.exec.physical.base with parameters of type VectorAccessibleModifier and TypeMethodDescriptionstatic LogicalExpression
PhysicalOperatorUtil.materializeExpression
(LogicalExpression expr, VectorAccessible incoming, FragmentContext context) Helper method to materialize the given logical expression using theExpressionTreeMaterializer
. -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl
Classes in org.apache.drill.exec.physical.impl that implement VectorAccessibleModifier and TypeClassDescriptionclass
class
Record batch used for a particular scan.class
class
Write the RecordBatch to the given RecordWriter. -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.aggregate
Classes in org.apache.drill.exec.physical.impl.aggregate that implement VectorAccessibleModifier and TypeClassDescriptionclass
class
Replaces "incoming" - instead scanning a spilled partition fileclass
-
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.common
Methods in org.apache.drill.exec.physical.impl.common with parameters of type VectorAccessibleModifier and TypeMethodDescriptionvoid
HashPartition.appendBatch
(VectorAccessible batch) Append the incoming batch (actually only the vectors of that batch) into the tmp list -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.filter
Classes in org.apache.drill.exec.physical.impl.filter that implement VectorAccessibleModifier and TypeClassDescriptionclass
class
A RuntimeFilterRecordBatch steps over the ScanBatch. -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.flatten
Classes in org.apache.drill.exec.physical.impl.flatten that implement VectorAccessible -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.join
Classes in org.apache.drill.exec.physical.impl.join that implement VectorAccessibleModifier and TypeClassDescriptionclass
AbstractHashBinaryRecordBatch<T extends PhysicalOperator>
Base class for the runtime execution implementation of the Hash-Join and Hash-SetOp operatorclass
Implements the runtime execution for the Hash-Join operator supporting INNER, LEFT OUTER, RIGHT OUTER, and FULL OUTER joinsclass
RecordBatch implementation for the lateral join operator.class
A join operator that merges two sorted streams using a record iterator.class
class
Methods in org.apache.drill.exec.physical.impl.join with parameters of type VectorAccessibleModifier and TypeMethodDescriptionstatic 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. -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.limit
Classes in org.apache.drill.exec.physical.impl.limit that implement VectorAccessibleModifier and TypeClassDescriptionclass
class
Helps to perform limit in a partition within a record batch. -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.mergereceiver
Classes in org.apache.drill.exec.physical.impl.mergereceiver that implement VectorAccessibleModifier and TypeClassDescriptionclass
Merges pre-sorted record batches from remote senders.Methods in org.apache.drill.exec.physical.impl.mergereceiver with parameters of type VectorAccessibleModifier and TypeMethodDescriptionvoid
MergingReceiverGeneratorBase.doSetup
(FragmentContext context, VectorAccessible incoming, VectorAccessible outgoing) abstract void
MergingReceiverTemplate.doSetup
(FragmentContext context, VectorAccessible incoming, VectorAccessible outgoing) -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.metadata
Classes in org.apache.drill.exec.physical.impl.metadata that implement VectorAccessibleModifier and TypeClassDescriptionclass
Terminal operator for producing ANALYZE statement.class
Responsible for handling metadata returned by incoming aggregate operators and fetching required metadata form the Metastore.class
class
Operator which adds aggregate calls for all incoming columns to calculate required metadata and produces aggregations. -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.orderedpartitioner
Classes in org.apache.drill.exec.physical.impl.orderedpartitioner that implement VectorAccessibleModifier and TypeClassDescriptionclass
Generates an ordered partition, rather than a random hash partition.Methods in org.apache.drill.exec.physical.impl.orderedpartitioner with parameters of type VectorAccessibleModifier and TypeMethodDescriptionabstract 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) final 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 -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.partitionsender
Classes in org.apache.drill.exec.physical.impl.partitionsender that implement VectorAccessibleMethods in org.apache.drill.exec.physical.impl.partitionsender with parameters of type VectorAccessibleModifier and TypeMethodDescriptionprotected void
PartitionerTemplate.OutgoingRecordBatch.doSetup
(RecordBatch incoming, VectorAccessible outgoing) -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.producer
Classes in org.apache.drill.exec.physical.impl.producer that implement VectorAccessible -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.project
Classes in org.apache.drill.exec.physical.impl.project that implement VectorAccessible -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.protocol
Classes in org.apache.drill.exec.physical.impl.protocol that implement VectorAccessibleModifier and TypeClassDescriptionclass
Modular implementation of the standard Drill record batch iterator protocol. -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.rangepartitioner
Classes in org.apache.drill.exec.physical.impl.rangepartitioner that implement VectorAccessibleModifier and TypeClassDescriptionclass
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). -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.setop
Classes in org.apache.drill.exec.physical.impl.setop that implement VectorAccessibleModifier and TypeClassDescriptionclass
Implements the runtime execution for the Hash-SetOp operator supporting EXCEPT, EXCEPT ALL, INTERSECT, and INTERSECT ALL -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.sort
Classes in org.apache.drill.exec.physical.impl.sort that implement VectorAccessibleMethods in org.apache.drill.exec.physical.impl.sort with parameters of type VectorAccessibleModifier and TypeMethodDescriptionboolean
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) Constructors in org.apache.drill.exec.physical.impl.sort with parameters of type VectorAccessible -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.statistics
Classes in org.apache.drill.exec.physical.impl.statistics that implement VectorAccessibleModifier and TypeClassDescriptionclass
class
Example input and output: Schema of incoming batch: -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.svremover
Classes in org.apache.drill.exec.physical.impl.svremover that implement VectorAccessibleMethods in org.apache.drill.exec.physical.impl.svremover with parameters of type VectorAccessibleModifier and TypeMethodDescriptionvoid
AbstractCopier.setup
(VectorAccessible incoming, VectorContainer outgoing) void
AbstractSV2Copier.setup
(VectorAccessible incoming, VectorContainer outgoing) void
AbstractSV4Copier.setup
(VectorAccessible incoming, VectorContainer outgoing) void
Copier.setup
(VectorAccessible incoming, VectorContainer outgoing) void
GenericCopier.setup
(VectorAccessible incoming, VectorContainer outgoing) void
StraightCopier.setup
(VectorAccessible incoming, VectorContainer outgoing) -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.TopN
Classes in org.apache.drill.exec.physical.impl.TopN that implement VectorAccessibleModifier and TypeClassDescriptionclass
Operator Batch which implements the TopN functionality.static class
Methods in org.apache.drill.exec.physical.impl.TopN with parameters of type VectorAccessibleModifier and TypeMethodDescriptionstatic 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) -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.trace
Classes in org.apache.drill.exec.physical.impl.trace that implement VectorAccessibleModifier and TypeClassDescriptionclass
Contains value vectors which are exactly the same as the incoming record batch's value vectors. -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.union
Classes in org.apache.drill.exec.physical.impl.union that implement VectorAccessible -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.unnest
Classes in org.apache.drill.exec.physical.impl.unnest that implement VectorAccessible -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.unorderedreceiver
Classes in org.apache.drill.exec.physical.impl.unorderedreceiver that implement VectorAccessible -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.unpivot
Classes in org.apache.drill.exec.physical.impl.unpivot that implement VectorAccessible -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.validate
Classes in org.apache.drill.exec.physical.impl.validate that implement VectorAccessibleMethods in org.apache.drill.exec.physical.impl.validate with parameters of type VectorAccessibleModifier and TypeMethodDescriptionstatic boolean
BatchValidator.validate
(VectorAccessible batch) void
BatchValidator.validateBatch
(VectorAccessible batch, int rowCount) -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.window
Classes in org.apache.drill.exec.physical.impl.window that implement VectorAccessibleModifier and TypeClassDescriptionclass
class
support for OVER(PARTITION BY expression1,expression2,...Methods in org.apache.drill.exec.physical.impl.window with parameters of type VectorAccessibleModifier and TypeMethodDescriptionabstract 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 expressionabstract 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
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 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
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) Constructors in org.apache.drill.exec.physical.impl.window with parameters of type VectorAccessible -
Uses of VectorAccessible in org.apache.drill.exec.physical.impl.xsort
Classes in org.apache.drill.exec.physical.impl.xsort that implement VectorAccessibleModifier and TypeClassDescriptionclass
Represents a group of batches spilled to disk.class
External sort batch: a sort batch which can spill to disk in order to operate within a defined memory footprint.class
The input batch group gathers batches buffered in memory before spilling.class
Holds a set of spilled batches, represented by a file on disk.Methods in org.apache.drill.exec.physical.impl.xsort with parameters of type VectorAccessibleModifier and TypeMethodDescriptionvoid
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
PriorityQueueCopierTemplate.doSetup
(VectorAccessible incoming, VectorAccessible outgoing) abstract void
SingleBatchSorterTemplate.doSetup
(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing) protected void
BaseSortWrapper.generateComparisons
(ClassGenerator<?> g, VectorAccessible batch, org.slf4j.Logger logger) PriorityQueueCopierWrapper.getCopier
(VectorAccessible batch) 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) -
Uses of VectorAccessible in org.apache.drill.exec.physical.rowSet
Methods in org.apache.drill.exec.physical.rowSet that return VectorAccessibleMethods in org.apache.drill.exec.physical.rowSet with parameters of type VectorAccessibleModifier and TypeMethodDescriptionstatic DirectRowSet
DirectRowSet.fromVectorAccessible
(BufferAllocator allocator, VectorAccessible va) -
Uses of VectorAccessible in org.apache.drill.exec.record
Subinterfaces of VectorAccessible in org.apache.drill.exec.recordModifier and TypeInterfaceDescriptioninterface
interface
A record batch contains a set of field values for a particular range of records.Classes in org.apache.drill.exec.record that implement VectorAccessibleModifier and TypeClassDescriptionclass
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 creationclass
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
class
Holds record batch loaded from record batch message.class
RecordIterator iterates over incoming record batches one record at a time.class
Empty batch without schema and data.class
Wrap a VectorContainer into a record batch.class
Methods in org.apache.drill.exec.record with parameters of type VectorAccessibleModifier and TypeMethodDescriptionvoid
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 schemavoid
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) Constructors in org.apache.drill.exec.record with parameters of type VectorAccessibleModifierConstructorDescriptionCreate empirical metadata for a record batch given a vector accessible (basically, an iterator over the vectors in the batch.)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. -
Uses of VectorAccessible in org.apache.drill.exec.store
Methods in org.apache.drill.exec.store with parameters of type VectorAccessibleModifier and TypeMethodDescriptionvoid
RecordWriter.updateSchema
(VectorAccessible batch) Update the schema in RecordWriter.void
StatisticsRecordWriter.updateSchema
(VectorAccessible batch) Update the schema in RecordWriter.void
StringOutputRecordWriter.updateSchema
(VectorAccessible batch) Constructors in org.apache.drill.exec.store with parameters of type VectorAccessibleModifierConstructorDescriptionEventBasedRecordWriter
(VectorAccessible batch, RecordWriter recordWriter) StatisticsRecordWriterImpl
(VectorAccessible batch, StatisticsRecordWriter recordWriter) -
Uses of VectorAccessible in org.apache.drill.exec.store.drill.plugin
Classes in org.apache.drill.exec.store.drill.plugin that implement VectorAccessible -
Uses of VectorAccessible in org.apache.drill.exec.store.easy.json
Methods in org.apache.drill.exec.store.easy.json with parameters of type VectorAccessibleModifier and TypeMethodDescriptionvoid
JsonRecordWriter.updateSchema
(VectorAccessible batch) void
JsonStatisticsRecordWriter.updateSchema
(VectorAccessible batch) -
Uses of VectorAccessible in org.apache.drill.exec.store.googlesheets
Methods in org.apache.drill.exec.store.googlesheets with parameters of type VectorAccessibleModifier and TypeMethodDescriptionvoid
GoogleSheetsBatchInsertWriter.updateSchema
(VectorAccessible batch) void
GoogleSheetsBatchWriter.updateSchema
(VectorAccessible batch) -
Uses of VectorAccessible in org.apache.drill.exec.store.jdbc
Methods in org.apache.drill.exec.store.jdbc with parameters of type VectorAccessibleModifier and TypeMethodDescriptionvoid
JdbcRecordWriter.updateSchema
(VectorAccessible batch) void
JdbcTableModifyWriter.updateSchema
(VectorAccessible batch) -
Uses of VectorAccessible in org.apache.drill.exec.store.kudu
Methods in org.apache.drill.exec.store.kudu with parameters of type VectorAccessible -
Uses of VectorAccessible in org.apache.drill.exec.store.parquet
Methods in org.apache.drill.exec.store.parquet with parameters of type VectorAccessible -
Uses of VectorAccessible in org.apache.drill.exec.store.splunk
Methods in org.apache.drill.exec.store.splunk with parameters of type VectorAccessibleModifier and TypeMethodDescriptionvoid
SplunkBatchInsertWriter.updateSchema
(VectorAccessible batch) void
SplunkBatchWriter.updateSchema
(VectorAccessible batch) Update the schema in RecordWriter. -
Uses of VectorAccessible in org.apache.drill.exec.util
Methods in org.apache.drill.exec.util with parameters of type VectorAccessibleModifier and TypeMethodDescriptionstatic 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) -
Uses of VectorAccessible in org.apache.drill.exec.vector
Methods in org.apache.drill.exec.vector with parameters of type VectorAccessibleModifier and TypeMethodDescriptionstatic void
CopyUtil.generateCopies
(ClassGenerator<?> g, VectorAccessible batch, boolean hyper)