public class JobMasterPartitionTrackerImpl extends AbstractPartitionTracker<ResourceID,ResultPartitionDeploymentDescriptor> implements JobMasterPartitionTracker
partitionInfos, partitionTable
Constructor and Description |
---|
JobMasterPartitionTrackerImpl(JobID jobId,
ShuffleMaster<?> shuffleMaster,
PartitionTrackerFactory.TaskExecutorGatewayLookup taskExecutorGatewayLookup) |
Modifier and Type | Method and Description |
---|---|
void |
connectToResourceManager(ResourceManagerGateway resourceManagerGateway) |
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.
|
void |
stopTrackingAndReleasePartitions(Collection<ResultPartitionID> resultPartitionIds,
boolean releaseOnShuffleMaster)
Releases the given partitions and stop the tracking of partitions that were released.
|
isPartitionTracked, isTrackingPartitionsFor, stopTrackingPartitions, stopTrackingPartitionsFor
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
getAllTrackedClusterPartitions, getAllTrackedNonClusterPartitions, stopTrackingAndReleasePartitions
isPartitionTracked, isTrackingPartitionsFor, stopTrackingPartitions, stopTrackingPartitionsFor
public JobMasterPartitionTrackerImpl(JobID jobId, ShuffleMaster<?> shuffleMaster, PartitionTrackerFactory.TaskExecutorGatewayLookup taskExecutorGatewayLookup)
public void startTrackingPartition(ResourceID producingTaskExecutorId, ResultPartitionDeploymentDescriptor resultPartitionDeploymentDescriptor)
JobMasterPartitionTracker
startTrackingPartition
in interface JobMasterPartitionTracker
producingTaskExecutorId
- ID of task executor on which the partition is producedresultPartitionDeploymentDescriptor
- deployment descriptor of the partitionpublic void stopTrackingAndReleasePartitions(Collection<ResultPartitionID> resultPartitionIds, boolean releaseOnShuffleMaster)
JobMasterPartitionTracker
stopTrackingAndReleasePartitions
in interface JobMasterPartitionTracker
public CompletableFuture<Void> stopTrackingAndPromotePartitions(Collection<ResultPartitionID> resultPartitionIds)
JobMasterPartitionTracker
stopTrackingAndPromotePartitions
in interface JobMasterPartitionTracker
resultPartitionIds
- ID of the partition containing both job partitions and cluster
partitions.public Collection<ResultPartitionDeploymentDescriptor> getAllTrackedPartitions()
JobMasterPartitionTracker
getAllTrackedPartitions
in interface JobMasterPartitionTracker
public void connectToResourceManager(ResourceManagerGateway resourceManagerGateway)
connectToResourceManager
in interface JobMasterPartitionTracker
public List<ShuffleDescriptor> getClusterPartitionShuffleDescriptors(IntermediateDataSetID intermediateDataSetID)
JobMasterPartitionTracker
getClusterPartitionShuffleDescriptors
in interface JobMasterPartitionTracker
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.