Interface TaskExecutorPartitionTracker
-
- All Superinterfaces:
PartitionTracker<JobID,TaskExecutorPartitionInfo>
- All Known Implementing Classes:
TaskExecutorPartitionTrackerImpl
public interface TaskExecutorPartitionTracker extends PartitionTracker<JobID,TaskExecutorPartitionInfo>
Utility for tracking partitions.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description ClusterPartitionReport
createClusterPartitionReport()
Creates aClusterPartitionReport
, describing which cluster partitions are currently available.Collection<TaskExecutorPartitionInfo>
getTrackedPartitionsFor(JobID producingJobId)
Get all partitions tracked for the given job.void
promoteJobPartitions(Collection<ResultPartitionID> partitionsToPromote)
Promotes the given partitions.void
startTrackingPartition(JobID producingJobId, TaskExecutorPartitionInfo partitionInfo)
Starts the tracking of the given partition for the given job.void
stopTrackingAndReleaseAllClusterPartitions()
Releases and stops tracking all partitions.void
stopTrackingAndReleaseClusterPartitions(Collection<IntermediateDataSetID> dataSetsToRelease)
Releases partitions associated with the given datasets and stops tracking of partitions that were released.void
stopTrackingAndReleaseJobPartitions(Collection<ResultPartitionID> resultPartitionIds)
Releases the given partitions and stop the tracking of partitions that were released.void
stopTrackingAndReleaseJobPartitionsFor(JobID producingJobId)
Releases all partitions for the given job 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(JobID producingJobId, TaskExecutorPartitionInfo partitionInfo)
Starts the tracking of the given partition for the given job.- Parameters:
producingJobId
- ID of job by which the partition is producedpartitionInfo
- information about the partition
-
stopTrackingAndReleaseJobPartitions
void stopTrackingAndReleaseJobPartitions(Collection<ResultPartitionID> resultPartitionIds)
Releases the given partitions and stop the tracking of partitions that were released.
-
stopTrackingAndReleaseJobPartitionsFor
void stopTrackingAndReleaseJobPartitionsFor(JobID producingJobId)
Releases all partitions for the given job and stop the tracking of partitions that were released.
-
getTrackedPartitionsFor
Collection<TaskExecutorPartitionInfo> getTrackedPartitionsFor(JobID producingJobId)
Get all partitions tracked for the given job.- Parameters:
producingJobId
- the job id- Returns:
- the tracked partitions
-
promoteJobPartitions
void promoteJobPartitions(Collection<ResultPartitionID> partitionsToPromote)
Promotes the given partitions.
-
stopTrackingAndReleaseClusterPartitions
void stopTrackingAndReleaseClusterPartitions(Collection<IntermediateDataSetID> dataSetsToRelease)
Releases partitions associated with the given datasets and stops tracking of partitions that were released.- Parameters:
dataSetsToRelease
- data sets to release
-
stopTrackingAndReleaseAllClusterPartitions
void stopTrackingAndReleaseAllClusterPartitions()
Releases and stops tracking all partitions.
-
createClusterPartitionReport
ClusterPartitionReport createClusterPartitionReport()
Creates aClusterPartitionReport
, describing which cluster partitions are currently available.
-
-