Uses of Interface
org.apache.flink.runtime.io.disk.FileChannelManager
-
Packages that use FileChannelManager 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 -
-
Uses of FileChannelManager in org.apache.flink.runtime.io.disk
Classes in org.apache.flink.runtime.io.disk that implement FileChannelManager Modifier and Type Class Description class
FileChannelManagerImpl
The manager used for creating/deleting file channels based on config temp dirs. -
Uses of FileChannelManager in org.apache.flink.runtime.io.network.partition
Constructors in org.apache.flink.runtime.io.network.partition with parameters of type FileChannelManager Constructor Description ResultPartitionFactory(ResultPartitionManager partitionManager, FileChannelManager channelManager, BufferPoolFactory bufferPoolFactory, BatchShuffleReadBufferPool batchShuffleReadBufferPool, ScheduledExecutorService batchShuffleReadIOExecutor, BoundedBlockingSubpartitionType blockingSubpartitionType, int configuredNetworkBuffersPerChannel, int floatingNetworkBuffersPerGate, int networkBufferSize, int startingBufferSize, boolean batchShuffleCompressionEnabled, org.apache.flink.configuration.NettyShuffleEnvironmentOptions.CompressionCodec compressionCodec, int maxBuffersPerChannel, int sortShuffleMinBuffers, int sortShuffleMinParallelism, boolean sslEnabled, int maxOverdraftBuffersPerGate, TieredResultPartitionFactory tieredResultPartitionFactory)
-
Uses of FileChannelManager in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle with parameters of type FileChannelManager Modifier and Type Method 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, org.apache.flink.util.function.SupplierWithException<BufferPool,IOException> bufferPoolFactory, FileChannelManager fileChannelManager, BatchShuffleReadBufferPool batchShuffleReadBufferPool, ScheduledExecutorService batchShuffleReadIOExecutor, boolean isNumberOfPartitionConsumerUndefined)
-