Uses of Class
org.apache.flink.runtime.checkpoint.JobManagerTaskRestore
-
Packages that use JobManagerTaskRestore Package Description org.apache.flink.runtime.deployment org.apache.flink.runtime.executiongraph org.apache.flink.runtime.state -
-
Uses of JobManagerTaskRestore in org.apache.flink.runtime.deployment
Methods in org.apache.flink.runtime.deployment that return JobManagerTaskRestore Modifier and Type Method Description JobManagerTaskRestore
TaskDeploymentDescriptor. getTaskRestore()
Methods in org.apache.flink.runtime.deployment with parameters of type JobManagerTaskRestore Modifier and Type Method Description TaskDeploymentDescriptor
TaskDeploymentDescriptorFactory. createDeploymentDescriptor(Execution execution, AllocationID allocationID, JobManagerTaskRestore taskRestore, Collection<ResultPartitionDeploymentDescriptor> producedPartitions)
Constructors in org.apache.flink.runtime.deployment with parameters of type JobManagerTaskRestore Constructor Description TaskDeploymentDescriptor(org.apache.flink.api.common.JobID jobId, TaskDeploymentDescriptor.MaybeOffloaded<JobInformation> serializedJobInformation, TaskDeploymentDescriptor.MaybeOffloaded<TaskInformation> serializedTaskInformation, ExecutionAttemptID executionAttemptId, AllocationID allocationId, JobManagerTaskRestore taskRestore, List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors, List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors)
-
Uses of JobManagerTaskRestore in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return JobManagerTaskRestore Modifier and Type Method Description JobManagerTaskRestore
Execution. getTaskRestore()
Methods in org.apache.flink.runtime.executiongraph with parameters of type JobManagerTaskRestore Modifier and Type Method Description void
Execution. setInitialState(JobManagerTaskRestore taskRestore)
Sets the initial state for the execution. -
Uses of JobManagerTaskRestore in org.apache.flink.runtime.state
Constructors in org.apache.flink.runtime.state with parameters of type JobManagerTaskRestore Constructor Description TaskStateManagerImpl(org.apache.flink.api.common.JobID jobId, ExecutionAttemptID executionAttemptID, TaskLocalStateStore localStateStore, FileMergingSnapshotManagerClosableWrapper fileMergingSnapshotManager, StateChangelogStorage<?> stateChangelogStorage, TaskExecutorStateChangelogStoragesManager changelogStoragesManager, JobManagerTaskRestore jobManagerTaskRestore, CheckpointResponder checkpointResponder)
TaskStateManagerImpl(org.apache.flink.api.common.JobID jobId, ExecutionAttemptID executionAttemptID, TaskLocalStateStore localStateStore, FileMergingSnapshotManagerClosableWrapper fileMergingSnapshotManager, StateChangelogStorage<?> stateChangelogStorage, TaskExecutorStateChangelogStoragesManager changelogStoragesManager, JobManagerTaskRestore jobManagerTaskRestore, CheckpointResponder checkpointResponder, SequentialChannelStateReaderImpl sequentialChannelStateReader)
-