Uses of Package
org.apache.flink.runtime.checkpoint
-
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.checkpoint Class Description AbstractCheckpointStats Base class for checkpoint statistics.AbstractCompleteCheckpointStore The abstract class ofCompletedCheckpointStore, which holds theSharedStateRegistryand provides the registration of shared state.Checkpoint A checkpoint, pending or completed.Checkpoint.DiscardObject Extra interface for discarding the checkpoint.CheckpointCoordinator The checkpoint coordinator coordinates the distributed snapshots of operators and state.CheckpointException Base class for checkpoint related exceptions.CheckpointFailureManager The checkpoint failure manager which centralized manage checkpoint failure processing logic.CheckpointFailureManager.FailJobCallback A callback interface about how to fail a job.CheckpointFailureReason Various reasons why a checkpoint was failure.CheckpointIDCounter A checkpoint ID counter.CheckpointMetrics A collection of simple metrics, around the triggering of a checkpoint.CheckpointMetricsBuilder A builder forCheckpointMetrics.CheckpointOptions Options for performing the checkpoint.CheckpointOptions.AlignmentType How a checkpoint should be aligned.CheckpointPlan The plan of one checkpoint, indicating which tasks to trigger, waiting for acknowledge or commit for one specific checkpoint.CheckpointPlanCalculator Calculates the plan of the next checkpoint, including the tasks to trigger, wait or commit for each checkpoint.CheckpointPlanCalculatorContext Provides the context forDefaultCheckpointPlanCalculatorto compute the plan of checkpoints.CheckpointProperties The configuration of a checkpoint.CheckpointRecoveryFactory A factory for per Job checkpoint recovery components.CheckpointRetentionPolicy Policy for whether checkpoints are retained after a job terminates.CheckpointsCleaner Delegate class responsible for checkpoints cleaning and counting the number of checkpoints yet to clean.CheckpointStatsCounts Counts of checkpoints.CheckpointStatsHistory An array based history of checkpoint stats.CheckpointStatsListener An interface that allows listening on the checkpoint lifecycle.CheckpointStatsSnapshot A snapshot of the checkpoint stats.CheckpointStatsStatus Status of the tracked checkpoint.CheckpointStatsTracker Tracker for checkpoint statistics.CheckpointStoreUtil CompletedCheckpointStoreutility interfaces.CheckpointType The type of checkpoint to perform.CompletedCheckpoint A CompletedCheckpoint describes a checkpoint after all required tasks acknowledged it (with their state) and that is considered successful.CompletedCheckpointStats Statistics for a successfully completed checkpoint.CompletedCheckpointStatsSummarySnapshot Immutable snapshot ofCompletedCheckpointStatsSummary.CompletedCheckpointStore A bounded LIFO-queue ofCompletedCheckpointinstances.DeactivatedCheckpointCompletedCheckpointStore This class represents aCompletedCheckpointStoreif checkpointing has been disabled.DeactivatedCheckpointIDCounter This class represents aCheckpointIDCounterif checkpointing is deactivated.FailedCheckpointStats Statistics for a failed checkpoint.FinishedOperatorSubtaskState A specializedOperatorSubtaskStaterepresenting the subtask is finished.FinishedTaskStateProvider Collects and fulfills the finished state for the subtasks or operators.FinishedTaskStateProvider.PartialFinishingNotSupportedByStateException Thrown when some subtasks of the operator have been finished but state doesn't support that (e.g.InflightDataRescalingDescriptor Captures ambiguous mappings of old channels to new channels for a particular gate or partition.InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor Captures ambiguous mappings of old channels to new channels.InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor.MappingType Type of mapping which should be used for this in-flight data.InitializationStatus Status of the initialization.LastStateConnectionStateListener ConnectionStateListenerwhich records the last state it was notified about.MasterState Simple encapsulation of state generated by checkpoint coordinator.MasterTriggerRestoreHook The interface for hooks that can be called by the checkpoint coordinator when triggering or restoring a checkpoint.NoOpCheckpointStatsTracker OperatorCoordinatorCheckpointContext This context is the interface through which theCheckpointCoordinatorinteracts with anOperatorCoordinatorduring checkpointing and checkpoint restoring.OperatorState Simple container class which contains the raw/managed operator state and key-group state handles from all subtasks of an operator and therefore represents the complete state of a logical operator.OperatorStateRepartitioner Interface that allows to implement different strategies for repartitioning of operator state as parallelism changes.OperatorSubtaskState This class encapsulates the state for one parallel instance of an operator.OperatorSubtaskState.Builder The builder for a newOperatorSubtaskStatewhich can be obtained byOperatorSubtaskState.builder().PendingCheckpoint A pending checkpoint is a checkpoint that has been started, but has not been acknowledged by all tasks that need to acknowledge it.PendingCheckpoint.TaskAcknowledgeResult Result of thePendingCheckpoint.acknowledgedTasksmethod.PendingCheckpointStats Statistics for a pending checkpoint that is still in progress.PerJobCheckpointRecoveryFactory.CheckpointStoreRecoveryHelper Restores or creates aCompletedCheckpointStore, optionally using an existing one.PrioritizedOperatorSubtaskState This class is a wrapper over multiple alternativeOperatorSubtaskStatethat are (partial) substitutes for each other and imposes a priority ordering over all alternatives for the different states which define an order in which the operator should attempt to restore the state from them.RescaleMappings Contains the fine-grain channel mappings that occur when a connected operator has been rescaled.RestoredCheckpointStats Statistics for a restored checkpoint.SavepointType The type of checkpoint to perform.SavepointType.PostCheckpointAction What's the intended action after the checkpoint (relevant for stopping with savepoint).SnapshotType The type of checkpoint to perform.SnapshotType.SharingFilesStrategy Defines what files can be shared across snapshots.StateObjectCollection This class represents a generic collection forStateObjects.StatsSummary Aggregated values of some measurement such as min/max/average state size.StatsSummarySnapshot Immutable snapshot ofStatsSummary.SubTaskInitializationMetrics A collection of simple metrics, around the triggering of a checkpoint.SubTaskInitializationMetricsBuilder A builder forSubTaskInitializationMetrics.SubtaskState Deprecated.Internal class for savepoint backwards compatibility.SubtaskStateStats Statistics for a single subtask that is part of a checkpoint.TaskStateSnapshot This class encapsulates state handles to the snapshots of all operator instances executed within one task.TaskStateStats Statistics for a single task/operator that gathers all statistics of its subtasks and provides summary statistics about all subtasks.TaskStateStats.TaskStateStatsSummary Summary of the subtask stats of a single task/operator.VertexFinishedStateChecker This class encapsulates the operation that checks if there are illegal modification to the JobGraph when restoring from a checkpoint with partially or fully finished operator states.ZooKeeperCheckpointStoreUtil SingletonCheckpointStoreUtilimplementation for ZooKeeper. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.checkpoint.channel Class Description CheckpointOptions Options for performing the checkpoint.TaskStateSnapshot This class encapsulates state handles to the snapshots of all operator instances executed within one task. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.checkpoint.filemerging Class Description OperatorSubtaskState This class encapsulates the state for one parallel instance of an operator. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.checkpoint.hooks Class Description MasterState Simple encapsulation of state generated by checkpoint coordinator.MasterTriggerRestoreHook The interface for hooks that can be called by the checkpoint coordinator when triggering or restoring a checkpoint. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.checkpoint.metadata Class Description CheckpointProperties The configuration of a checkpoint.MasterState Simple encapsulation of state generated by checkpoint coordinator.OperatorState Simple container class which contains the raw/managed operator state and key-group state handles from all subtasks of an operator and therefore represents the complete state of a logical operator.OperatorSubtaskState This class encapsulates the state for one parallel instance of an operator.StateObjectCollection This class represents a generic collection forStateObjects. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.deployment Class Description JobManagerTaskRestore This class encapsulates the data from the job manager to restore a task. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.dispatcher Class Description CheckpointStatsSnapshot A snapshot of the checkpoint stats. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.dispatcher.cleanup Class Description CheckpointRecoveryFactory A factory for per Job checkpoint recovery components. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.execution Class Description CheckpointException Base class for checkpoint related exceptions.CheckpointMetrics A collection of simple metrics, around the triggering of a checkpoint.TaskStateSnapshot This class encapsulates state handles to the snapshots of all operator instances executed within one task. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.executiongraph Class Description CheckpointCoordinator The checkpoint coordinator coordinates the distributed snapshots of operators and state.CheckpointIDCounter A checkpoint ID counter.CheckpointOptions Options for performing the checkpoint.CheckpointPlanCalculatorContext Provides the context forDefaultCheckpointPlanCalculatorto compute the plan of checkpoints.CheckpointsCleaner Delegate class responsible for checkpoints cleaning and counting the number of checkpoints yet to clean.CheckpointStatsSnapshot A snapshot of the checkpoint stats.CheckpointStatsTracker Tracker for checkpoint statistics.CompletedCheckpointStore A bounded LIFO-queue ofCompletedCheckpointinstances.JobManagerTaskRestore This class encapsulates the data from the job manager to restore a task.MasterTriggerRestoreHook The interface for hooks that can be called by the checkpoint coordinator when triggering or restoring a checkpoint. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.highavailability Class Description CheckpointRecoveryFactory A factory for per Job checkpoint recovery components. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.highavailability.nonha Class Description CheckpointRecoveryFactory A factory for per Job checkpoint recovery components. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.highavailability.nonha.embedded Class Description CheckpointRecoveryFactory A factory for per Job checkpoint recovery components. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.highavailability.zookeeper Class Description CheckpointRecoveryFactory A factory for per Job checkpoint recovery components. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.io.network.api Class Description CheckpointOptions Options for performing the checkpoint. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.io.network.api.writer Class Description CheckpointException Base class for checkpoint related exceptions.RescaleMappings Contains the fine-grain channel mappings that occur when a connected operator has been rescaled. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.io.network.partition Class Description CheckpointException Base class for checkpoint related exceptions. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.io.network.partition.consumer Class Description CheckpointException Base class for checkpoint related exceptions. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle Class Description CheckpointException Base class for checkpoint related exceptions. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.jobgraph.tasks Class Description CheckpointException Base class for checkpoint related exceptions.CheckpointMetaData Encapsulates all the meta data for a checkpoint.CheckpointMetricsBuilder A builder forCheckpointMetrics.CheckpointOptions Options for performing the checkpoint.CheckpointRetentionPolicy Policy for whether checkpoints are retained after a job terminates. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.jobmanager.slots Class Description CheckpointOptions Options for performing the checkpoint. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.jobmaster Class Description CheckpointCoordinatorGateway RPC Gateway interface for messages to the CheckpointCoordinator.CheckpointMetrics A collection of simple metrics, around the triggering of a checkpoint.CheckpointOptions Options for performing the checkpoint.CheckpointRecoveryFactory A factory for per Job checkpoint recovery components.CheckpointStatsSnapshot A snapshot of the checkpoint stats.CompletedCheckpoint A CompletedCheckpoint describes a checkpoint after all required tasks acknowledged it (with their state) and that is considered successful.SubTaskInitializationMetrics A collection of simple metrics, around the triggering of a checkpoint.TaskStateSnapshot This class encapsulates state handles to the snapshots of all operator instances executed within one task. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.messages.checkpoint Class Description CheckpointException Base class for checkpoint related exceptions.CheckpointFailureReason Various reasons why a checkpoint was failure.CheckpointMetrics A collection of simple metrics, around the triggering of a checkpoint.TaskStateSnapshot This class encapsulates state handles to the snapshots of all operator instances executed within one task. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.operators.coordination Class Description CheckpointCoordinator The checkpoint coordinator coordinates the distributed snapshots of operators and state.OperatorCoordinatorCheckpointContext This context is the interface through which theCheckpointCoordinatorinteracts with anOperatorCoordinatorduring checkpointing and checkpoint restoring. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.rest.handler.job.checkpoints Class Description AbstractCheckpointStats Base class for checkpoint statistics.CheckpointStatsSnapshot A snapshot of the checkpoint stats. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.rest.messages.checkpoints Class Description AbstractCheckpointStats Base class for checkpoint statistics.CheckpointStatsStatus Status of the tracked checkpoint.StatsSummary Aggregated values of some measurement such as min/max/average state size.StatsSummarySnapshot Immutable snapshot ofStatsSummary. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.scheduler Class Description CheckpointIDCounter A checkpoint ID counter.CheckpointMetrics A collection of simple metrics, around the triggering of a checkpoint.CheckpointRecoveryFactory A factory for per Job checkpoint recovery components.CheckpointScheduling CheckpointSchedulingprovides methods for starting and stopping the periodic scheduling of checkpoints.CheckpointsCleaner Delegate class responsible for checkpoints cleaning and counting the number of checkpoints yet to clean.CheckpointStatsSnapshot A snapshot of the checkpoint stats.CheckpointStatsTracker Tracker for checkpoint statistics.CompletedCheckpoint A CompletedCheckpoint describes a checkpoint after all required tasks acknowledged it (with their state) and that is considered successful.CompletedCheckpointStore A bounded LIFO-queue ofCompletedCheckpointinstances.SubTaskInitializationMetrics A collection of simple metrics, around the triggering of a checkpoint.TaskStateSnapshot This class encapsulates state handles to the snapshots of all operator instances executed within one task. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.scheduler.adaptive Class Description CheckpointMetrics A collection of simple metrics, around the triggering of a checkpoint.CheckpointRecoveryFactory A factory for per Job checkpoint recovery components.CheckpointScheduling CheckpointSchedulingprovides methods for starting and stopping the periodic scheduling of checkpoints.CheckpointsCleaner Delegate class responsible for checkpoints cleaning and counting the number of checkpoints yet to clean.CheckpointStatsSnapshot A snapshot of the checkpoint stats.CompletedCheckpoint A CompletedCheckpoint describes a checkpoint after all required tasks acknowledged it (with their state) and that is considered successful.SubTaskInitializationMetrics A collection of simple metrics, around the triggering of a checkpoint.TaskStateSnapshot This class encapsulates state handles to the snapshots of all operator instances executed within one task. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.scheduler.adaptive.allocator Class Description CompletedCheckpoint A CompletedCheckpoint describes a checkpoint after all required tasks acknowledged it (with their state) and that is considered successful. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.scheduler.adaptivebatch Class Description CheckpointRecoveryFactory A factory for per Job checkpoint recovery components.CheckpointScheduling CheckpointSchedulingprovides methods for starting and stopping the periodic scheduling of checkpoints.CheckpointsCleaner Delegate class responsible for checkpoints cleaning and counting the number of checkpoints yet to clean. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.scheduler.stopwithsavepoint Class Description CheckpointCoordinator The checkpoint coordinator coordinates the distributed snapshots of operators and state.CompletedCheckpoint A CompletedCheckpoint describes a checkpoint after all required tasks acknowledged it (with their state) and that is considered successful. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.state Class Description CheckpointMetaData Encapsulates all the meta data for a checkpoint.CheckpointMetrics A collection of simple metrics, around the triggering of a checkpoint.CheckpointOptions Options for performing the checkpoint.CompletedCheckpoint A CompletedCheckpoint describes a checkpoint after all required tasks acknowledged it (with their state) and that is considered successful.InflightDataRescalingDescriptor Captures ambiguous mappings of old channels to new channels for a particular gate or partition.JobManagerTaskRestore This class encapsulates the data from the job manager to restore a task.OperatorSubtaskState This class encapsulates the state for one parallel instance of an operator.PrioritizedOperatorSubtaskState This class is a wrapper over multiple alternativeOperatorSubtaskStatethat are (partial) substitutes for each other and imposes a priority ordering over all alternatives for the different states which define an order in which the operator should attempt to restore the state from them.SnapshotType The type of checkpoint to perform.StateObjectCollection This class represents a generic collection forStateObjects.SubTaskInitializationMetrics A collection of simple metrics, around the triggering of a checkpoint.TaskStateSnapshot This class encapsulates state handles to the snapshots of all operator instances executed within one task. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.state.heap Class Description CheckpointOptions Options for performing the checkpoint. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.state.v2.adaptor Class Description CheckpointOptions Options for performing the checkpoint.SnapshotType The type of checkpoint to perform. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.taskexecutor Class Description CheckpointOptions Options for performing the checkpoint. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.taskexecutor.rpc Class Description CheckpointCoordinatorGateway RPC Gateway interface for messages to the CheckpointCoordinator.CheckpointException Base class for checkpoint related exceptions.CheckpointMetrics A collection of simple metrics, around the triggering of a checkpoint.SubTaskInitializationMetrics A collection of simple metrics, around the triggering of a checkpoint.TaskStateSnapshot This class encapsulates state handles to the snapshots of all operator instances executed within one task. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.taskmanager Class Description CheckpointException Base class for checkpoint related exceptions.CheckpointMetrics A collection of simple metrics, around the triggering of a checkpoint.CheckpointOptions Options for performing the checkpoint.SubTaskInitializationMetrics A collection of simple metrics, around the triggering of a checkpoint.TaskStateSnapshot This class encapsulates state handles to the snapshots of all operator instances executed within one task. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.util Class Description CompletedCheckpointStore A bounded LIFO-queue ofCompletedCheckpointinstances.ZooKeeperCheckpointIDCounter CheckpointIDCounterinstances for JobManagers running inHighAvailabilityMode.ZOOKEEPER. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.runtime.webmonitor Class Description CheckpointStatsSnapshot A snapshot of the checkpoint stats. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.streaming.api.checkpoint Class Description MasterTriggerRestoreHook The interface for hooks that can be called by the checkpoint coordinator when triggering or restoring a checkpoint. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.streaming.api.operators Class Description CheckpointException Base class for checkpoint related exceptions.CheckpointOptions Options for performing the checkpoint.OperatorSubtaskState This class encapsulates the state for one parallel instance of an operator.PrioritizedOperatorSubtaskState This class is a wrapper over multiple alternativeOperatorSubtaskStatethat are (partial) substitutes for each other and imposes a priority ordering over all alternatives for the different states which define an order in which the operator should attempt to restore the state from them.StateObjectCollection This class represents a generic collection forStateObjects.SubTaskInitializationMetricsBuilder A builder forSubTaskInitializationMetrics. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.streaming.api.operators.sort Class Description CheckpointException Base class for checkpoint related exceptions. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.streaming.api.operators.sorted.state Class Description CheckpointOptions Options for performing the checkpoint. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.streaming.runtime.io Class Description CheckpointException Base class for checkpoint related exceptions.InflightDataRescalingDescriptor Captures ambiguous mappings of old channels to new channels for a particular gate or partition. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.streaming.runtime.io.checkpointing Class Description CheckpointException Base class for checkpoint related exceptions. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.streaming.runtime.io.recovery Class Description CheckpointException Base class for checkpoint related exceptions.InflightDataRescalingDescriptor Captures ambiguous mappings of old channels to new channels for a particular gate or partition. -
Classes in org.apache.flink.runtime.checkpoint used by org.apache.flink.streaming.runtime.tasks Class Description CheckpointException Base class for checkpoint related exceptions.CheckpointMetaData Encapsulates all the meta data for a checkpoint.CheckpointMetricsBuilder A builder forCheckpointMetrics.CheckpointOptions Options for performing the checkpoint.SubTaskInitializationMetricsBuilder A builder forSubTaskInitializationMetrics.