| Modifier and Type | Method and Description |
|---|---|
DrillBuf |
DrillBuf.retain(BufferAllocator target)
Create a new DrillBuf that is associated with an alternative allocator for
the purposes of memory ownership and accounting.
|
DrillBuf.TransferResult |
DrillBuf.transferOwnership(BufferAllocator target)
Transfer the memory accounting ownership of this DrillBuf to another
allocator.
|
| Constructor and Description |
|---|
ExpandableByteBuf(io.netty.buffer.ByteBuf buffer,
BufferAllocator allocator) |
| Modifier and Type | Method and Description |
|---|---|
static VectorSerializer.Reader |
VectorSerializer.reader(BufferAllocator allocator,
InputStream stream) |
| Constructor and Description |
|---|
CachedVectorContainer(BufferAllocator allocator) |
CachedVectorContainer(byte[] data,
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.
|
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
DrillClient.getAllocator() |
| Constructor and Description |
|---|
DrillClient(DrillConfig config,
ClusterCoordinator coordinator,
BufferAllocator allocator) |
DrillClient(DrillConfig config,
ClusterCoordinator coordinator,
BufferAllocator allocator,
boolean isDirect) |
| Modifier and Type | Class and Description |
|---|---|
class |
BaseAllocator |
class |
RootAllocator
The root allocator for using direct memory inside a Drillbit.
|
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
BaseAllocator.newChildAllocator(String name,
long initReservation,
long maxAllocation) |
BufferAllocator |
BufferAllocator.newChildAllocator(String name,
long initReservation,
long maxAllocation)
Create a new child allocator.
|
static BufferAllocator |
RootAllocatorFactory.newRoot(DrillConfig drillConfig)
Create a new Root Allocator
|
static BufferAllocator |
RootAllocatorFactory.newRoot(long maxAlloc) |
| Modifier and Type | Method and Description |
|---|---|
AllocationManager.BufferLedger |
AllocationManager.BufferLedger.getLedgerForAllocator(BufferAllocator allocator)
Returns the ledger associated with a particular BufferAllocator.
|
| Constructor and Description |
|---|
DrillByteBufAllocator(BufferAllocator allocator) |
| Modifier and Type | Field and Description |
|---|---|
protected BufferAllocator |
BaseOperatorContext.allocator |
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
FragmentContextImpl.getAllocator()
Deprecated.
|
BufferAllocator |
QueryContext.getAllocator() |
BufferAllocator |
FragmentContext.getAllocator() |
BufferAllocator |
OperatorContext.getAllocator()
Return the memory allocator for this operator.
|
BufferAllocator |
BaseOperatorContext.getAllocator() |
BufferAllocator |
OptimizerRulesContext.getAllocator()
Method returns the allocator
|
BufferAllocator |
FragmentContextImpl.getNewChildAllocator(String operatorName,
int operatorId,
long initialReservation,
long maximumReservation) |
BufferAllocator |
FragmentContext.getNewChildAllocator(String operatorName,
int operatorId,
long initialReservation,
long maximumReservation) |
BufferAllocator |
FragmentContextImpl.getRootAllocator() |
BufferAllocator |
ExecutorFragmentContext.getRootAllocator()
Returns the root allocator for the Drillbit.
|
| Modifier and Type | Method and Description |
|---|---|
OperatorStats |
FragmentStats.newOperatorStats(OpProfileDef profileDef,
BufferAllocator allocator)
Creates a new holder for operator statistics within this holder for fragment statistics.
|
| Constructor and Description |
|---|
BaseOperatorContext(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) |
| Modifier and Type | Field and Description |
|---|---|
protected BufferAllocator |
MockRecordBatch.allocator |
| Constructor and Description |
|---|
Mutator(OperatorContext oContext,
BufferAllocator allocator,
VectorContainer container) |
| Constructor and Description |
|---|
HashAggUpdater(BufferAllocator allocator) |
| Constructor and Description |
|---|
ChainedHashTable(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) |
| Constructor and Description |
|---|
HashJoinHelper(FragmentContext context,
BufferAllocator allocator) |
| Modifier and Type | Method and Description |
|---|---|
protected 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.
|
| Constructor and Description |
|---|
OutgoingRecordBatch(OperatorStats stats,
HashPartitionSender operator,
AccountingDataTunnel tunnel,
FragmentContext context,
BufferAllocator allocator,
int oppositeMinorFragmentId) |
| Modifier and Type | Field and Description |
|---|---|
protected BufferAllocator |
ScanSchemaOrchestrator.allocator |
| Modifier and Type | Method and Description |
|---|---|
abstract BufferAllocator |
ResolvedTuple.allocator() |
BufferAllocator |
ResolvedTuple.ResolvedRow.allocator() |
BufferAllocator |
ResolvedTuple.ResolvedMap.allocator() |
BufferAllocator |
ResolvedTuple.ResolvedSingleDict.allocator() |
BufferAllocator |
ResolvedTuple.ResolvedDictArray.allocator() |
| Modifier and Type | Method and Description |
|---|---|
protected abstract AbstractMapVector |
ResolvedTuple.ResolvedMap.createMap(AbstractMapVector inputMap,
MaterializedField create,
BufferAllocator allocator) |
protected AbstractMapVector |
ResolvedTuple.ResolvedSingleMap.createMap(AbstractMapVector inputMap,
MaterializedField schema,
BufferAllocator allocator) |
protected AbstractMapVector |
ResolvedTuple.ResolvedMapArray.createMap(AbstractMapVector inputMap,
MaterializedField schema,
BufferAllocator allocator) |
| Constructor and Description |
|---|
ScanSchemaOrchestrator(BufferAllocator allocator,
ScanSchemaOrchestrator.ScanOrchestratorBuilder builder) |
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
ScanLifecycle.allocator() |
| Constructor and Description |
|---|
OutputBatchBuilder(TupleMetadata outputSchema,
List<OutputBatchBuilder.BatchSource> sources,
BufferAllocator allocator) |
| Constructor and Description |
|---|
RecordBatchData(VectorAccessible batch,
BufferAllocator allocator) |
SortRecordBatchBuilder(BufferAllocator a) |
| Modifier and Type | Method and Description |
|---|---|
RowSet |
AbstractGenericCopierTest.createExpectedRowset(BufferAllocator allocator) |
RowSet |
GenericSV4CopierTest.createSrcRowSet(BufferAllocator allocator) |
RowSet |
GenericCopierTest.createSrcRowSet(BufferAllocator allocator) |
RowSet |
GenericSV2CopierTest.createSrcRowSet(BufferAllocator allocator) |
RowSet |
GenericSV2BatchCopierTest.createSrcRowSet(BufferAllocator allocator) |
abstract RowSet |
AbstractGenericCopierTest.createSrcRowSet(BufferAllocator allocator) |
| Modifier and Type | Method and Description |
|---|---|
static 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) |
| Modifier and Type | Field and Description |
|---|---|
protected BufferAllocator |
BatchGroup.allocator |
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
PriorityQueueCopierWrapper.getAllocator() |
| Modifier and Type | Method and Description |
|---|---|
void |
PriorityQueueCopierTemplate.setup(BufferAllocator allocator,
VectorAccessible hyperBatch,
List<BatchGroup> batchGroups,
VectorAccessible outgoing) |
void |
PriorityQueueCopier.setup(BufferAllocator allocator,
VectorAccessible hyperBatch,
List<BatchGroup> batchGroups,
VectorAccessible outgoing) |
void |
MSorter.setup(FragmentContext context,
BufferAllocator allocator,
SelectionVector4 vector4,
VectorContainer hyperBatch,
int outputBatchSize,
int desiredBatchSize) |
void |
MSortTemplate.setup(FragmentContext context,
BufferAllocator allocator,
SelectionVector4 vector4,
VectorContainer hyperBatch,
int outputBatchSize,
int desiredBatchSize) |
| Constructor and Description |
|---|
BatchGroup(VectorContainer container,
BufferAllocator allocator) |
InputBatch(VectorContainer container,
SelectionVector2 sv2,
BufferAllocator allocator,
long dataSize) |
SpilledRun(SpillSet spillSet,
String path,
BufferAllocator allocator) |
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
ResultVectorCache.allocator() |
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
ResultVectorCacheImpl.allocator() |
BufferAllocator |
ResultSetLoaderImpl.allocator() |
BufferAllocator |
NullResultVectorCacheImpl.allocator() |
| Constructor and Description |
|---|
NullResultVectorCacheImpl(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) |
| Constructor and Description |
|---|
BuildVectorsFromMetadata(BufferAllocator allocator) |
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
AbstractRowSet.allocator() |
BufferAllocator |
RowSet.allocator() |
| Modifier and Type | Method and Description |
|---|---|
static 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) |
static RowSetWriter |
RowSetTestUtils.makeWriter(BufferAllocator allocator,
TupleMetadata outputSchema) |
static RowSetWriter |
RowSetTestUtils.makeWriter(BufferAllocator allocator,
TupleMetadata outputSchema,
int size) |
| Constructor and Description |
|---|
HyperRowSetBuilderImpl(BufferAllocator allocator) |
RowSetBuilder(BufferAllocator allocator,
BatchSchema schema)
Deprecated.
|
RowSetBuilder(BufferAllocator allocator,
TupleMetadata schema) |
RowSetBuilder(BufferAllocator allocator,
TupleMetadata schema,
int capacity) |
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
RecordBatchLoader.allocator() |
BufferAllocator |
VectorContainer.getAllocator() |
| Modifier and Type | Method and Description |
|---|---|
VectorWrapper<T> |
HyperVectorWrapper.cloneAndTransfer(BufferAllocator allocator) |
VectorWrapper<T> |
VectorWrapper.cloneAndTransfer(BufferAllocator allocator) |
VectorWrapper<T> |
SimpleVectorWrapper.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 |
WritableBatch.transfer(BufferAllocator allocator) |
| Constructor and Description |
|---|
RecordBatchLoader(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.
|
| Constructor and Description |
|---|
SelectionVector2(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) |
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
AbstractConnectionConfig.getAllocator() |
BufferAllocator |
AbstractServerConnection.getAllocator() |
BufferAllocator |
ConnectionConfig.getAllocator() |
BufferAllocator |
RemoteConnection.getAllocator() |
| Modifier and Type | Method and Description |
|---|---|
abstract 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) |
| Constructor and Description |
|---|
AbstractConnectionConfig(BufferAllocator allocator,
BootStrapContext context) |
BitConnectionConfig(BufferAllocator allocator,
BootStrapContext context) |
ProtobufLengthDecoder(BufferAllocator allocator,
OutOfMemoryHandler outOfMemoryHandler) |
| Modifier and Type | Method and Description |
|---|---|
ProtobufLengthDecoder |
ControlClient.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.
|
| Constructor and Description |
|---|
ControllerImpl(BootStrapContext context,
BufferAllocator allocator,
ControlMessageHandler handler) |
ControlProtobufLengthDecoder(BufferAllocator allocator,
OutOfMemoryHandler outOfMemoryHandler) |
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
DataClientConnection.getAllocator() |
| Modifier and Type | Method and Description |
|---|---|
ProtobufLengthDecoder |
DataClient.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.
|
RawFragmentBatch |
IncomingDataBatch.newRawFragmentBatch(BufferAllocator allocator)
Create a new RawFragmentBatch based on this incoming data batch that is transferred into the provided allocator.
|
| Constructor and Description |
|---|
Client(BufferAllocator allocator,
OutOfMemoryHandler outOfMemoryHandler) |
DataConnectionCreator(BootStrapContext context,
BufferAllocator allocator,
WorkEventBus workBus,
WorkManager.WorkerBee bee) |
Server(BufferAllocator allocator,
OutOfMemoryHandler outOfMemoryHandler) |
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
UserClient.UserToBitConnection.getAllocator() |
| Modifier and Type | Method and Description |
|---|---|
ProtobufLengthDecoder |
UserClient.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.
|
| Constructor and Description |
|---|
UserClient(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) |
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
BootStrapContext.getAllocator() |
BufferAllocator |
DrillbitContext.getAllocator() |
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
WebSessionResources.getAllocator() |
| Modifier and Type | Method and Description |
|---|---|
SSLEngine |
SSLConfigServer.createSSLEngine(BufferAllocator allocator,
String peerHost,
int peerPort) |
SSLEngine |
SSLConfig.createSSLEngine(BufferAllocator allocator,
String peerHost,
int peerPort) |
SSLEngine |
SSLConfigClient.createSSLEngine(BufferAllocator allocator,
String peerHost,
int peerPort) |
| Constructor and Description |
|---|
TestOutputMutator(BufferAllocator allocator) |
| Constructor and Description |
|---|
TextRecordWriter(BufferAllocator allocator,
StorageStrategy storageStrategy,
org.apache.hadoop.conf.Configuration fsConf) |
| Constructor and Description |
|---|
ParquetDirectByteBufferAllocator(BufferAllocator allocator) |
| Modifier and Type | Method and Description |
|---|---|
static RecordBatchOverflow.Builder |
RecordBatchOverflow.newBuilder(BufferAllocator allocator,
RecordBatchStats.RecordBatchStatsContext batchStatsContext) |
| Modifier and Type | Field and Description |
|---|---|
protected BufferAllocator |
DirectBufInputStream.allocator |
| Constructor and Description |
|---|
BufferedDirectBufInputStream(InputStream in,
BufferAllocator allocator,
String id,
long startOffset,
long totalByteSize,
boolean enforceTotalByteSize,
boolean enableHints)
Creates a
BufferedDirectBufInputStream
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 a
BufferedDirectBufInputStream
with the specified buffer size. |
DirectBufInputStream(InputStream in,
BufferAllocator allocator,
String id,
long startOffset,
long totalByteSize,
boolean enforceTotalByteSize,
boolean enableHints) |
| Modifier and Type | Method and Description |
|---|---|
static String |
RecordBatchStats.printAllocatorStats(BufferAllocator allocator) |
| Modifier and Type | Field and Description |
|---|---|
protected BufferAllocator |
BaseValueVector.allocator |
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
ValueVector.getAllocator() |
BufferAllocator |
BaseValueVector.getAllocator() |
BufferAllocator |
ZeroVector.getAllocator() |
| Constructor and Description |
|---|
BaseDataValueVector(MaterializedField field,
BufferAllocator allocator) |
BaseValueVector(MaterializedField field,
BufferAllocator allocator) |
BitVector(MaterializedField field,
BufferAllocator allocator) |
ObjectVector(MaterializedField field,
BufferAllocator allocator) |
UntypedNullVector(MaterializedField field,
BufferAllocator allocator) |
| Modifier and Type | Field and Description |
|---|---|
protected BufferAllocator |
AbstractContainerVector.allocator |
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
AbstractContainerVector.getAllocator() |
| Modifier and Type | Field and Description |
|---|---|
protected BufferAllocator |
AbstractDataCollector.ownerAllocator
Allocator which owns incoming batches
|
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
DataCollector.getAllocator() |
BufferAllocator |
AbstractDataCollector.getAllocator() |
| Modifier and Type | Method and Description |
|---|---|
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.
|
void |
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.
|
| Modifier and Type | Method and Description |
|---|---|
RuntimeFilterWritable |
RuntimeFilterWritable.duplicate(BufferAllocator bufferAllocator) |
RuntimeFilterWritable |
RuntimeFilterWritable.newRuntimeFilterWritable(BufferAllocator bufferAllocator) |
| Constructor and Description |
|---|
BloomFilter(int numBytes,
BufferAllocator bufferAllocator) |
BloomFilter(int ndv,
double fpp,
BufferAllocator bufferAllocator) |
| Modifier and Type | Field and Description |
|---|---|
protected static BufferAllocator |
BaseTestQuery.allocator |
protected BufferAllocator |
BaseFixture.allocator |
| Modifier and Type | Method and Description |
|---|---|
BufferAllocator |
ClientFixture.allocator() |
BufferAllocator |
BaseTestQuery.ClassicTestServices.allocator() |
BufferAllocator |
ClusterFixture.FixtureTestServices.allocator() |
BufferAllocator |
DrillTestWrapper.TestServices.allocator() |
BufferAllocator |
BaseFixture.allocator() |
BufferAllocator |
OperatorFixture.MockFragmentContext.getAllocator() |
protected static BufferAllocator |
BaseTestQuery.getAllocator() |
BufferAllocator |
OperatorFixture.MockFragmentContext.getNewChildAllocator(String operatorName,
int operatorId,
long initialReservation,
long maximumReservation) |
BufferAllocator |
PhysicalOpUnitTestBase.MockExecutorFragmentContext.getRootAllocator() |
| Modifier and Type | Method and Description |
|---|---|
static QueryRowSetReader |
QueryRowSetReader.build(BufferAllocator allocator,
BufferingQueryEventListener listener) |
static void |
BaseFixture.dirtyMemory(BufferAllocator allocator,
int blockCount) |
| Constructor and Description |
|---|
MockFragmentContext(DrillConfig config,
OptionManager options,
BufferAllocator allocator,
ExecutorService scanExecutorService,
ExecutorService scanDecodeExecutorService) |
MockOperatorContext(FragmentContext fragContext,
BufferAllocator allocator,
PhysicalOperator config) |
QueryBatchIterator(BufferAllocator allocator,
BufferingQueryEventListener listener) |
QueryResultSet(BufferingQueryEventListener listener,
BufferAllocator allocator) |
QueryRowSetIterator(BufferAllocator allocator,
BufferingQueryEventListener listener) |
| Constructor and Description |
|---|
ColumnChunkIncReadStore(long rowCount,
org.apache.parquet.hadoop.CodecFactory codecFactory,
BufferAllocator allocator,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path path) |
Copyright © 2021 The Apache Software Foundation. All rights reserved.