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 TypeMethodDescriptionintVectorSerializer.Writer.write(VectorAccessible va) intVectorSerializer.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 LogicalExpressionExpressionTreeMaterializer.materialize(LogicalExpression expr, VectorAccessible batch, ErrorCollector errorCollector, FunctionLookupContext functionLookupContext) static LogicalExpressionExpressionTreeMaterializer.materialize(LogicalExpression expr, VectorAccessible batch, ErrorCollector errorCollector, FunctionLookupContext functionLookupContext, boolean allowComplexWriterExpr) static LogicalExpressionExpressionTreeMaterializer.materialize(LogicalExpression expr, VectorAccessible batch, ErrorCollector errorCollector, FunctionLookupContext functionLookupContext, boolean allowComplexWriterExpr, boolean unionTypeEnabled) Materializes logical expression taking into account passed parameters.static LogicalExpressionExpressionTreeMaterializer.materializeAndCheckErrors(LogicalExpression expr, VectorAccessible batch, FunctionLookupContext functionLookupContext) Method parameters in org.apache.drill.exec.expr with type arguments of type VectorAccessibleModifier and TypeMethodDescriptionstatic LogicalExpressionExpressionTreeMaterializer.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 voidInterpreterEvaluator.evaluate(int recordCount, UdfUtilities udfUtilities, VectorAccessible incoming, ValueVector outVV, LogicalExpression expr) Constructors in org.apache.drill.exec.expr.fn.interpreter with parameters of type VectorAccessibleModifierConstructorDescriptionprotectedEvalVisitor(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 LogicalExpressionPhysicalOperatorUtil.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 TypeClassDescriptionclassclassRecord batch used for a particular scan.classclassWrite 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 TypeClassDescriptionclassclassReplaces "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 TypeMethodDescriptionvoidHashPartition.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 TypeClassDescriptionclassclassA 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 TypeClassDescriptionclassAbstractHashBinaryRecordBatch<T extends PhysicalOperator>Base class for the runtime execution implementation of the Hash-Join and Hash-SetOp operatorclassImplements the runtime execution for the Hash-Join operator supporting INNER, LEFT OUTER, RIGHT OUTER, and FULL OUTER joinsclassRecordBatch implementation for the lateral join operator.classA join operator that merges two sorted streams using a record iterator.classclassMethods in org.apache.drill.exec.physical.impl.join with parameters of type VectorAccessibleModifier and TypeMethodDescriptionstatic voidJoinUtils.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 TypeClassDescriptionclassclassHelps 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 TypeClassDescriptionclassMerges pre-sorted record batches from remote senders.Methods in org.apache.drill.exec.physical.impl.mergereceiver with parameters of type VectorAccessibleModifier and TypeMethodDescriptionvoidMergingReceiverGeneratorBase.doSetup(FragmentContext context, VectorAccessible incoming, VectorAccessible outgoing) abstract voidMergingReceiverTemplate.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 TypeClassDescriptionclassTerminal operator for producing ANALYZE statement.classResponsible for handling metadata returned by incoming aggregate operators and fetching required metadata form the Metastore.classclassOperator 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 TypeClassDescriptionclassGenerates 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 voidOrderedPartitionProjectorTemplate.doSetup(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, VectorContainer partitionVectors) abstract voidSampleCopierTemplate.doSetup(FragmentContext context, VectorAccessible incoming, VectorAccessible outgoing) protected voidOrderedPartitionRecordBatch.doWork(VectorAccessible batch) 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) voidSampleCopier.setupCopier(FragmentContext context, SelectionVector4 sv4, VectorAccessible incoming, VectorAccessible outgoing) voidSampleCopierTemplate.setupCopier(FragmentContext context, SelectionVector4 sv4, VectorAccessible incoming, VectorAccessible outgoing) protected voidOrderedPartitionRecordBatch.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 voidPartitionerTemplate.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 TypeClassDescriptionclassModular 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 TypeClassDescriptionclassProvides 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 TypeClassDescriptionclassImplements 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 TypeMethodDescriptionbooleanSortRecordBatchBuilder.add(VectorAccessible batch) Add another record batch to the set of record batches.static SorterSortBatch.createNewSorter(FragmentContext context, List<Order.Ordering> orderings, VectorAccessible batch) static SorterSortBatch.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 TypeClassDescriptionclassclassExample 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 TypeMethodDescriptionvoidAbstractCopier.setup(VectorAccessible incoming, VectorContainer outgoing) voidAbstractSV2Copier.setup(VectorAccessible incoming, VectorContainer outgoing) voidAbstractSV4Copier.setup(VectorAccessible incoming, VectorContainer outgoing) voidCopier.setup(VectorAccessible incoming, VectorContainer outgoing) voidGenericCopier.setup(VectorAccessible incoming, VectorContainer outgoing) voidStraightCopier.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 TypeClassDescriptionclassOperator Batch which implements the TopN functionality.static classMethods in org.apache.drill.exec.physical.impl.TopN with parameters of type VectorAccessibleModifier and TypeMethodDescriptionstatic PriorityQueueTopNBatch.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 TypeClassDescriptionclassContains 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 booleanBatchValidator.validate(VectorAccessible batch) voidBatchValidator.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 TypeClassDescriptionclassclasssupport for OVER(PARTITION BY expression1,expression2,...Methods in org.apache.drill.exec.physical.impl.window with parameters of type VectorAccessibleModifier and TypeMethodDescriptionabstract booleanFrameSupportTemplate.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.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 booleanFrameSupportTemplate.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 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 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) abstract voidFrameSupportTemplate.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 TypeClassDescriptionclassRepresents a group of batches spilled to disk.classExternal sort batch: a sort batch which can spill to disk in order to operate within a defined memory footprint.classThe input batch group gathers batches buffered in memory before spilling.classHolds 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 TypeMethodDescriptionvoidBufferedBatches.add(VectorAccessible incoming, long batchSize) voidSortImpl.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 voidPriorityQueueCopierTemplate.doSetup(VectorAccessible incoming, VectorAccessible outgoing) abstract voidSingleBatchSorterTemplate.doSetup(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing) protected voidBaseSortWrapper.generateComparisons(ClassGenerator<?> g, VectorAccessible batch, org.slf4j.Logger logger) PriorityQueueCopierWrapper.getCopier(VectorAccessible batch) 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) -
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 DirectRowSetDirectRowSet.fromVectorAccessible(BufferAllocator allocator, VectorAccessible va) -
Uses of VectorAccessible in org.apache.drill.exec.record
Subinterfaces of VectorAccessible in org.apache.drill.exec.recordModifier and TypeInterfaceDescriptioninterfaceinterfaceA 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 TypeClassDescriptionclassAbstractBinaryRecordBatch<T extends PhysicalOperator>classAbstractRecordBatch<T extends PhysicalOperator>classAbstractSingleRecordBatch<T extends PhysicalOperator>Implements an AbstractUnaryRecordBatch where the incoming record batch is known at the time of creationclassAbstractTableFunctionRecordBatch<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.classAbstractUnaryRecordBatch<T extends PhysicalOperator>Base class for operators that have a single input.classclassHolds record batch loaded from record batch message.classRecordIterator iterates over incoming record batches one record at a time.classEmpty batch without schema and data.classWrap a VectorContainer into a record batch.classMethods in org.apache.drill.exec.record with parameters of type VectorAccessibleModifier and TypeMethodDescriptionvoidExpandableHyperContainer.addBatch(VectorAccessible batch) voidVectorInitializer.allocateBatch(VectorAccessible va, int recordCount) static voidVectorAccessibleUtilities.allocateVectors(VectorAccessible va, int targetRecordCount) static voidVectorAccessibleUtilities.clear(VectorAccessible va) static VectorContainerSchemaUtil.coerceContainer(VectorAccessible in, BatchSchema toSchema, BufferAllocator allocator) static VectorContainerSchemaUtil.coerceContainer(VectorAccessible in, BatchSchema toSchema, OperatorContext context) Creates a copy a record batch, converting any fields as necessary to coerce it into the provided schemavoidVectorContainer.copySchemaFrom(VectorAccessible other) static WritableBatchWritableBatch.get(VectorAccessible batch) static VectorContainerVectorContainer.getTransferClone(VectorAccessible incoming, BufferAllocator allocator) static VectorContainerVectorContainer.getTransferClone(VectorAccessible incoming, OperatorContext oContext) Get a set of transferred clones of this container.static VectorContainerVectorContainer.getTransferClone(VectorAccessible incoming, VectorWrapper<?>[] ignoreWrappers, OperatorContext oContext) static voidVectorAccessibleUtilities.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 TypeMethodDescriptionvoidRecordWriter.updateSchema(VectorAccessible batch) Update the schema in RecordWriter.voidStatisticsRecordWriter.updateSchema(VectorAccessible batch) Update the schema in RecordWriter.voidStringOutputRecordWriter.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 TypeMethodDescriptionvoidJsonRecordWriter.updateSchema(VectorAccessible batch) voidJsonStatisticsRecordWriter.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 TypeMethodDescriptionvoidGoogleSheetsBatchInsertWriter.updateSchema(VectorAccessible batch) voidGoogleSheetsBatchWriter.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 TypeMethodDescriptionvoidJdbcRecordWriter.updateSchema(VectorAccessible batch) voidJdbcTableModifyWriter.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 TypeMethodDescriptionvoidSplunkBatchInsertWriter.updateSchema(VectorAccessible batch) voidSplunkBatchWriter.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 voidVectorUtil.appendVectorAccessibleContent(VectorAccessible va, StringBuilder formattedResults, String delimiter, boolean includeHeader) static voidVectorUtil.logVectorAccessibleContent(VectorAccessible va) static voidVectorUtil.logVectorAccessibleContent(VectorAccessible va, int columnWidth) static voidVectorUtil.logVectorAccessibleContent(VectorAccessible va, int[] columnWidths) static voidVectorUtil.logVectorAccessibleContent(VectorAccessible va, String delimiter) static voidBatchPrinter.printBatch(VectorAccessible batch) static voidBatchPrinter.printBatch(VectorAccessible batch, SelectionVector2 sv2) static voidBatchPrinter.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 voidCopyUtil.generateCopies(ClassGenerator<?> g, VectorAccessible batch, boolean hyper)