JavaScript is disabled on your browser.
Skip navigation links
Overview
Package
Class
Use
Tree
Deprecated
Index
Help
Back to Flink Website
Prev
Next
Frames
No Frames
All Classes
Hierarchy For Package org.apache.flink.runtime.checkpoint
Package Hierarchies:
All Packages
Class Hierarchy
java.lang.
Object
org.apache.flink.runtime.checkpoint.
AbstractCheckpointStats
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
CompletedCheckpointStats
org.apache.flink.runtime.checkpoint.
FailedCheckpointStats
org.apache.flink.runtime.checkpoint.
PendingCheckpointStats
org.apache.flink.runtime.checkpoint.
CheckpointCoordinator
org.apache.flink.runtime.checkpoint.
CheckpointCoordinatorDeActivator
(implements org.apache.flink.runtime.executiongraph.
JobStatusListener
)
org.apache.flink.runtime.checkpoint.
CheckpointFailureManager
org.apache.flink.runtime.checkpoint.
CheckpointMetaData
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
CheckpointMetrics
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
CheckpointMetricsBuilder
org.apache.flink.runtime.checkpoint.
CheckpointOptions
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
CheckpointProperties
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
Checkpoints
org.apache.flink.runtime.checkpoint.
CheckpointsCleaner
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
CheckpointStatsCounts
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
CheckpointStatsHistory
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
CheckpointStatsSnapshot
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
CheckpointStatsTracker
org.apache.flink.runtime.checkpoint.
CompletedCheckpoint
(implements org.apache.flink.runtime.checkpoint.
Checkpoint
, java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
CompletedCheckpointStatsSummary
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
DefaultCompletedCheckpointStore
<R> (implements org.apache.flink.runtime.checkpoint.
CompletedCheckpointStore
)
org.apache.flink.runtime.checkpoint.
DefaultLastStateConnectionStateListener
(implements org.apache.flink.runtime.checkpoint.
LastStateConnectionStateListener
)
org.apache.flink.runtime.checkpoint.
EmbeddedCompletedCheckpointStore
(implements org.apache.flink.runtime.checkpoint.
CompletedCheckpointStore
)
org.apache.flink.runtime.checkpoint.
InflightDataRescalingDescriptor
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
JobManagerTaskRestore
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
MappingBasedRepartitioner
<T> (implements org.apache.flink.runtime.checkpoint.
OperatorStateRepartitioner
<T>)
org.apache.flink.runtime.checkpoint.
MasterState
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
MinMaxAvgStats
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
OperatorState
(implements org.apache.flink.runtime.state.
CompositeStateHandle
)
org.apache.flink.runtime.checkpoint.
OperatorSubtaskState
(implements org.apache.flink.runtime.state.
CompositeStateHandle
)
org.apache.flink.runtime.checkpoint.
OperatorSubtaskState.Builder
org.apache.flink.runtime.checkpoint.
PendingCheckpoint
(implements org.apache.flink.runtime.checkpoint.
Checkpoint
)
org.apache.flink.runtime.checkpoint.
PerJobCheckpointRecoveryFactory
(implements org.apache.flink.runtime.checkpoint.
CheckpointRecoveryFactory
)
org.apache.flink.runtime.checkpoint.
PrioritizedOperatorSubtaskState
org.apache.flink.runtime.checkpoint.
PrioritizedOperatorSubtaskState.Builder
org.apache.flink.runtime.checkpoint.
RescaledChannelsMapping
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
RestoredCheckpointStats
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
RoundRobinOperatorStateRepartitioner
(implements org.apache.flink.runtime.checkpoint.
OperatorStateRepartitioner
<T>)
org.apache.flink.runtime.checkpoint.
StandaloneCheckpointIDCounter
(implements org.apache.flink.runtime.checkpoint.
CheckpointIDCounter
)
org.apache.flink.runtime.checkpoint.
StandaloneCheckpointRecoveryFactory
(implements org.apache.flink.runtime.checkpoint.
CheckpointRecoveryFactory
)
org.apache.flink.runtime.checkpoint.
StandaloneCompletedCheckpointStore
(implements org.apache.flink.runtime.checkpoint.
CompletedCheckpointStore
)
org.apache.flink.runtime.checkpoint.
StateAssignmentOperation
org.apache.flink.runtime.checkpoint.
StateObjectCollection
<T> (implements java.util.
Collection
<E>, org.apache.flink.runtime.state.
StateObject
)
org.apache.flink.runtime.checkpoint.
SubtaskState
(implements org.apache.flink.runtime.state.
CompositeStateHandle
)
org.apache.flink.runtime.checkpoint.
SubtaskStateStats
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
TaskState
(implements org.apache.flink.runtime.state.
CompositeStateHandle
)
org.apache.flink.runtime.checkpoint.
TaskStateSnapshot
(implements org.apache.flink.runtime.state.
CompositeStateHandle
)
org.apache.flink.runtime.checkpoint.
TaskStateStats
(implements java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
TaskStateStats.TaskStateStatsSummary
(implements java.io.
Serializable
)
java.lang.
Throwable
(implements java.io.
Serializable
)
java.lang.
Exception
org.apache.flink.runtime.checkpoint.
CheckpointException
org.apache.flink.runtime.checkpoint.
ZooKeeperCheckpointIDCounter
(implements org.apache.flink.runtime.checkpoint.
CheckpointIDCounter
)
org.apache.flink.runtime.checkpoint.
ZooKeeperCheckpointRecoveryFactory
(implements org.apache.flink.runtime.checkpoint.
CheckpointRecoveryFactory
)
Interface Hierarchy
org.apache.flink.runtime.checkpoint.
Checkpoint
org.apache.flink.runtime.checkpoint.
CheckpointFailureManager.FailJobCallback
org.apache.flink.runtime.checkpoint.
CheckpointIDCounter
org.apache.flink.api.common.state.
CheckpointListener
org.apache.flink.runtime.checkpoint.
OperatorCoordinatorCheckpointContext
(also extends org.apache.flink.runtime.operators.coordination.
OperatorInfo
)
org.apache.flink.runtime.checkpoint.
CheckpointRecoveryFactory
org.apache.flink.runtime.checkpoint.
CheckpointScheduling
org.apache.flink.runtime.checkpoint.
CheckpointStoreUtil
org.apache.flink.runtime.checkpoint.
CompletedCheckpointStore
org.apache.flink.shaded.curator4.org.apache.curator.framework.state.ConnectionStateListener
org.apache.flink.runtime.checkpoint.
LastStateConnectionStateListener
org.apache.flink.runtime.checkpoint.
MasterTriggerRestoreHook
<T>
org.apache.flink.runtime.operators.coordination.
OperatorInfo
org.apache.flink.runtime.checkpoint.
OperatorCoordinatorCheckpointContext
(also extends org.apache.flink.api.common.state.
CheckpointListener
)
org.apache.flink.runtime.checkpoint.
OperatorStateRepartitioner
<T>
org.apache.flink.runtime.rpc.
RpcGateway
org.apache.flink.runtime.checkpoint.
CheckpointCoordinatorGateway
java.io.
Serializable
org.apache.flink.runtime.checkpoint.
MasterTriggerRestoreHook.Factory
Enum Hierarchy
java.lang.
Object
java.lang.
Enum
<E> (implements java.lang.
Comparable
<T>, java.io.
Serializable
)
org.apache.flink.runtime.checkpoint.
PendingCheckpoint.TaskAcknowledgeResult
org.apache.flink.runtime.checkpoint.
CheckpointOptions.AlignmentType
org.apache.flink.runtime.checkpoint.
CheckpointStatsStatus
org.apache.flink.runtime.checkpoint.
CheckpointType
org.apache.flink.runtime.checkpoint.
CheckpointType.PostCheckpointAction
org.apache.flink.runtime.checkpoint.
CheckpointRetentionPolicy
org.apache.flink.runtime.checkpoint.
CheckpointFailureReason
org.apache.flink.runtime.checkpoint.
ZooKeeperCheckpointStoreUtil
(implements org.apache.flink.runtime.checkpoint.
CheckpointStoreUtil
)
Skip navigation links
Overview
Package
Class
Use
Tree
Deprecated
Index
Help
Prev
Next
Frames
No Frames
All Classes
Copyright © 2014–2021
The Apache Software Foundation
. All rights reserved.