Uses of Class
org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
-
-
Uses of BatchShuffleReadBufferPool in org.apache.flink.runtime.io.network
Methods in org.apache.flink.runtime.io.network that return BatchShuffleReadBufferPool Modifier and Type Method Description BatchShuffleReadBufferPool
NettyShuffleEnvironment. getBatchShuffleReadBufferPool()
-
Uses of BatchShuffleReadBufferPool in org.apache.flink.runtime.io.network.partition
Constructors in org.apache.flink.runtime.io.network.partition with parameters of type BatchShuffleReadBufferPool 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)
SortMergeResultPartition(String owningTaskName, int partitionIndex, ResultPartitionID partitionId, ResultPartitionType partitionType, int numSubpartitions, int numTargetKeyGroups, BatchShuffleReadBufferPool readBufferPool, Executor readIOExecutor, ResultPartitionManager partitionManager, String resultFileBasePath, BufferCompressor bufferCompressor, org.apache.flink.util.function.SupplierWithException<BufferPool,IOException> bufferPoolFactory)
-
Uses of BatchShuffleReadBufferPool 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 BatchShuffleReadBufferPool 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)
-
Uses of BatchShuffleReadBufferPool in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier with parameters of type BatchShuffleReadBufferPool Modifier and Type Method Description TierProducerAgent
TierFactory. createProducerAgent(int numPartitions, int numSubpartitions, TieredStoragePartitionId partitionID, String dataFileBasePath, boolean isBroadcastOnly, TieredStorageMemoryManager storageMemoryManager, TieredStorageNettyService nettyService, TieredStorageResourceRegistry resourceRegistry, BatchShuffleReadBufferPool bufferPool, ScheduledExecutorService ioExecutor, List<TierShuffleDescriptor> shuffleDescriptors, int maxRequestedBuffer, BufferCompressor bufferCompressor)
Creates the producer-side agent of a Tier. -
Uses of BatchShuffleReadBufferPool in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk with parameters of type BatchShuffleReadBufferPool Modifier and Type Method Description TierProducerAgent
DiskTierFactory. createProducerAgent(int numPartitions, int numSubpartitions, TieredStoragePartitionId partitionId, String dataFileBasePath, boolean isBroadcastOnly, TieredStorageMemoryManager storageMemoryManager, TieredStorageNettyService nettyService, TieredStorageResourceRegistry resourceRegistry, BatchShuffleReadBufferPool bufferPool, ScheduledExecutorService ioExecutor, List<TierShuffleDescriptor> shuffleDescriptors, int maxRequestedBuffers, BufferCompressor bufferCompressor)
Constructors in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk with parameters of type BatchShuffleReadBufferPool Constructor Description DiskIOScheduler(TieredStoragePartitionId partitionId, BatchShuffleReadBufferPool bufferPool, ScheduledExecutorService ioExecutor, int maxRequestedBuffers, Duration bufferRequestTimeout, BiFunction<Integer,Integer,Integer> segmentIdGetter, PartitionFileReader partitionFileReader)
-
Uses of BatchShuffleReadBufferPool in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory with parameters of type BatchShuffleReadBufferPool Modifier and Type Method Description TierProducerAgent
MemoryTierFactory. createProducerAgent(int numPartitions, int numSubpartitions, TieredStoragePartitionId partitionID, String dataFileBasePath, boolean isBroadcastOnly, TieredStorageMemoryManager memoryManager, TieredStorageNettyService nettyService, TieredStorageResourceRegistry resourceRegistry, BatchShuffleReadBufferPool bufferPool, ScheduledExecutorService ioExecutor, List<TierShuffleDescriptor> shuffleDescriptors, int maxRequestedBuffers, BufferCompressor bufferCompressor)
-
Uses of BatchShuffleReadBufferPool in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote with parameters of type BatchShuffleReadBufferPool Modifier and Type Method Description TierProducerAgent
RemoteTierFactory. createProducerAgent(int numPartitions, int numSubpartitions, TieredStoragePartitionId partitionID, String dataFileBasePath, boolean isBroadcastOnly, TieredStorageMemoryManager storageMemoryManager, TieredStorageNettyService nettyService, TieredStorageResourceRegistry resourceRegistry, BatchShuffleReadBufferPool bufferPool, ScheduledExecutorService ioExecutor, List<TierShuffleDescriptor> shuffleDescriptors, int maxRequestedBuffers, BufferCompressor bufferCompressor)
-