Interface | Description |
---|---|
CheckpointListener |
This interface must be implemented by functions/operations that want to receive
a commit notification once a checkpoint has been completely acknowledged by all
participants.
|
KvState<K,N,S extends State,SD extends StateDescriptor<S,?>,Backend extends AbstractStateBackend> |
Key/Value state implementation for user-defined state.
|
KvStateSnapshot<K,N,S extends State,SD extends StateDescriptor<S,?>,Backend extends AbstractStateBackend> |
This class represents a snapshot of the
KvState , taken for a checkpoint. |
StateBackendFactory<T extends AbstractStateBackend> |
A factory to create a specific state backend.
|
StateHandle<T> |
StateHandle is a general handle interface meant to abstract operator state fetching.
|
StreamStateHandle |
A state handle that produces an input stream when resolved.
|
Class | Description |
---|---|
AbstractHeapState<K,N,SV,S extends State,SD extends StateDescriptor<S,?>,Backend extends AbstractStateBackend> |
Base class for partitioned
ListState implementations that are backed by a regular
heap hash map. |
AbstractStateBackend |
A state backend defines how state is stored and snapshotted during checkpoints.
|
AbstractStateBackend.CheckpointStateOutputStream |
A dedicated output stream that produces a
StreamStateHandle when closed. |
AbstractStateBackend.CheckpointStateOutputView |
A dedicated DataOutputView stream that produces a
StateHandle<DataInputView> when closed. |
ArrayListSerializer<T> | |
AsynchronousKvStateSnapshot<K,N,S extends State,SD extends StateDescriptor<S,?>,Backend extends AbstractStateBackend> |
KvStateSnapshot that asynchronously materializes the state that it represents. |
AsynchronousStateHandle<T> |
StateHandle that can asynchronously materialize the state that it represents. |
GenericFoldingState<K,N,T,ACC,Backend extends AbstractStateBackend,W extends ValueState<ACC> & KvState<K,N,ValueState<ACC>,ValueStateDescriptor<ACC>,Backend>> |
Generic implementation of
FoldingState based on a wrapped ValueState . |
GenericListState<K,N,T,Backend extends AbstractStateBackend,W extends ValueState<ArrayList<T>> & KvState<K,N,ValueState<ArrayList<T>>,ValueStateDescriptor<ArrayList<T>>,Backend>> |
Generic implementation of
ListState based on a wrapped ValueState . |
GenericReducingState<K,N,T,Backend extends AbstractStateBackend,W extends ValueState<T> & KvState<K,N,ValueState<T>,ValueStateDescriptor<T>,Backend>> |
Generic implementation of
ReducingState based on a wrapped ValueState . |
LocalStateHandle<T extends Serializable> |
A StateHandle that includes the operator states directly.
|
SerializedCheckpointData |
This class represents serialized checkpoint data for a collection of elements.
|
StateUtils |
A collection of utility methods for dealing with operator state.
|
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.