Class ExecutionVertexFinishedEvent
- java.lang.Object
-
- org.apache.flink.runtime.jobmaster.event.ExecutionVertexFinishedEvent
-
- All Implemented Interfaces:
Serializable
,JobEvent
public class ExecutionVertexFinishedEvent extends Object implements JobEvent
This class is used to record the state ofExecutionVertex
.- See Also:
- Serialized Form
-
-
Constructor Summary
Constructors Constructor Description ExecutionVertexFinishedEvent(ExecutionAttemptID executionAttemptId, TaskManagerLocation location, Map<OperatorID,CompletableFuture<byte[]>> operatorCoordinatorSnapshotFutures, CompletableFuture<ShuffleMasterSnapshot> shuffleMasterSnapshotFuture, IOMetrics ioMetrics, Map<String,Accumulator<?,?>> userAccumulators)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description int
getAttemptNumber()
ExecutionAttemptID
getExecutionAttemptId()
ExecutionVertexID
getExecutionVertexId()
IOMetrics
getIOMetrics()
Map<OperatorID,CompletableFuture<byte[]>>
getOperatorCoordinatorSnapshotFutures()
CompletableFuture<ShuffleMasterSnapshot>
getShuffleMasterSnapshotFuture()
TaskManagerLocation
getTaskManagerLocation()
Map<String,Accumulator<?,?>>
getUserAccumulators()
boolean
hasOperatorCoordinatorAndShuffleMasterSnapshots()
String
toString()
-
-
-
Constructor Detail
-
ExecutionVertexFinishedEvent
public ExecutionVertexFinishedEvent(ExecutionAttemptID executionAttemptId, TaskManagerLocation location, Map<OperatorID,CompletableFuture<byte[]>> operatorCoordinatorSnapshotFutures, @Nullable CompletableFuture<ShuffleMasterSnapshot> shuffleMasterSnapshotFuture, IOMetrics ioMetrics, @Nullable Map<String,Accumulator<?,?>> userAccumulators)
-
-
Method Detail
-
getExecutionAttemptId
public ExecutionAttemptID getExecutionAttemptId()
-
getExecutionVertexId
public ExecutionVertexID getExecutionVertexId()
-
getAttemptNumber
public int getAttemptNumber()
-
getTaskManagerLocation
public TaskManagerLocation getTaskManagerLocation()
-
getOperatorCoordinatorSnapshotFutures
public Map<OperatorID,CompletableFuture<byte[]>> getOperatorCoordinatorSnapshotFutures()
-
getShuffleMasterSnapshotFuture
@Nullable public CompletableFuture<ShuffleMasterSnapshot> getShuffleMasterSnapshotFuture()
-
getIOMetrics
public IOMetrics getIOMetrics()
-
getUserAccumulators
@Nullable public Map<String,Accumulator<?,?>> getUserAccumulators()
-
hasOperatorCoordinatorAndShuffleMasterSnapshots
public boolean hasOperatorCoordinatorAndShuffleMasterSnapshots()
-
-