Uses of Interface
org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierShuffleDescriptor
-
-
Uses of TierShuffleDescriptor in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle that return types with arguments of type TierShuffleDescriptor Modifier and Type Method Description List<TierShuffleDescriptor>
TieredInternalShuffleMaster. addPartitionAndGetShuffleDescriptor(JobID jobID, ResultPartitionID resultPartitionID)
Method parameters in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle with type arguments of type TierShuffleDescriptor 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, SupplierWithException<BufferPool,IOException> bufferPoolFactory, FileChannelManager fileChannelManager, BatchShuffleReadBufferPool batchShuffleReadBufferPool, ScheduledExecutorService batchShuffleReadIOExecutor, boolean isNumberOfPartitionConsumerUndefined)
-
Uses of TierShuffleDescriptor in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage that return types with arguments of type TierShuffleDescriptor Modifier and Type Method Description List<TierShuffleDescriptor>
TieredStorageMasterClient. addPartitionAndGetShuffleDescriptor(JobID jobID, ResultPartitionID resultPartitionID)
Method parameters in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage with type arguments of type TierShuffleDescriptor Modifier and Type Method Description void
TieredStorageConsumerClient. updateTierShuffleDescriptors(TieredStoragePartitionId partitionId, TieredStorageInputChannelId inputChannelId, TieredStorageSubpartitionId subpartitionId, List<TierShuffleDescriptor> tierShuffleDescriptors)
-
Uses of TierShuffleDescriptor in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier
Classes in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier that implement TierShuffleDescriptor Modifier and Type Class Description class
NoOpTierShuffleDescriptor
The empty implementation forTierShuffleDescriptor
.class
UnknownTierShuffleDescriptor
This is a placeholder when the tier shuffle descriptor should be unknown because the netty shuffle descriptor is unknown.Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier that return TierShuffleDescriptor Modifier and Type Method Description TierShuffleDescriptor
NoOpMasterAgent. addPartitionAndGetShuffleDescriptor(JobID jobID, ResultPartitionID resultPartitionID)
TierShuffleDescriptor
TierMasterAgent. addPartitionAndGetShuffleDescriptor(JobID jobID, ResultPartitionID resultPartitionID)
Add a new tiered storage partition and get theTierShuffleDescriptor
.Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier with parameters of type TierShuffleDescriptor Modifier and Type Method Description void
NoOpMasterAgent. releasePartition(TierShuffleDescriptor shuffleDescriptor)
void
TierMasterAgent. releasePartition(TierShuffleDescriptor shuffleDescriptor)
Release a tiered storage partition.void
TierConsumerAgent. updateTierShuffleDescriptor(TieredStoragePartitionId partitionId, TieredStorageInputChannelId inputChannelId, TieredStorageSubpartitionId subpartitionId, TierShuffleDescriptor tierShuffleDescriptor)
Update theTierShuffleDescriptor
for the consumer agent.Method parameters in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier with type arguments of type TierShuffleDescriptor 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 TierShuffleDescriptor 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 TierShuffleDescriptor Modifier and Type Method Description void
DiskTierConsumerAgent. updateTierShuffleDescriptor(TieredStoragePartitionId partitionId, TieredStorageInputChannelId inputChannelId, TieredStorageSubpartitionId subpartitionId, TierShuffleDescriptor tierShuffleDescriptor)
Method parameters in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk with type arguments of type TierShuffleDescriptor 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)
-
Uses of TierShuffleDescriptor 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 TierShuffleDescriptor Modifier and Type Method Description void
MemoryTierConsumerAgent. updateTierShuffleDescriptor(TieredStoragePartitionId partitionId, TieredStorageInputChannelId inputChannelId, TieredStorageSubpartitionId subpartitionId, TierShuffleDescriptor tierShuffleDescriptor)
Method parameters in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory with type arguments of type TierShuffleDescriptor 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 TierShuffleDescriptor in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote
Classes in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote that implement TierShuffleDescriptor Modifier and Type Class Description class
RemoteTierShuffleDescriptor
The shuffle descriptor implementation for remote tier.Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote that return TierShuffleDescriptor Modifier and Type Method Description TierShuffleDescriptor
RemoteTierMasterAgent. addPartitionAndGetShuffleDescriptor(JobID jobID, ResultPartitionID resultPartitionID)
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote with parameters of type TierShuffleDescriptor Modifier and Type Method Description void
RemoteTierMasterAgent. releasePartition(TierShuffleDescriptor shuffleDescriptor)
void
RemoteTierConsumerAgent. updateTierShuffleDescriptor(TieredStoragePartitionId partitionId, TieredStorageInputChannelId inputChannelId, TieredStorageSubpartitionId subpartitionId, TierShuffleDescriptor tierShuffleDescriptor)
Method parameters in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote with type arguments of type TierShuffleDescriptor 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)
-
Uses of TierShuffleDescriptor in org.apache.flink.runtime.shuffle
Methods in org.apache.flink.runtime.shuffle that return types with arguments of type TierShuffleDescriptor Modifier and Type Method Description List<TierShuffleDescriptor>
NettyShuffleDescriptor. getTierShuffleDescriptors()
Constructor parameters in org.apache.flink.runtime.shuffle with type arguments of type TierShuffleDescriptor Constructor Description NettyShuffleDescriptor(ResourceID producerLocation, NettyShuffleDescriptor.PartitionConnectionInfo partitionConnectionInfo, ResultPartitionID resultPartitionID, List<TierShuffleDescriptor> tierShuffleDescriptors)
-