public class TaskExecutorPartitionTrackerImpl extends AbstractPartitionTracker<JobID,TaskExecutorPartitionInfo> implements TaskExecutorPartitionTracker
partitionInfos, partitionTable
Constructor and Description |
---|
TaskExecutorPartitionTrackerImpl(ShuffleEnvironment<?,?> shuffleEnvironment) |
Modifier and Type | Method and Description |
---|---|
ClusterPartitionReport |
createClusterPartitionReport()
Creates a
ClusterPartitionReport , 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> partitionsToRelease)
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.
|
isPartitionTracked, isTrackingPartitionsFor, stopTrackingPartitions, stopTrackingPartitionsFor
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
isPartitionTracked, isTrackingPartitionsFor, stopTrackingPartitions, stopTrackingPartitionsFor
public TaskExecutorPartitionTrackerImpl(ShuffleEnvironment<?,?> shuffleEnvironment)
public void startTrackingPartition(JobID producingJobId, TaskExecutorPartitionInfo partitionInfo)
TaskExecutorPartitionTracker
startTrackingPartition
in interface TaskExecutorPartitionTracker
producingJobId
- ID of job by which the partition is producedpartitionInfo
- information about the partitionpublic void stopTrackingAndReleaseJobPartitions(Collection<ResultPartitionID> partitionsToRelease)
TaskExecutorPartitionTracker
stopTrackingAndReleaseJobPartitions
in interface TaskExecutorPartitionTracker
public void stopTrackingAndReleaseJobPartitionsFor(JobID producingJobId)
TaskExecutorPartitionTracker
stopTrackingAndReleaseJobPartitionsFor
in interface TaskExecutorPartitionTracker
public Collection<TaskExecutorPartitionInfo> getTrackedPartitionsFor(JobID producingJobId)
TaskExecutorPartitionTracker
getTrackedPartitionsFor
in interface TaskExecutorPartitionTracker
producingJobId
- the job idpublic void promoteJobPartitions(Collection<ResultPartitionID> partitionsToPromote)
TaskExecutorPartitionTracker
promoteJobPartitions
in interface TaskExecutorPartitionTracker
public void stopTrackingAndReleaseClusterPartitions(Collection<IntermediateDataSetID> dataSetsToRelease)
TaskExecutorPartitionTracker
stopTrackingAndReleaseClusterPartitions
in interface TaskExecutorPartitionTracker
dataSetsToRelease
- data sets to releasepublic void stopTrackingAndReleaseAllClusterPartitions()
TaskExecutorPartitionTracker
stopTrackingAndReleaseAllClusterPartitions
in interface TaskExecutorPartitionTracker
public ClusterPartitionReport createClusterPartitionReport()
TaskExecutorPartitionTracker
ClusterPartitionReport
, describing which cluster partitions are currently
available.createClusterPartitionReport
in interface TaskExecutorPartitionTracker
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.