Package | Description |
---|---|
org.apache.flink.runtime.io.disk | |
org.apache.flink.runtime.io.network.partition | |
org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle |
Modifier and Type | Class and Description |
---|---|
class |
FileChannelManagerImpl
The manager used for creating/deleting file channels based on config temp dirs.
|
Constructor and Description |
---|
ResultPartitionFactory(ResultPartitionManager partitionManager,
FileChannelManager channelManager,
BufferPoolFactory bufferPoolFactory,
BatchShuffleReadBufferPool batchShuffleReadBufferPool,
ScheduledExecutorService batchShuffleReadIOExecutor,
BoundedBlockingSubpartitionType blockingSubpartitionType,
int configuredNetworkBuffersPerChannel,
int floatingNetworkBuffersPerGate,
int networkBufferSize,
boolean batchShuffleCompressionEnabled,
NettyShuffleEnvironmentOptions.CompressionCodec compressionCodec,
int maxBuffersPerChannel,
int sortShuffleMinBuffers,
int sortShuffleMinParallelism,
boolean sslEnabled,
int maxOverdraftBuffersPerGate,
int hybridShuffleSpilledIndexRegionGroupSize,
long hybridShuffleNumRetainedInMemoryRegionsMax,
Optional<TieredResultPartitionFactory> tieredStorage) |
Modifier and Type | Method and Description |
---|---|
TieredResultPartition |
TieredResultPartitionFactory.createTieredResultPartition(String owningTaskName,
int partitionIndex,
ResultPartitionID partitionId,
ResultPartitionType partitionType,
int numPartitions,
int numSubpartitions,
int maxParallelism,
int bufferSizeBytes,
Boolean isBroadCastOnly,
ResultPartitionManager partitionManager,
BufferCompressor bufferCompressor,
List<TierShuffleDescriptor> tierShuffleDescriptors,
SupplierWithException<BufferPool,IOException> bufferPoolFactory,
FileChannelManager fileChannelManager,
BatchShuffleReadBufferPool batchShuffleReadBufferPool,
ScheduledExecutorService batchShuffleReadIOExecutor,
boolean isNumberOfPartitionConsumerUndefined) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.