Modifier and Type | Class and Description |
---|---|
class |
StateObjectCollection<T extends StateObject>
This class represents a generic collection for
StateObject s. |
Modifier and Type | Class and Description |
---|---|
class |
OperatorState
Simple container class which contains the raw/managed operator state and key-group state handles from all sub
tasks of an operator and therefore represents the complete state of a logical operator.
|
class |
OperatorSubtaskState
This class encapsulates the state for one parallel instance of an operator.
|
class |
StateObjectCollection<T extends StateObject>
This class represents a generic collection for
StateObject s. |
class |
SubtaskState
Container for the chained state of one parallel subtask of an operator/task.
|
class |
TaskState
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
class |
TaskStateSnapshot
This class encapsulates state handles to the snapshots of all operator instances executed within one task.
|
Modifier and Type | Method and Description |
---|---|
static <T extends StateObject> |
StateObjectCollection.empty() |
protected <T extends StateObject> |
PrioritizedOperatorSubtaskState.Builder.resolvePrioritizedAlternatives(StateObjectCollection<T> jobManagerState,
List<StateObjectCollection<T>> alternativesByPriority,
java.util.function.BiFunction<T,T,Boolean> approveFun)
This helper method resolves the dependencies between the ground truth of the operator state obtained from the
job manager and potential alternatives for recovery, e.g.
|
static <T extends StateObject> |
StateObjectCollection.singleton(T stateObject) |
Modifier and Type | Class and Description |
---|---|
class |
ChainedStateHandle<T extends StateObject>
Handle to state handles for the operators in an operator chain.
|
interface |
Snapshotable<S extends StateObject,R>
Interface for operators that can perform snapshots of their state.
|
class |
SnapshotResult<T extends StateObject>
This class contains the combined results from the snapshot of a state backend:
A state object representing the state that will be reported to the Job Manager to acknowledge the checkpoint.
A state object that represents the state for the
TaskLocalStateStoreImpl .
Both state objects are optional and can be null, e.g. |
interface |
SnapshotStrategy<S extends StateObject>
Interface for different snapshot approaches in state backends.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CompositeStateHandle
Base of all snapshots that are taken by
StateBackend s and some other
components in tasks. |
interface |
KeyedStateHandle
Base for the handles of the checkpointed states in keyed streams.
|
interface |
OperatorStateHandle
Interface of a state handle for operator state.
|
interface |
RetrievableStateHandle<T extends Serializable>
Handle to state that can be read back again via
RetrievableStateHandle.retrieveState() . |
interface |
StreamStateHandle
A
StateObject that represents state that was written to a stream. |
Modifier and Type | Class and Description |
---|---|
class |
ChainedStateHandle<T extends StateObject>
Handle to state handles for the operators in an operator chain.
|
class |
DirectoryKeyedStateHandle
This class is a keyed state handle based on a directory.
|
class |
DirectoryStateHandle
This state handle represents a directory.
|
class |
IncrementalKeyedStateHandle
The handle to states of an incremental snapshot.
|
class |
IncrementalLocalKeyedStateHandle
State handle for local copies of
IncrementalKeyedStateHandle . |
class |
KeyGroupsStateHandle
A handle to the partitioned stream operator state after it has been checkpointed.
|
class |
OperatorStreamStateHandle
State handle for partitionable operator state.
|
class |
PlaceholderStreamStateHandle
A placeholder state handle for shared state that will replaced by an original that was
created in a previous checkpoint.
|
class |
RetrievableStreamStateHandle<T extends Serializable>
Wrapper around a
StreamStateHandle to make the referenced state object retrievable trough a simple get call. |
class |
SnapshotResult<T extends StateObject>
This class contains the combined results from the snapshot of a state backend:
A state object representing the state that will be reported to the Job Manager to acknowledge the checkpoint.
A state object that represents the state for the
TaskLocalStateStoreImpl .
Both state objects are optional and can be null, e.g. |
Modifier and Type | Method and Description |
---|---|
static <T extends StateObject> |
SnapshotResult.empty() |
static <T extends StateObject> |
SnapshotResult.of(T jobManagerState) |
static <T extends StateObject> |
SnapshotResult.withLocalState(T jobManagerState,
T localState) |
static <T extends StateObject> |
ChainedStateHandle.wrapSingleHandle(T stateHandleToWrap) |
Modifier and Type | Method and Description |
---|---|
static long |
StateUtil.getStateSize(StateObject handle)
Returns the size of a state object
|
Modifier and Type | Method and Description |
---|---|
static void |
StateUtil.bestEffortDiscardAllStateObjects(Iterable<? extends StateObject> handlesToDiscard)
Iterates through the passed state handles and calls discardState() on each handle that is not null.
|
static void |
StateUtil.discardStateFuture(RunnableFuture<? extends StateObject> stateFuture)
Discards the given state future by first trying to cancel it.
|
Modifier and Type | Class and Description |
---|---|
class |
FileStateHandle
StreamStateHandle for state that was written to a file stream. |
Modifier and Type | Class and Description |
---|---|
class |
ByteStreamStateHandle
A state handle that contains stream state in a byte array.
|
Modifier and Type | Class and Description |
---|---|
class |
BackendRestorerProcedure<T extends Closeable & Disposable & Snapshotable<?,Collection<S>>,S extends StateObject>
This class implements the logic that creates (and potentially restores) a state backend.
|
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.