Interface JobMasterPartitionTracker
-
- All Superinterfaces:
PartitionTracker<ResourceID,ResultPartitionDeploymentDescriptor>
- All Known Implementing Classes:
JobMasterPartitionTrackerImpl
public interface JobMasterPartitionTracker extends PartitionTracker<ResourceID,ResultPartitionDeploymentDescriptor>
Utility for tracking partitions and issuing release calls to task executors and shuffle masters.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Default Methods Modifier and Type Method Description void
connectToResourceManager(ResourceManagerGateway resourceManagerGateway)
default Collection<ResultPartitionDeploymentDescriptor>
getAllTrackedClusterPartitions()
Gets all the cluster partitions under tracking.default Collection<ResultPartitionDeploymentDescriptor>
getAllTrackedNonClusterPartitions()
Gets all the non-cluster partitions under tracking.Collection<ResultPartitionDeploymentDescriptor>
getAllTrackedPartitions()
Gets all the partitions under tracking.List<ShuffleDescriptor>
getClusterPartitionShuffleDescriptors(IntermediateDataSetID intermediateDataSetID)
Get the shuffle descriptors of the cluster partitions ordered by partition number.void
startTrackingPartition(ResourceID producingTaskExecutorId, ResultPartitionDeploymentDescriptor resultPartitionDeploymentDescriptor)
Starts the tracking of the given partition for the given task executor ID.CompletableFuture<Void>
stopTrackingAndPromotePartitions(Collection<ResultPartitionID> resultPartitionIds)
Promotes the given partitions, and stops the tracking of partitions that were promoted.default void
stopTrackingAndReleasePartitions(Collection<ResultPartitionID> resultPartitionIds)
Releases the given partitions and stop the tracking of partitions that were released.void
stopTrackingAndReleasePartitions(Collection<ResultPartitionID> resultPartitionIds, boolean releaseOnShuffleMaster)
Releases the given partitions and stop the tracking of partitions that were released.-
Methods inherited from interface org.apache.flink.runtime.io.network.partition.PartitionTracker
isPartitionTracked, isTrackingPartitionsFor, stopTrackingPartitions, stopTrackingPartitionsFor
-
-
-
-
Method Detail
-
startTrackingPartition
void startTrackingPartition(ResourceID producingTaskExecutorId, ResultPartitionDeploymentDescriptor resultPartitionDeploymentDescriptor)
Starts the tracking of the given partition for the given task executor ID.- Parameters:
producingTaskExecutorId
- ID of task executor on which the partition is producedresultPartitionDeploymentDescriptor
- deployment descriptor of the partition
-
stopTrackingAndReleasePartitions
default void stopTrackingAndReleasePartitions(Collection<ResultPartitionID> resultPartitionIds)
Releases the given partitions and stop the tracking of partitions that were released.
-
stopTrackingAndReleasePartitions
void stopTrackingAndReleasePartitions(Collection<ResultPartitionID> resultPartitionIds, boolean releaseOnShuffleMaster)
Releases the given partitions and stop the tracking of partitions that were released. The boolean flag indicates whether we need to notify the ShuffleMaster to release all external resources or not.
-
stopTrackingAndPromotePartitions
CompletableFuture<Void> stopTrackingAndPromotePartitions(Collection<ResultPartitionID> resultPartitionIds)
Promotes the given partitions, and stops the tracking of partitions that were promoted.- Parameters:
resultPartitionIds
- ID of the partition containing both job partitions and cluster partitions.- Returns:
- Future that will be completed if the partitions are promoted.
-
getAllTrackedPartitions
Collection<ResultPartitionDeploymentDescriptor> getAllTrackedPartitions()
Gets all the partitions under tracking.
-
getAllTrackedNonClusterPartitions
default Collection<ResultPartitionDeploymentDescriptor> getAllTrackedNonClusterPartitions()
Gets all the non-cluster partitions under tracking.
-
getAllTrackedClusterPartitions
default Collection<ResultPartitionDeploymentDescriptor> getAllTrackedClusterPartitions()
Gets all the cluster partitions under tracking.
-
connectToResourceManager
void connectToResourceManager(ResourceManagerGateway resourceManagerGateway)
-
getClusterPartitionShuffleDescriptors
List<ShuffleDescriptor> getClusterPartitionShuffleDescriptors(IntermediateDataSetID intermediateDataSetID)
Get the shuffle descriptors of the cluster partitions ordered by partition number.
-
-