Uses of Class
org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
Packages that use CheckpointMetrics Package Description org.apache.flink.runtime.checkpoint org.apache.flink.runtime.execution org.apache.flink.runtime.jobmaster org.apache.flink.runtime.messages.checkpoint This package contains the messages that are sent betweenJobMaster
andTaskExecutor
to coordinate the checkpoint snapshots of the distributed dataflow.org.apache.flink.runtime.scheduler org.apache.flink.runtime.scheduler.adaptive org.apache.flink.runtime.state org.apache.flink.runtime.taskexecutor.rpc org.apache.flink.runtime.taskmanager org.apache.flink.state.api.runtime -
-
Uses of CheckpointMetrics in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return CheckpointMetrics Modifier and Type Method Description CheckpointMetrics
CheckpointMetricsBuilder. build()
CheckpointMetrics
CheckpointMetricsBuilder. buildIncomplete()
Methods in org.apache.flink.runtime.checkpoint with parameters of type CheckpointMetrics Modifier and Type Method Description void
CheckpointCoordinatorGateway. acknowledgeCheckpoint(JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, SerializedValue<TaskStateSnapshot> subtaskState)
PendingCheckpoint.TaskAcknowledgeResult
PendingCheckpoint. acknowledgeTask(ExecutionAttemptID executionAttemptId, TaskStateSnapshot operatorSubtaskStates, CheckpointMetrics metrics)
Acknowledges the task with the given execution attempt id and the given subtask state.void
CheckpointCoordinator. reportCheckpointMetrics(long id, ExecutionAttemptID attemptId, CheckpointMetrics metrics)
void
CheckpointCoordinatorGateway. reportCheckpointMetrics(JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics)
void
CheckpointStatsTracker. reportIncompleteStats(long checkpointId, ExecutionAttemptID attemptId, CheckpointMetrics metrics)
void
DefaultCheckpointStatsTracker. reportIncompleteStats(long checkpointId, ExecutionAttemptID attemptId, CheckpointMetrics metrics)
void
NoOpCheckpointStatsTracker. reportIncompleteStats(long checkpointId, ExecutionAttemptID attemptId, CheckpointMetrics metrics)
-
Uses of CheckpointMetrics in org.apache.flink.runtime.execution
Methods in org.apache.flink.runtime.execution with parameters of type CheckpointMetrics Modifier and Type Method Description void
Environment. acknowledgeCheckpoint(long checkpointId, CheckpointMetrics checkpointMetrics)
Confirms that the invokable has successfully completed all steps it needed to for the checkpoint with the give checkpoint-ID.void
Environment. acknowledgeCheckpoint(long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot subtaskState)
Confirms that the invokable has successfully completed all required steps for the checkpoint with the give checkpoint-ID. -
Uses of CheckpointMetrics in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster with parameters of type CheckpointMetrics Modifier and Type Method Description void
JobMaster. acknowledgeCheckpoint(JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, SerializedValue<TaskStateSnapshot> checkpointState)
void
JobMaster. reportCheckpointMetrics(JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics)
-
Uses of CheckpointMetrics in org.apache.flink.runtime.messages.checkpoint
Methods in org.apache.flink.runtime.messages.checkpoint that return CheckpointMetrics Modifier and Type Method Description CheckpointMetrics
AcknowledgeCheckpoint. getCheckpointMetrics()
Constructors in org.apache.flink.runtime.messages.checkpoint with parameters of type CheckpointMetrics Constructor Description AcknowledgeCheckpoint(JobID job, ExecutionAttemptID taskExecutionId, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot subtaskState)
-
Uses of CheckpointMetrics in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler with parameters of type CheckpointMetrics Modifier and Type Method Description void
ExecutionGraphHandler. acknowledgeCheckpoint(JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot checkpointState)
void
SchedulerBase. acknowledgeCheckpoint(JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot checkpointState)
void
SchedulerNG. acknowledgeCheckpoint(JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot checkpointState)
void
ExecutionGraphHandler. reportCheckpointMetrics(ExecutionAttemptID attemptId, long id, CheckpointMetrics metrics)
void
SchedulerBase. reportCheckpointMetrics(JobID jobID, ExecutionAttemptID attemptId, long id, CheckpointMetrics metrics)
void
SchedulerNG. reportCheckpointMetrics(JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics)
-
Uses of CheckpointMetrics in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive with parameters of type CheckpointMetrics Modifier and Type Method Description void
AdaptiveScheduler. acknowledgeCheckpoint(JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot checkpointState)
void
AdaptiveScheduler. reportCheckpointMetrics(JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics)
-
Uses of CheckpointMetrics in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state with parameters of type CheckpointMetrics Modifier and Type Method Description void
TaskStateManager. reportIncompleteTaskStateSnapshots(CheckpointMetaData checkpointMetaData, CheckpointMetrics checkpointMetrics)
Report the stats for state snapshots for an aborted checkpoint.void
TaskStateManagerImpl. reportIncompleteTaskStateSnapshots(CheckpointMetaData checkpointMetaData, CheckpointMetrics checkpointMetrics)
void
TaskStateManager. reportTaskStateSnapshots(CheckpointMetaData checkpointMetaData, CheckpointMetrics checkpointMetrics, TaskStateSnapshot acknowledgedState, TaskStateSnapshot localState)
Report the state snapshots for the operator instances running in the owning task.void
TaskStateManagerImpl. reportTaskStateSnapshots(CheckpointMetaData checkpointMetaData, CheckpointMetrics checkpointMetrics, TaskStateSnapshot acknowledgedState, TaskStateSnapshot localState)
-
Uses of CheckpointMetrics in org.apache.flink.runtime.taskexecutor.rpc
Methods in org.apache.flink.runtime.taskexecutor.rpc with parameters of type CheckpointMetrics Modifier and Type Method Description void
RpcCheckpointResponder. acknowledgeCheckpoint(JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot subtaskState)
void
RpcCheckpointResponder. reportCheckpointMetrics(JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics)
-
Uses of CheckpointMetrics in org.apache.flink.runtime.taskmanager
Methods in org.apache.flink.runtime.taskmanager with parameters of type CheckpointMetrics Modifier and Type Method Description void
CheckpointResponder. acknowledgeCheckpoint(JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot subtaskState)
Acknowledges the given checkpoint.void
RuntimeEnvironment. acknowledgeCheckpoint(long checkpointId, CheckpointMetrics checkpointMetrics)
void
RuntimeEnvironment. acknowledgeCheckpoint(long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot checkpointStateHandles)
void
CheckpointResponder. reportCheckpointMetrics(JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics)
Report metrics for the given checkpoint. -
Uses of CheckpointMetrics in org.apache.flink.state.api.runtime
Methods in org.apache.flink.state.api.runtime with parameters of type CheckpointMetrics Modifier and Type Method Description void
SavepointEnvironment. acknowledgeCheckpoint(long checkpointId, CheckpointMetrics checkpointMetrics)
void
SavepointEnvironment. acknowledgeCheckpoint(long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot subtaskState)
-