Uses of Interface
org.apache.drill.exec.memory.BufferAllocator
Package
Description
Distributed cache for syncing state and data between Drillbits.
Java client API for submitting queries and accepting result sets from a Drill
server.
Drill expression materialization and evaluation facilities.
Memory Allocation, Account and Management
See the README.md file in this directory for detailed information about Drill's memory allocation subsystem.
Provides run-time semantic analysis of the projection list for the
scan operator.
Implements the details of the scan lifecycle for a set of readers,
primarily the process of resolving the scan output schema from a variety
of input schemas, then running each reader, each of which will produce
some number of batches.
Provides a second-generation row set (AKA "record batch") writer used
by client code to
Define the schema of a result set.
Write data into the vectors backing a row set.
Handles the details of the result set loader implementation.
This set of classes models the structure of a batch consisting
of single vectors (as contrasted with a hyper batch.) Provides tools
or metdata-based construction, allocation, reading and writing of
the vectors.
Provides a set of tools to work with row sets.
Drill storage plugin.
-
Uses of BufferAllocator in io.netty.buffer
Modifier and TypeMethodDescriptionDrillBuf.retain
(BufferAllocator target) Create a new DrillBuf that is associated with an alternative allocator for the purposes of memory ownership and accounting.DrillBuf.transferOwnership
(BufferAllocator target) Transfer the memory accounting ownership of this DrillBuf to another allocator.ModifierConstructorDescriptionExpandableByteBuf
(io.netty.buffer.ByteBuf buffer, BufferAllocator allocator) -
Uses of BufferAllocator in org.apache.drill.exec.cache
Modifier and TypeMethodDescriptionstatic VectorSerializer.Reader
VectorSerializer.reader
(BufferAllocator allocator, InputStream stream) ModifierConstructorDescriptionCachedVectorContainer
(byte[] data, BufferAllocator allocator) CachedVectorContainer
(BufferAllocator allocator) CachedVectorContainer
(WritableBatch batch, BufferAllocator allocator) Reader
(BufferAllocator allocator, InputStream stream) VectorAccessibleSerializable
(BufferAllocator allocator) VectorAccessibleSerializable
(WritableBatch batch, BufferAllocator allocator) VectorAccessibleSerializable
(WritableBatch batch, SelectionVector2 sv2, BufferAllocator allocator) Creates a wrapper around batch and sv2 for writing to a stream. -
Uses of BufferAllocator in org.apache.drill.exec.client
ModifierConstructorDescriptionDrillClient
(DrillConfig config, ClusterCoordinator coordinator, BufferAllocator allocator) DrillClient
(DrillConfig config, ClusterCoordinator coordinator, BufferAllocator allocator, boolean isDirect) -
Uses of BufferAllocator in org.apache.drill.exec.expr
Modifier and TypeMethodDescriptionstatic ValueVector
BasicTypeHelper.getNewVector
(String name, BufferAllocator allocator, TypeProtos.MajorType type, CallBack callback) static ValueVector
BasicTypeHelper.getNewVector
(MaterializedField field, TypeProtos.MajorType type, BufferAllocator allocator, CallBack callBack) static ValueVector
BasicTypeHelper.getNewVector
(MaterializedField field, BufferAllocator allocator) static ValueVector
BasicTypeHelper.getNewVector
(MaterializedField field, BufferAllocator allocator, CallBack callBack) -
Uses of BufferAllocator in org.apache.drill.exec.memory
Modifier and TypeClassDescriptionclass
class
The root allocator for using direct memory inside a Drillbit.Modifier and TypeMethodDescriptionBaseAllocator.newChildAllocator
(String name, long initReservation, long maxAllocation) BufferAllocator.newChildAllocator
(String name, long initReservation, long maxAllocation) Create a new child allocator.static BufferAllocator
RootAllocatorFactory.newRoot
(long maxAlloc) static BufferAllocator
RootAllocatorFactory.newRoot
(DrillConfig drillConfig) Create a new Root AllocatorModifier and TypeMethodDescriptionAllocationManager.BufferLedger.getLedgerForAllocator
(BufferAllocator allocator) Returns the ledger associated with a particular BufferAllocator. -
Uses of BufferAllocator in org.apache.drill.exec.ops
Modifier and TypeMethodDescriptionBaseOperatorContext.getAllocator()
BufferManager.getAllocator()
BufferManagerImpl.getAllocator()
FragmentContext.getAllocator()
FragmentContextImpl.getAllocator()
Deprecated.OperatorContext.getAllocator()
Return the memory allocator for this operator.OptimizerRulesContext.getAllocator()
Method returns the allocatorQueryContext.getAllocator()
FragmentContext.getNewChildAllocator
(String operatorName, int operatorId, long initialReservation, long maximumReservation) FragmentContextImpl.getNewChildAllocator
(String operatorName, int operatorId, long initialReservation, long maximumReservation) ExecutorFragmentContext.getRootAllocator()
Returns the root allocator for the Drillbit.FragmentContextImpl.getRootAllocator()
Modifier and TypeMethodDescriptionFragmentStats.newOperatorStats
(OpProfileDef profileDef, BufferAllocator allocator) Creates a new holder for operator statistics within this holder for fragment statistics.ModifierConstructorDescriptionBaseOperatorContext
(FragmentContext context, BufferAllocator allocator, PhysicalOperator popConfig) BufferManagerImpl
(BufferAllocator allocator) FragmentStats
(BufferAllocator allocator, CoordinationProtos.DrillbitEndpoint endpoint) OperatorStats
(int operatorId, String operatorType, int inputCount, BufferAllocator allocator) OperatorStats
(OpProfileDef def, BufferAllocator allocator) -
Uses of BufferAllocator in org.apache.drill.exec.physical.impl
ModifierConstructorDescriptionMutator
(OperatorContext oContext, BufferAllocator allocator, VectorContainer container) -
Uses of BufferAllocator in org.apache.drill.exec.physical.impl.aggregate
-
Uses of BufferAllocator in org.apache.drill.exec.physical.impl.common
Modifier and TypeMethodDescriptionvoid
HashTable.setup
(HashTableConfig htConfig, BufferAllocator allocator, VectorContainer incomingBuild, RecordBatch incomingProbe, RecordBatch outgoing, VectorContainer htContainerOrig, FragmentContext context, ClassGenerator<?> cg) HashTable.setup(org.apache.drill.exec.physical.impl.common.HashTableConfig, org.apache.drill.exec.memory.BufferAllocator, org.apache.drill.exec.record.VectorContainer, org.apache.drill.exec.record.RecordBatch, org.apache.drill.exec.record.RecordBatch, org.apache.drill.exec.record.VectorContainer, org.apache.drill.exec.ops.FragmentContext, org.apache.drill.exec.expr.ClassGenerator<?>)
must be called before anything can be done to theHashTable
.void
HashTableTemplate.setup
(HashTableConfig htConfig, BufferAllocator allocator, VectorContainer incomingBuild, RecordBatch incomingProbe, RecordBatch outgoing, VectorContainer htContainerOrig, FragmentContext context, ClassGenerator<?> cg) ModifierConstructorDescriptionChainedHashTable
(HashTableConfig htConfig, FragmentContext context, BufferAllocator allocator, RecordBatch incomingBuild, RecordBatch incomingProbe, RecordBatch outgoing) HashPartition
(FragmentContext context, BufferAllocator allocator, ChainedHashTable baseHashTable, RecordBatch buildBatch, RecordBatch probeBatch, boolean semiJoin, int recordsPerBatch, SpillSet spillSet, int partNum, int cycleNum, int numPartitions) -
Uses of BufferAllocator in org.apache.drill.exec.physical.impl.join
Modifier and TypeFieldDescriptionprotected final BufferAllocator
AbstractHashBinaryRecordBatch.allocator
-
Uses of BufferAllocator in org.apache.drill.exec.physical.impl.partitionsender
Modifier and TypeMethodDescriptionprotected PartitionerTemplate.OutgoingRecordBatch
PartitionerTemplate.newOutgoingRecordBatch
(OperatorStats stats, HashPartitionSender operator, AccountingDataTunnel tunnel, FragmentContext context, BufferAllocator allocator, int oppositeMinorFragmentId) Shim method to be overridden in plain-old Java mode by the subclass to instantiate the generated inner class.ModifierConstructorDescriptionOutgoingRecordBatch
(OperatorStats stats, HashPartitionSender operator, AccountingDataTunnel tunnel, FragmentContext context, BufferAllocator allocator, int oppositeMinorFragmentId) -
Uses of BufferAllocator in org.apache.drill.exec.physical.impl.scan.project
Modifier and TypeFieldDescriptionprotected final BufferAllocator
ScanSchemaOrchestrator.allocator
Modifier and TypeMethodDescriptionabstract BufferAllocator
ResolvedTuple.allocator()
ResolvedTuple.ResolvedDictArray.allocator()
ResolvedTuple.ResolvedMap.allocator()
ResolvedTuple.ResolvedRow.allocator()
ResolvedTuple.ResolvedSingleDict.allocator()
Modifier and TypeMethodDescriptionprotected abstract AbstractMapVector
ResolvedTuple.ResolvedMap.createMap
(AbstractMapVector inputMap, MaterializedField create, BufferAllocator allocator) protected AbstractMapVector
ResolvedTuple.ResolvedMapArray.createMap
(AbstractMapVector inputMap, MaterializedField schema, BufferAllocator allocator) protected AbstractMapVector
ResolvedTuple.ResolvedSingleMap.createMap
(AbstractMapVector inputMap, MaterializedField schema, BufferAllocator allocator) ModifierConstructorDescriptionScanSchemaOrchestrator
(BufferAllocator allocator, ScanSchemaOrchestrator.ScanOrchestratorBuilder builder) -
Uses of BufferAllocator in org.apache.drill.exec.physical.impl.scan.v3.lifecycle
ModifierConstructorDescriptionOutputBatchBuilder
(TupleMetadata outputSchema, List<OutputBatchBuilder.BatchSource> sources, BufferAllocator allocator) -
Uses of BufferAllocator in org.apache.drill.exec.physical.impl.sort
-
Uses of BufferAllocator in org.apache.drill.exec.physical.impl.TopN
Modifier 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) void
PriorityQueue.init
(int limit, BufferAllocator allocator, boolean hasSv2) Initializes the priority queue.void
PriorityQueueTemplate.init
(int limit, BufferAllocator allocator, boolean hasSv2) -
Uses of BufferAllocator in org.apache.drill.exec.physical.impl.xsort
Modifier and TypeMethodDescriptionvoid
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) ModifierConstructorDescriptionBatchGroup
(VectorContainer container, BufferAllocator allocator) InputBatch
(VectorContainer container, SelectionVector2 sv2, BufferAllocator allocator, long dataSize) SpilledRun
(SpillSet spillSet, String path, BufferAllocator allocator) -
Uses of BufferAllocator in org.apache.drill.exec.physical.resultSet
-
Uses of BufferAllocator in org.apache.drill.exec.physical.resultSet.impl
Modifier and TypeMethodDescriptionNullResultVectorCacheImpl.allocator()
ResultSetLoaderImpl.allocator()
ResultVectorCacheImpl.allocator()
ModifierConstructorDescriptionNullResultVectorCacheImpl
(BufferAllocator allocator) ResultSetCopierImpl
(BufferAllocator allocator, PullResultSetReader source) ResultSetCopierImpl
(BufferAllocator allocator, PullResultSetReader source, ResultSetOptionBuilder outputOptions) ResultSetLoaderImpl
(BufferAllocator allocator) ResultSetLoaderImpl
(BufferAllocator allocator, ResultSetLoaderImpl.ResultSetOptions options) ResultVectorCacheImpl
(BufferAllocator allocator) ResultVectorCacheImpl
(BufferAllocator allocator, boolean permissiveMode) -
Uses of BufferAllocator in org.apache.drill.exec.physical.resultSet.model.single
-
Uses of BufferAllocator in org.apache.drill.exec.physical.rowSet
Modifier and TypeMethodDescriptionstatic RowSet.HyperRowSetBuilder
HyperRowSetImpl.builder
(BufferAllocator allocator) static RowSet
RowSetBuilder.emptyBatch
(BufferAllocator allocator, TupleMetadata schema) static RowSet.HyperRowSet
HyperRowSetImpl.fromRowSets
(BufferAllocator allocator, RowSet.SingleRowSet... rowSets) static DirectRowSet
DirectRowSet.fromSchema
(BufferAllocator allocator, BatchSchema schema) static DirectRowSet
DirectRowSet.fromSchema
(BufferAllocator allocator, TupleMetadata schema) static DirectRowSet
DirectRowSet.fromVectorAccessible
(BufferAllocator allocator, VectorAccessible va) ModifierConstructorDescriptionHyperRowSetBuilderImpl
(BufferAllocator allocator) RowSetBuilder
(BufferAllocator allocator, BatchSchema schema) Deprecated.RowSetBuilder
(BufferAllocator allocator, TupleMetadata schema) RowSetBuilder
(BufferAllocator allocator, TupleMetadata schema, int capacity) -
Uses of BufferAllocator in org.apache.drill.exec.record
Modifier and TypeMethodDescriptionHyperVectorWrapper.cloneAndTransfer
(BufferAllocator allocator) SimpleVectorWrapper.cloneAndTransfer
(BufferAllocator allocator) VectorWrapper.cloneAndTransfer
(BufferAllocator allocator) static VectorContainer
SchemaUtil.coerceContainer
(VectorAccessible in, BatchSchema toSchema, BufferAllocator allocator) static VectorContainer
VectorContainer.getTransferClone
(VectorAccessible incoming, BufferAllocator allocator) void
WritableBatch.reconstructContainer
(BufferAllocator allocator, VectorContainer container) WritableBatch.transfer
(BufferAllocator allocator) ModifierConstructorDescriptionRecordBatchLoader
(BufferAllocator allocator) Constructs a loader using the given allocator for vector buffer allocation.VectorContainer
(BufferAllocator allocator) VectorContainer
(BufferAllocator allocator, BatchSchema schema) Create a new vector container given a pre-defined schema. -
Uses of BufferAllocator in org.apache.drill.exec.record.selection
ModifierConstructorDescriptionSelectionVector2
(BufferAllocator allocator) SelectionVector2
(BufferAllocator allocator, DrillBuf buf, int count) Create a selection vector with the given buffer.SelectionVector2
(BufferAllocator allocator, DrillBuf buf, int count, int actualRecordCount) SelectionVector2Builder
(BufferAllocator allocator, int maxSize) SelectionVector4
(BufferAllocator allocator, int recordCount) -
Uses of BufferAllocator in org.apache.drill.exec.rpc
Modifier and TypeMethodDescriptionAbstractConnectionConfig.getAllocator()
AbstractServerConnection.getAllocator()
ConnectionConfig.getAllocator()
RemoteConnection.getAllocator()
Modifier and TypeMethodDescriptionabstract ProtobufLengthDecoder
BasicClient.getDecoder
(BufferAllocator allocator) protected abstract ProtobufLengthDecoder
BasicServer.getDecoder
(BufferAllocator allocator, OutOfMemoryHandler outOfMemoryHandler) abstract void
AbstractRpcMetrics.initialize
(boolean useEncryptedCounter, BufferAllocator allocator) protected void
AbstractRpcMetrics.registerAllocatorMetrics
(BufferAllocator allocator, String metricPrefix) ModifierConstructorDescriptionprotected
AbstractConnectionConfig
(BufferAllocator allocator, BootStrapContext context) protected
BitConnectionConfig
(BufferAllocator allocator, BootStrapContext context) ProtobufLengthDecoder
(BufferAllocator allocator, OutOfMemoryHandler outOfMemoryHandler) -
Uses of BufferAllocator in org.apache.drill.exec.rpc.control
Modifier and TypeMethodDescriptionControlClient.getDecoder
(BufferAllocator allocator) protected ProtobufLengthDecoder
ControlServer.getDecoder
(BufferAllocator allocator, OutOfMemoryHandler outOfMemoryHandler) void
ControlRpcMetrics.initialize
(boolean useEncryptedCounter, BufferAllocator allocator) Should only be called when first access to getInstance is made.ModifierConstructorDescriptionControllerImpl
(BootStrapContext context, BufferAllocator allocator, ControlMessageHandler handler) ControlProtobufLengthDecoder
(BufferAllocator allocator, OutOfMemoryHandler outOfMemoryHandler) -
Uses of BufferAllocator in org.apache.drill.exec.rpc.data
Modifier and TypeMethodDescriptionDataClient.getDecoder
(BufferAllocator allocator) protected ProtobufLengthDecoder
DataServer.getDecoder
(BufferAllocator allocator, OutOfMemoryHandler outOfMemoryHandler) void
DataRpcMetrics.initialize
(boolean useEncryptedCounter, BufferAllocator allocator) Should only be called when first access to getInstance is made.IncomingDataBatch.newRawFragmentBatch
(BufferAllocator allocator) Create a new RawFragmentBatch based on this incoming data batch that is transferred into the provided allocator.ModifierConstructorDescriptionClient
(BufferAllocator allocator, OutOfMemoryHandler outOfMemoryHandler) DataConnectionCreator
(BootStrapContext context, BufferAllocator allocator, WorkEventBus workBus, WorkManager.WorkerBee bee) Server
(BufferAllocator allocator, OutOfMemoryHandler outOfMemoryHandler) -
Uses of BufferAllocator in org.apache.drill.exec.rpc.user
Modifier and TypeMethodDescriptionUserClient.getDecoder
(BufferAllocator allocator) protected ProtobufLengthDecoder
UserServer.getDecoder
(BufferAllocator allocator, OutOfMemoryHandler outOfMemoryHandler) void
UserRpcMetrics.initialize
(boolean useEncryptedCounter, BufferAllocator allocator) Should only be called when first access to getInstance is made.ModifierConstructorDescriptionUserClient
(String clientName, DrillConfig config, Properties properties, boolean supportComplexTypes, BufferAllocator allocator, io.netty.channel.EventLoopGroup eventLoopGroup, Executor eventExecutor, CoordinationProtos.DrillbitEndpoint endpoint) UserProtobufLengthDecoder
(BufferAllocator allocator, OutOfMemoryHandler outOfMemoryHandler) UserServer
(BootStrapContext context, BufferAllocator allocator, io.netty.channel.EventLoopGroup eventLoopGroup, UserWorker worker) -
Uses of BufferAllocator in org.apache.drill.exec.server
-
Uses of BufferAllocator in org.apache.drill.exec.server.rest
-
Uses of BufferAllocator in org.apache.drill.exec.ssl
Modifier and TypeMethodDescriptionSSLConfig.createSSLEngine
(BufferAllocator allocator, String peerHost, int peerPort) SSLConfigClient.createSSLEngine
(BufferAllocator allocator, String peerHost, int peerPort) SSLConfigServer.createSSLEngine
(BufferAllocator allocator, String peerHost, int peerPort) -
Uses of BufferAllocator in org.apache.drill.exec.store
-
Uses of BufferAllocator in org.apache.drill.exec.store.drill.plugin
Modifier and TypeMethodDescriptionDrillStoragePluginConfig.getDrillClient
(String userName, BufferAllocator allocator) -
Uses of BufferAllocator in org.apache.drill.exec.store.easy.text.writer
ModifierConstructorDescriptionTextRecordWriter
(BufferAllocator allocator, StorageStrategy storageStrategy, org.apache.hadoop.conf.Configuration fsConf) -
Uses of BufferAllocator in org.apache.drill.exec.store.parquet
-
Uses of BufferAllocator in org.apache.drill.exec.store.parquet.columnreaders.batchsizing
Modifier and TypeMethodDescriptionstatic RecordBatchOverflow.Builder
RecordBatchOverflow.newBuilder
(BufferAllocator allocator, RecordBatchStats.RecordBatchStatsContext batchStatsContext) -
Uses of BufferAllocator in org.apache.drill.exec.util.filereader
ModifierConstructorDescriptionBufferedDirectBufInputStream
(InputStream in, BufferAllocator allocator, String id, long startOffset, long totalByteSize, boolean enforceTotalByteSize, boolean enableHints) Creates aBufferedDirectBufInputStream
with the default (8 MiB) buffer size.BufferedDirectBufInputStream
(InputStream in, BufferAllocator allocator, String id, long startOffset, long totalByteSize, int bufSize, boolean enforceTotalByteSize, boolean enableHints) Creates aBufferedDirectBufInputStream
with the specified buffer size.DirectBufInputStream
(InputStream in, BufferAllocator allocator, String id, long startOffset, long totalByteSize, boolean enforceTotalByteSize, boolean enableHints) -
Uses of BufferAllocator in org.apache.drill.exec.util.record
Modifier and TypeMethodDescriptionstatic String
RecordBatchStats.printAllocatorStats
(BufferAllocator allocator) -
Uses of BufferAllocator in org.apache.drill.exec.vector
Modifier and TypeMethodDescriptionBaseValueVector.getAllocator()
ValueVector.getAllocator()
ZeroVector.getAllocator()
Modifier and TypeMethodDescriptionBaseValueVector.getTransferPair
(BufferAllocator allocator) BigIntVector.getTransferPair
(String ref, BufferAllocator allocator) BigIntVector.getTransferPair
(BufferAllocator allocator) BitVector.getTransferPair
(String ref, BufferAllocator allocator) BitVector.getTransferPair
(BufferAllocator allocator) DateVector.getTransferPair
(String ref, BufferAllocator allocator) DateVector.getTransferPair
(BufferAllocator allocator) Decimal18Vector.getTransferPair
(String ref, BufferAllocator allocator) Decimal18Vector.getTransferPair
(BufferAllocator allocator) Decimal28DenseVector.getTransferPair
(String ref, BufferAllocator allocator) Decimal28DenseVector.getTransferPair
(BufferAllocator allocator) Decimal28SparseVector.getTransferPair
(String ref, BufferAllocator allocator) Decimal28SparseVector.getTransferPair
(BufferAllocator allocator) Decimal38DenseVector.getTransferPair
(String ref, BufferAllocator allocator) Decimal38DenseVector.getTransferPair
(BufferAllocator allocator) Decimal38SparseVector.getTransferPair
(String ref, BufferAllocator allocator) Decimal38SparseVector.getTransferPair
(BufferAllocator allocator) Decimal9Vector.getTransferPair
(String ref, BufferAllocator allocator) Decimal9Vector.getTransferPair
(BufferAllocator allocator) Float4Vector.getTransferPair
(String ref, BufferAllocator allocator) Float4Vector.getTransferPair
(BufferAllocator allocator) Float8Vector.getTransferPair
(String ref, BufferAllocator allocator) Float8Vector.getTransferPair
(BufferAllocator allocator) IntervalDayVector.getTransferPair
(String ref, BufferAllocator allocator) IntervalDayVector.getTransferPair
(BufferAllocator allocator) IntervalVector.getTransferPair
(String ref, BufferAllocator allocator) IntervalVector.getTransferPair
(BufferAllocator allocator) IntervalYearVector.getTransferPair
(String ref, BufferAllocator allocator) IntervalYearVector.getTransferPair
(BufferAllocator allocator) IntVector.getTransferPair
(String ref, BufferAllocator allocator) IntVector.getTransferPair
(BufferAllocator allocator) NullableBigIntVector.getTransferPair
(String ref, BufferAllocator allocator) NullableBigIntVector.getTransferPair
(BufferAllocator allocator) NullableBitVector.getTransferPair
(String ref, BufferAllocator allocator) NullableBitVector.getTransferPair
(BufferAllocator allocator) NullableDateVector.getTransferPair
(String ref, BufferAllocator allocator) NullableDateVector.getTransferPair
(BufferAllocator allocator) NullableDecimal18Vector.getTransferPair
(String ref, BufferAllocator allocator) NullableDecimal18Vector.getTransferPair
(BufferAllocator allocator) NullableDecimal28DenseVector.getTransferPair
(String ref, BufferAllocator allocator) NullableDecimal28DenseVector.getTransferPair
(BufferAllocator allocator) NullableDecimal28SparseVector.getTransferPair
(String ref, BufferAllocator allocator) NullableDecimal28SparseVector.getTransferPair
(BufferAllocator allocator) NullableDecimal38DenseVector.getTransferPair
(String ref, BufferAllocator allocator) NullableDecimal38DenseVector.getTransferPair
(BufferAllocator allocator) NullableDecimal38SparseVector.getTransferPair
(String ref, BufferAllocator allocator) NullableDecimal38SparseVector.getTransferPair
(BufferAllocator allocator) NullableDecimal9Vector.getTransferPair
(String ref, BufferAllocator allocator) NullableDecimal9Vector.getTransferPair
(BufferAllocator allocator) NullableFloat4Vector.getTransferPair
(String ref, BufferAllocator allocator) NullableFloat4Vector.getTransferPair
(BufferAllocator allocator) NullableFloat8Vector.getTransferPair
(String ref, BufferAllocator allocator) NullableFloat8Vector.getTransferPair
(BufferAllocator allocator) NullableIntervalDayVector.getTransferPair
(String ref, BufferAllocator allocator) NullableIntervalDayVector.getTransferPair
(BufferAllocator allocator) NullableIntervalVector.getTransferPair
(String ref, BufferAllocator allocator) NullableIntervalVector.getTransferPair
(BufferAllocator allocator) NullableIntervalYearVector.getTransferPair
(String ref, BufferAllocator allocator) NullableIntervalYearVector.getTransferPair
(BufferAllocator allocator) NullableIntVector.getTransferPair
(String ref, BufferAllocator allocator) NullableIntVector.getTransferPair
(BufferAllocator allocator) NullableSmallIntVector.getTransferPair
(String ref, BufferAllocator allocator) NullableSmallIntVector.getTransferPair
(BufferAllocator allocator) NullableTimeStampVector.getTransferPair
(String ref, BufferAllocator allocator) NullableTimeStampVector.getTransferPair
(BufferAllocator allocator) NullableTimeVector.getTransferPair
(String ref, BufferAllocator allocator) NullableTimeVector.getTransferPair
(BufferAllocator allocator) NullableTinyIntVector.getTransferPair
(String ref, BufferAllocator allocator) NullableTinyIntVector.getTransferPair
(BufferAllocator allocator) NullableUInt1Vector.getTransferPair
(String ref, BufferAllocator allocator) NullableUInt1Vector.getTransferPair
(BufferAllocator allocator) NullableUInt2Vector.getTransferPair
(String ref, BufferAllocator allocator) NullableUInt2Vector.getTransferPair
(BufferAllocator allocator) NullableUInt4Vector.getTransferPair
(String ref, BufferAllocator allocator) NullableUInt4Vector.getTransferPair
(BufferAllocator allocator) NullableUInt8Vector.getTransferPair
(String ref, BufferAllocator allocator) NullableUInt8Vector.getTransferPair
(BufferAllocator allocator) NullableVar16CharVector.getTransferPair
(String ref, BufferAllocator allocator) NullableVar16CharVector.getTransferPair
(BufferAllocator allocator) NullableVarBinaryVector.getTransferPair
(String ref, BufferAllocator allocator) NullableVarBinaryVector.getTransferPair
(BufferAllocator allocator) NullableVarCharVector.getTransferPair
(String ref, BufferAllocator allocator) NullableVarCharVector.getTransferPair
(BufferAllocator allocator) NullableVarDecimalVector.getTransferPair
(String ref, BufferAllocator allocator) NullableVarDecimalVector.getTransferPair
(BufferAllocator allocator) ObjectVector.getTransferPair
(String ref, BufferAllocator allocator) ObjectVector.getTransferPair
(BufferAllocator allocator) RepeatedBigIntVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedBigIntVector.getTransferPair
(BufferAllocator allocator) RepeatedBitVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedBitVector.getTransferPair
(BufferAllocator allocator) RepeatedDateVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedDateVector.getTransferPair
(BufferAllocator allocator) RepeatedDecimal18Vector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedDecimal18Vector.getTransferPair
(BufferAllocator allocator) RepeatedDecimal28DenseVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedDecimal28DenseVector.getTransferPair
(BufferAllocator allocator) RepeatedDecimal28SparseVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedDecimal28SparseVector.getTransferPair
(BufferAllocator allocator) RepeatedDecimal38DenseVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedDecimal38DenseVector.getTransferPair
(BufferAllocator allocator) RepeatedDecimal38SparseVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedDecimal38SparseVector.getTransferPair
(BufferAllocator allocator) RepeatedDecimal9Vector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedDecimal9Vector.getTransferPair
(BufferAllocator allocator) RepeatedFloat4Vector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedFloat4Vector.getTransferPair
(BufferAllocator allocator) RepeatedFloat8Vector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedFloat8Vector.getTransferPair
(BufferAllocator allocator) RepeatedIntervalDayVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedIntervalDayVector.getTransferPair
(BufferAllocator allocator) RepeatedIntervalVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedIntervalVector.getTransferPair
(BufferAllocator allocator) RepeatedIntervalYearVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedIntervalYearVector.getTransferPair
(BufferAllocator allocator) RepeatedIntVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedIntVector.getTransferPair
(BufferAllocator allocator) RepeatedSmallIntVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedSmallIntVector.getTransferPair
(BufferAllocator allocator) RepeatedTimeStampVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedTimeStampVector.getTransferPair
(BufferAllocator allocator) RepeatedTimeVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedTimeVector.getTransferPair
(BufferAllocator allocator) RepeatedTinyIntVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedTinyIntVector.getTransferPair
(BufferAllocator allocator) RepeatedUInt1Vector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedUInt1Vector.getTransferPair
(BufferAllocator allocator) RepeatedUInt2Vector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedUInt2Vector.getTransferPair
(BufferAllocator allocator) RepeatedUInt4Vector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedUInt4Vector.getTransferPair
(BufferAllocator allocator) RepeatedUInt8Vector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedUInt8Vector.getTransferPair
(BufferAllocator allocator) RepeatedVar16CharVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedVar16CharVector.getTransferPair
(BufferAllocator allocator) RepeatedVarBinaryVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedVarBinaryVector.getTransferPair
(BufferAllocator allocator) RepeatedVarCharVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedVarCharVector.getTransferPair
(BufferAllocator allocator) RepeatedVarDecimalVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedVarDecimalVector.getTransferPair
(BufferAllocator allocator) SmallIntVector.getTransferPair
(String ref, BufferAllocator allocator) SmallIntVector.getTransferPair
(BufferAllocator allocator) TimeStampVector.getTransferPair
(String ref, BufferAllocator allocator) TimeStampVector.getTransferPair
(BufferAllocator allocator) TimeVector.getTransferPair
(String ref, BufferAllocator allocator) TimeVector.getTransferPair
(BufferAllocator allocator) TinyIntVector.getTransferPair
(String ref, BufferAllocator allocator) TinyIntVector.getTransferPair
(BufferAllocator allocator) UInt1Vector.getTransferPair
(String ref, BufferAllocator allocator) UInt1Vector.getTransferPair
(BufferAllocator allocator) UInt2Vector.getTransferPair
(String ref, BufferAllocator allocator) UInt2Vector.getTransferPair
(BufferAllocator allocator) UInt4Vector.getTransferPair
(String ref, BufferAllocator allocator) UInt4Vector.getTransferPair
(BufferAllocator allocator) UInt8Vector.getTransferPair
(String ref, BufferAllocator allocator) UInt8Vector.getTransferPair
(BufferAllocator allocator) UntypedNullVector.getTransferPair
(String ref, BufferAllocator allocator) UntypedNullVector.getTransferPair
(BufferAllocator allocator) ValueVector.getTransferPair
(String ref, BufferAllocator allocator) ValueVector.getTransferPair
(BufferAllocator allocator) Returns atransfer pair
, creating a new target vector of the same type.Var16CharVector.getTransferPair
(String ref, BufferAllocator allocator) Var16CharVector.getTransferPair
(BufferAllocator allocator) VarBinaryVector.getTransferPair
(String ref, BufferAllocator allocator) VarBinaryVector.getTransferPair
(BufferAllocator allocator) VarCharVector.getTransferPair
(String ref, BufferAllocator allocator) VarCharVector.getTransferPair
(BufferAllocator allocator) VarDecimalVector.getTransferPair
(String ref, BufferAllocator allocator) VarDecimalVector.getTransferPair
(BufferAllocator allocator) ZeroVector.getTransferPair
(String ref, BufferAllocator allocator) ZeroVector.getTransferPair
(BufferAllocator allocator) static VarCharHolder
ValueHolderHelper.getVarCharHolder
(BufferAllocator a, String s) ModifierConstructorDescriptionBaseDataValueVector
(MaterializedField field, BufferAllocator allocator) protected
BaseValueVector
(MaterializedField field, BufferAllocator allocator) BigIntVector
(MaterializedField field, BufferAllocator allocator) BitVector
(MaterializedField field, BufferAllocator allocator) DateVector
(MaterializedField field, BufferAllocator allocator) Decimal18Vector
(MaterializedField field, BufferAllocator allocator) Decimal28DenseVector
(MaterializedField field, BufferAllocator allocator) Decimal28SparseVector
(MaterializedField field, BufferAllocator allocator) Decimal38DenseVector
(MaterializedField field, BufferAllocator allocator) Decimal38SparseVector
(MaterializedField field, BufferAllocator allocator) Decimal9Vector
(MaterializedField field, BufferAllocator allocator) Float4Vector
(MaterializedField field, BufferAllocator allocator) Float8Vector
(MaterializedField field, BufferAllocator allocator) IntervalDayVector
(MaterializedField field, BufferAllocator allocator) IntervalVector
(MaterializedField field, BufferAllocator allocator) IntervalYearVector
(MaterializedField field, BufferAllocator allocator) IntVector
(MaterializedField field, BufferAllocator allocator) NullableBigIntVector
(MaterializedField field, BufferAllocator allocator) NullableBitVector
(MaterializedField field, BufferAllocator allocator) NullableDateVector
(MaterializedField field, BufferAllocator allocator) NullableDecimal18Vector
(MaterializedField field, BufferAllocator allocator) NullableDecimal28DenseVector
(MaterializedField field, BufferAllocator allocator) NullableDecimal28SparseVector
(MaterializedField field, BufferAllocator allocator) NullableDecimal38DenseVector
(MaterializedField field, BufferAllocator allocator) NullableDecimal38SparseVector
(MaterializedField field, BufferAllocator allocator) NullableDecimal9Vector
(MaterializedField field, BufferAllocator allocator) NullableFloat4Vector
(MaterializedField field, BufferAllocator allocator) NullableFloat8Vector
(MaterializedField field, BufferAllocator allocator) NullableIntervalDayVector
(MaterializedField field, BufferAllocator allocator) NullableIntervalVector
(MaterializedField field, BufferAllocator allocator) NullableIntervalYearVector
(MaterializedField field, BufferAllocator allocator) NullableIntVector
(MaterializedField field, BufferAllocator allocator) NullableSmallIntVector
(MaterializedField field, BufferAllocator allocator) NullableTimeStampVector
(MaterializedField field, BufferAllocator allocator) NullableTimeVector
(MaterializedField field, BufferAllocator allocator) NullableTinyIntVector
(MaterializedField field, BufferAllocator allocator) NullableUInt1Vector
(MaterializedField field, BufferAllocator allocator) NullableUInt2Vector
(MaterializedField field, BufferAllocator allocator) NullableUInt4Vector
(MaterializedField field, BufferAllocator allocator) NullableUInt8Vector
(MaterializedField field, BufferAllocator allocator) NullableVar16CharVector
(MaterializedField field, BufferAllocator allocator) NullableVarBinaryVector
(MaterializedField field, BufferAllocator allocator) NullableVarCharVector
(MaterializedField field, BufferAllocator allocator) NullableVarDecimalVector
(MaterializedField field, BufferAllocator allocator) ObjectVector
(MaterializedField field, BufferAllocator allocator) RepeatedBigIntVector
(MaterializedField field, BufferAllocator allocator) RepeatedBitVector
(MaterializedField field, BufferAllocator allocator) RepeatedDateVector
(MaterializedField field, BufferAllocator allocator) RepeatedDecimal18Vector
(MaterializedField field, BufferAllocator allocator) RepeatedDecimal28DenseVector
(MaterializedField field, BufferAllocator allocator) RepeatedDecimal28SparseVector
(MaterializedField field, BufferAllocator allocator) RepeatedDecimal38DenseVector
(MaterializedField field, BufferAllocator allocator) RepeatedDecimal38SparseVector
(MaterializedField field, BufferAllocator allocator) RepeatedDecimal9Vector
(MaterializedField field, BufferAllocator allocator) RepeatedFloat4Vector
(MaterializedField field, BufferAllocator allocator) RepeatedFloat8Vector
(MaterializedField field, BufferAllocator allocator) RepeatedIntervalDayVector
(MaterializedField field, BufferAllocator allocator) RepeatedIntervalVector
(MaterializedField field, BufferAllocator allocator) RepeatedIntervalYearVector
(MaterializedField field, BufferAllocator allocator) RepeatedIntVector
(MaterializedField field, BufferAllocator allocator) RepeatedSmallIntVector
(MaterializedField field, BufferAllocator allocator) RepeatedTimeStampVector
(MaterializedField field, BufferAllocator allocator) RepeatedTimeVector
(MaterializedField field, BufferAllocator allocator) RepeatedTinyIntVector
(MaterializedField field, BufferAllocator allocator) RepeatedUInt1Vector
(MaterializedField field, BufferAllocator allocator) RepeatedUInt2Vector
(MaterializedField field, BufferAllocator allocator) RepeatedUInt4Vector
(MaterializedField field, BufferAllocator allocator) RepeatedUInt8Vector
(MaterializedField field, BufferAllocator allocator) RepeatedVar16CharVector
(MaterializedField field, BufferAllocator allocator) RepeatedVarBinaryVector
(MaterializedField field, BufferAllocator allocator) RepeatedVarCharVector
(MaterializedField field, BufferAllocator allocator) RepeatedVarDecimalVector
(MaterializedField field, BufferAllocator allocator) SmallIntVector
(MaterializedField field, BufferAllocator allocator) TimeStampVector
(MaterializedField field, BufferAllocator allocator) TimeVector
(MaterializedField field, BufferAllocator allocator) TinyIntVector
(MaterializedField field, BufferAllocator allocator) UInt1Vector
(MaterializedField field, BufferAllocator allocator) UInt2Vector
(MaterializedField field, BufferAllocator allocator) UInt4Vector
(MaterializedField field, BufferAllocator allocator) UInt8Vector
(MaterializedField field, BufferAllocator allocator) UntypedNullVector
(MaterializedField field, BufferAllocator allocator) Var16CharVector
(MaterializedField field, BufferAllocator allocator) VarBinaryVector
(MaterializedField field, BufferAllocator allocator) VarCharVector
(MaterializedField field, BufferAllocator allocator) VarDecimalVector
(MaterializedField field, BufferAllocator allocator) -
Uses of BufferAllocator in org.apache.drill.exec.vector.complex
Modifier and TypeFieldDescriptionprotected final BufferAllocator
AbstractContainerVector.allocator
Modifier and TypeMethodDescriptionAbstractContainerVector.getAllocator()
UnionVector.getAllocator()
Modifier and TypeMethodDescriptionDictVector.getTransferPair
(String ref, BufferAllocator allocator) DictVector.getTransferPair
(BufferAllocator allocator) ListVector.getTransferPair
(String ref, BufferAllocator allocator) MapVector.getTransferPair
(String ref, BufferAllocator allocator) MapVector.getTransferPair
(BufferAllocator allocator) RepeatedDictVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedListVector.DelegateRepeatedVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedListVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedListVector.getTransferPair
(BufferAllocator allocator) RepeatedMapVector.getTransferPair
(String ref, BufferAllocator allocator) RepeatedMapVector.getTransferPair
(BufferAllocator allocator) UnionVector.getTransferPair
(String ref, BufferAllocator allocator) UnionVector.getTransferPair
(BufferAllocator allocator) AbstractRepeatedMapVector.getTransferPairToSingleMap
(String reference, BufferAllocator allocator) ModifierConstructorDescriptionprotected
AbstractContainerVector
(MaterializedField field, BufferAllocator allocator, CallBack callBack) protected
AbstractMapVector
(MaterializedField field, BufferAllocator allocator, CallBack callBack) protected
AbstractRepeatedMapVector
(MaterializedField field, BufferAllocator allocator, CallBack callBack) protected
BaseRepeatedValueVector
(MaterializedField field, BufferAllocator allocator) protected
BaseRepeatedValueVector
(MaterializedField field, BufferAllocator allocator, ValueVector vector) DelegateRepeatedVector
(String path, BufferAllocator allocator) DelegateRepeatedVector
(MaterializedField field, BufferAllocator allocator) DictVector
(MaterializedField field, BufferAllocator allocator, CallBack callBack) DictVector
(MaterializedField field, BufferAllocator allocator, CallBack callBack, TypeProtos.MajorType keyType, TypeProtos.MajorType valueType) ListVector
(MaterializedField field, BufferAllocator allocator, CallBack callBack) MapTransferPair
(MapVector from, String path, BufferAllocator allocator) MapVector
(String path, BufferAllocator allocator, CallBack callBack) MapVector
(MaterializedField field, BufferAllocator allocator, CallBack callBack) RepeatedDictVector
(String path, BufferAllocator allocator) RepeatedDictVector
(MaterializedField field, BufferAllocator allocator, CallBack callback) RepeatedListVector
(String path, BufferAllocator allocator, CallBack callBack) RepeatedListVector
(MaterializedField field, BufferAllocator allocator, CallBack callBack) protected
RepeatedListVector
(MaterializedField field, BufferAllocator allocator, CallBack callBack, RepeatedListVector.DelegateRepeatedVector delegate) RepeatedMapVector
(MaterializedField field, BufferAllocator allocator, CallBack callBack) UnionVector
(MaterializedField field, BufferAllocator allocator, CallBack callBack) -
Uses of BufferAllocator in org.apache.drill.exec.vector.complex.impl
-
Uses of BufferAllocator in org.apache.drill.exec.work.batch
Modifier and TypeFieldDescriptionprotected BufferAllocator
AbstractDataCollector.ownerAllocator
Allocator which owns incoming batchesModifier and TypeMethodDescriptionAbstractDataCollector.getAllocator()
DataCollector.getAllocator()
Modifier and TypeMethodDescriptionvoid
AbstractDataCollector.setAllocator
(BufferAllocator allocator) Enables caller (e.g., receiver) to attach its buffer allocator to this Data Collector in order to claim ownership of incoming batches; by default, the fragment allocator owns these batches.void
DataCollector.setAllocator
(BufferAllocator allocator) Enables caller (e.g., receiver) to attach its buffer allocator to this Data Collector in order to claim ownership of incoming batches; by default, the fragment allocator owns these batches. -
Uses of BufferAllocator in org.apache.drill.exec.work.filter
Modifier and TypeMethodDescriptionRuntimeFilterWritable.duplicate
(BufferAllocator bufferAllocator) RuntimeFilterWritable.newRuntimeFilterWritable
(BufferAllocator bufferAllocator) ModifierConstructorDescriptionBloomFilter
(int ndv, double fpp, BufferAllocator bufferAllocator) BloomFilter
(int numBytes, BufferAllocator bufferAllocator) -
Uses of BufferAllocator in org.apache.parquet.hadoop
ModifierConstructorDescriptionColumnChunkIncReadStore
(long rowCount, org.apache.parquet.compression.CompressionCodecFactory codecFactory, BufferAllocator allocator, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path path)
RowSetBuilder(BufferAllocator, TupleMetadata)
instead.