Package | Description |
---|---|
org.apache.flink.runtime.io.network.buffer | |
org.apache.flink.runtime.io.network.partition | |
org.apache.flink.runtime.io.network.partition.consumer |
Modifier and Type | Method and Description |
---|---|
BufferPool |
BufferPoolFactory.createBufferPool(int numRequiredBuffers,
int maxUsedBuffers)
Tries to create a buffer pool, which is guaranteed to provide at least the number of required
buffers.
|
BufferPool |
NetworkBufferPool.createBufferPool(int numRequiredBuffers,
int maxUsedBuffers) |
BufferPool |
BufferPoolFactory.createBufferPool(int numRequiredBuffers,
int maxUsedBuffers,
int numSubpartitions,
int maxBuffersPerChannel)
Tries to create a buffer pool with an owner, which is guaranteed to provide at least the
number of required buffers.
|
BufferPool |
NetworkBufferPool.createBufferPool(int numRequiredBuffers,
int maxUsedBuffers,
int numSubpartitions,
int maxBuffersPerChannel) |
Modifier and Type | Method and Description |
---|---|
void |
BufferPoolFactory.destroyBufferPool(BufferPool bufferPool)
Destroy callback for updating factory book keeping.
|
void |
NetworkBufferPool.destroyBufferPool(BufferPool bufferPool) |
Modifier and Type | Field and Description |
---|---|
protected BufferPool |
ResultPartition.bufferPool |
Modifier and Type | Method and Description |
---|---|
BufferPool |
ResultPartition.getBufferPool() |
Modifier and Type | Method and Description |
---|---|
ResultPartition |
ResultPartitionFactory.create(String taskNameWithSubtaskAndId,
int partitionIndex,
ResultPartitionID id,
ResultPartitionType type,
int numberOfSubpartitions,
int maxParallelism,
SupplierWithException<BufferPool,IOException> bufferPoolFactory) |
Constructor and Description |
---|
PartitionSortedBuffer(BufferPool bufferPool,
int numSubpartitions,
int bufferSize,
int numGuaranteedBuffers,
int[] customReadOrder) |
Constructor and Description |
---|
BoundedBlockingResultPartition(String owningTaskName,
int partitionIndex,
ResultPartitionID partitionId,
ResultPartitionType partitionType,
ResultSubpartition[] subpartitions,
int numTargetKeyGroups,
ResultPartitionManager partitionManager,
BufferCompressor bufferCompressor,
SupplierWithException<BufferPool,IOException> bufferPoolFactory) |
BufferWritingResultPartition(String owningTaskName,
int partitionIndex,
ResultPartitionID partitionId,
ResultPartitionType partitionType,
ResultSubpartition[] subpartitions,
int numTargetKeyGroups,
ResultPartitionManager partitionManager,
BufferCompressor bufferCompressor,
SupplierWithException<BufferPool,IOException> bufferPoolFactory) |
PipelinedResultPartition(String owningTaskName,
int partitionIndex,
ResultPartitionID partitionId,
ResultPartitionType partitionType,
ResultSubpartition[] subpartitions,
int numTargetKeyGroups,
ResultPartitionManager partitionManager,
BufferCompressor bufferCompressor,
SupplierWithException<BufferPool,IOException> bufferPoolFactory) |
ResultPartition(String owningTaskName,
int partitionIndex,
ResultPartitionID partitionId,
ResultPartitionType partitionType,
int numSubpartitions,
int numTargetKeyGroups,
ResultPartitionManager partitionManager,
BufferCompressor bufferCompressor,
SupplierWithException<BufferPool,IOException> bufferPoolFactory) |
SortMergeResultPartition(String owningTaskName,
int partitionIndex,
ResultPartitionID partitionId,
ResultPartitionType partitionType,
int numSubpartitions,
int numTargetKeyGroups,
BatchShuffleReadBufferPool readBufferPool,
Executor readIOExecutor,
ResultPartitionManager partitionManager,
String resultFileBasePath,
BufferCompressor bufferCompressor,
SupplierWithException<BufferPool,IOException> bufferPoolFactory) |
Modifier and Type | Method and Description |
---|---|
BufferPool |
SingleInputGate.getBufferPool() |
Modifier and Type | Method and Description |
---|---|
void |
SingleInputGate.setBufferPool(BufferPool bufferPool) |
Constructor and Description |
---|
SingleInputGate(String owningTaskName,
int gateIndex,
IntermediateDataSetID consumedResultId,
ResultPartitionType consumedPartitionType,
int consumedSubpartitionIndex,
int numberOfInputChannels,
PartitionProducerStateProvider partitionProducerStateProvider,
SupplierWithException<BufferPool,IOException> bufferPoolFactory,
BufferDecompressor bufferDecompressor,
MemorySegmentProvider memorySegmentProvider,
int segmentSize) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.