public class TaskStateManagerImpl extends Object implements TaskStateManager
TaskStateManager
and collaborates with the job manager
through CheckpointResponder
) as well as a task-manager-local state store. Like this, client code does
not have to deal with the differences between remote or local state on recovery because this class handles both
cases transparently.
Reported state is tagged by clients so that this class can properly forward to the right receiver for the checkpointed state.
构造器和说明 |
---|
TaskStateManagerImpl(org.apache.flink.api.common.JobID jobId,
ExecutionAttemptID executionAttemptID,
TaskLocalStateStore localStateStore,
JobManagerTaskRestore jobManagerTaskRestore,
CheckpointResponder checkpointResponder) |
限定符和类型 | 方法和说明 |
---|---|
LocalRecoveryConfig |
createLocalRecoveryConfig()
Returns the configuration for local recovery, i.e. the base directories for all file-based local state of the
owning subtask and the general mode for local recovery.
|
void |
notifyCheckpointComplete(long checkpointId)
Tracking when local state can be disposed.
|
PrioritizedOperatorSubtaskState |
prioritizedOperatorState(OperatorID operatorID)
Returns means to restore previously reported state of an operator running in the owning task.
|
void |
reportTaskStateSnapshots(CheckpointMetaData checkpointMetaData,
CheckpointMetrics checkpointMetrics,
TaskStateSnapshot acknowledgedState,
TaskStateSnapshot localState)
Report the state snapshots for the operator instances running in the owning task.
|
public TaskStateManagerImpl(@Nonnull org.apache.flink.api.common.JobID jobId, @Nonnull ExecutionAttemptID executionAttemptID, @Nonnull TaskLocalStateStore localStateStore, @Nullable JobManagerTaskRestore jobManagerTaskRestore, @Nonnull CheckpointResponder checkpointResponder)
public void reportTaskStateSnapshots(@Nonnull CheckpointMetaData checkpointMetaData, @Nonnull CheckpointMetrics checkpointMetrics, @Nullable TaskStateSnapshot acknowledgedState, @Nullable TaskStateSnapshot localState)
TaskStateManager
reportTaskStateSnapshots
在接口中 TaskStateManager
checkpointMetaData
- meta data from the checkpoint request.checkpointMetrics
- task level metrics for the checkpoint.acknowledgedState
- the reported states to acknowledge to the job manager.localState
- the reported states for local recovery.@Nonnull public PrioritizedOperatorSubtaskState prioritizedOperatorState(OperatorID operatorID)
TaskStateManager
prioritizedOperatorState
在接口中 TaskStateManager
operatorID
- the id of the operator for which we request state.@Nonnull public LocalRecoveryConfig createLocalRecoveryConfig()
TaskStateManager
createLocalRecoveryConfig
在接口中 TaskStateManager
public void notifyCheckpointComplete(long checkpointId) throws Exception
notifyCheckpointComplete
在接口中 CheckpointListener
checkpointId
- The ID of the checkpoint that has been completed.Exception
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.