Uses of Class
org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
Packages that use TaskStateSnapshot Package Description org.apache.flink.runtime.checkpoint org.apache.flink.runtime.checkpoint.channel 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 -
-
Uses of TaskStateSnapshot in org.apache.flink.runtime.checkpoint
Fields in org.apache.flink.runtime.checkpoint declared as TaskStateSnapshot Modifier and Type Field Description static TaskStateSnapshot
TaskStateSnapshot. FINISHED_ON_RESTORE
Methods in org.apache.flink.runtime.checkpoint that return TaskStateSnapshot Modifier and Type Method Description static TaskStateSnapshot
TaskStateSnapshot. deserializeTaskStateSnapshot(org.apache.flink.util.SerializedValue<TaskStateSnapshot> subtaskState, ClassLoader classLoader)
TaskStateSnapshot
JobManagerTaskRestore. getTaskStateSnapshot()
Methods in org.apache.flink.runtime.checkpoint that return types with arguments of type TaskStateSnapshot Modifier and Type Method Description static org.apache.flink.util.SerializedValue<TaskStateSnapshot>
TaskStateSnapshot. serializeTaskStateSnapshot(TaskStateSnapshot subtaskState)
Methods in org.apache.flink.runtime.checkpoint with parameters of type TaskStateSnapshot Modifier and Type Method Description PendingCheckpoint.TaskAcknowledgeResult
PendingCheckpoint. acknowledgeTask(ExecutionAttemptID executionAttemptId, TaskStateSnapshot operatorSubtaskStates, CheckpointMetrics metrics)
Acknowledges the task with the given execution attempt id and the given subtask state.static org.apache.flink.util.SerializedValue<TaskStateSnapshot>
TaskStateSnapshot. serializeTaskStateSnapshot(TaskStateSnapshot subtaskState)
Method parameters in org.apache.flink.runtime.checkpoint with type arguments of type TaskStateSnapshot Modifier and Type Method Description void
CheckpointCoordinatorGateway. acknowledgeCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, org.apache.flink.util.SerializedValue<TaskStateSnapshot> subtaskState)
static TaskStateSnapshot
TaskStateSnapshot. deserializeTaskStateSnapshot(org.apache.flink.util.SerializedValue<TaskStateSnapshot> subtaskState, ClassLoader classLoader)
Constructors in org.apache.flink.runtime.checkpoint with parameters of type TaskStateSnapshot Constructor Description JobManagerTaskRestore(long restoreCheckpointId, TaskStateSnapshot taskStateSnapshot)
-
Uses of TaskStateSnapshot in org.apache.flink.runtime.checkpoint.channel
Constructors in org.apache.flink.runtime.checkpoint.channel with parameters of type TaskStateSnapshot Constructor Description SequentialChannelStateReaderImpl(TaskStateSnapshot taskStateSnapshot)
-
Uses of TaskStateSnapshot in org.apache.flink.runtime.execution
Methods in org.apache.flink.runtime.execution with parameters of type TaskStateSnapshot Modifier and Type Method Description 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 TaskStateSnapshot in org.apache.flink.runtime.jobmaster
Method parameters in org.apache.flink.runtime.jobmaster with type arguments of type TaskStateSnapshot Modifier and Type Method Description void
JobMaster. acknowledgeCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, org.apache.flink.util.SerializedValue<TaskStateSnapshot> checkpointState)
-
Uses of TaskStateSnapshot in org.apache.flink.runtime.messages.checkpoint
Methods in org.apache.flink.runtime.messages.checkpoint that return TaskStateSnapshot Modifier and Type Method Description TaskStateSnapshot
AcknowledgeCheckpoint. getSubtaskState()
Constructors in org.apache.flink.runtime.messages.checkpoint with parameters of type TaskStateSnapshot Constructor Description AcknowledgeCheckpoint(org.apache.flink.api.common.JobID job, ExecutionAttemptID taskExecutionId, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot subtaskState)
-
Uses of TaskStateSnapshot in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler with parameters of type TaskStateSnapshot Modifier and Type Method Description void
ExecutionGraphHandler. acknowledgeCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot checkpointState)
void
SchedulerBase. acknowledgeCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot checkpointState)
void
SchedulerNG. acknowledgeCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot checkpointState)
-
Uses of TaskStateSnapshot in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive with parameters of type TaskStateSnapshot Modifier and Type Method Description void
AdaptiveScheduler. acknowledgeCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot checkpointState)
-
Uses of TaskStateSnapshot in org.apache.flink.runtime.state
Fields in org.apache.flink.runtime.state with type parameters of type TaskStateSnapshot Modifier and Type Field Description protected SortedMap<Long,TaskStateSnapshot>
TaskLocalStateStoreImpl. storedTaskStateByCheckpointID
Maps checkpoint ids to local TaskStateSnapshots.Methods in org.apache.flink.runtime.state that return TaskStateSnapshot Modifier and Type Method Description TaskStateSnapshot
NoOpTaskLocalStateStoreImpl. retrieveLocalState(long checkpointID)
TaskStateSnapshot
TaskLocalStateStore. retrieveLocalState(long checkpointID)
Returns the local state that is stored under the given checkpoint id or null if nothing was stored under the id.TaskStateSnapshot
TaskLocalStateStoreImpl. retrieveLocalState(long checkpointID)
Methods in org.apache.flink.runtime.state with parameters of type TaskStateSnapshot Modifier and Type Method Description 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)
void
ChangelogTaskLocalStateStore. storeLocalState(long checkpointId, TaskStateSnapshot localState)
void
NoOpTaskLocalStateStoreImpl. storeLocalState(long checkpointId, TaskStateSnapshot localState)
void
TaskLocalStateStore. storeLocalState(long checkpointId, TaskStateSnapshot localState)
Stores the local state for the given checkpoint id.void
TaskLocalStateStoreImpl. storeLocalState(long checkpointId, TaskStateSnapshot localState)
-
Uses of TaskStateSnapshot in org.apache.flink.runtime.taskexecutor.rpc
Methods in org.apache.flink.runtime.taskexecutor.rpc with parameters of type TaskStateSnapshot Modifier and Type Method Description void
RpcCheckpointResponder. acknowledgeCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot subtaskState)
-
Uses of TaskStateSnapshot in org.apache.flink.runtime.taskmanager
Methods in org.apache.flink.runtime.taskmanager with parameters of type TaskStateSnapshot Modifier and Type Method Description void
CheckpointResponder. acknowledgeCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot subtaskState)
Acknowledges the given checkpoint.void
RuntimeEnvironment. acknowledgeCheckpoint(long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot checkpointStateHandles)
-