Uses of Interface
org.apache.flink.runtime.state.RetrievableStateHandle
-
-
Uses of RetrievableStateHandle in org.apache.flink.runtime.persistence
Methods in org.apache.flink.runtime.persistence that return RetrievableStateHandle Modifier and Type Method Description RetrievableStateHandle<T>StateHandleStore. addAndLock(String name, T state)Persist the state to distributed storage(e.g.RetrievableStateHandle<T>StateHandleStore. getAndLock(String name)Gets theRetrievableStateHandlestored with the given name.RetrievableStateHandle<T>RetrievableStateStorageHelper. store(T state)Stores the given state and returns a state handle to it.Methods in org.apache.flink.runtime.persistence that return types with arguments of type RetrievableStateHandle Modifier and Type Method Description List<org.apache.flink.api.java.tuple.Tuple2<RetrievableStateHandle<T>,String>>StateHandleStore. getAllAndLock()Gets all available state handles from the storage. -
Uses of RetrievableStateHandle in org.apache.flink.runtime.persistence.filesystem
Methods in org.apache.flink.runtime.persistence.filesystem that return RetrievableStateHandle Modifier and Type Method Description RetrievableStateHandle<T>FileSystemStateStorageHelper. store(T state) -
Uses of RetrievableStateHandle in org.apache.flink.runtime.state
Classes in org.apache.flink.runtime.state that implement RetrievableStateHandle Modifier and Type Class Description classRetrievableStreamStateHandle<T extends Serializable>Wrapper around aStreamStateHandleto make the referenced state object retrievable trough a simple get call. -
Uses of RetrievableStateHandle in org.apache.flink.runtime.zookeeper
Methods in org.apache.flink.runtime.zookeeper that return RetrievableStateHandle Modifier and Type Method Description RetrievableStateHandle<T>ZooKeeperStateHandleStore. addAndLock(String pathInZooKeeper, T state)Creates a state handle, stores it in ZooKeeper and locks it.RetrievableStateHandle<T>ZooKeeperStateHandleStore. getAndLock(String pathInZooKeeper)Gets theRetrievableStateHandlestored in the given ZooKeeper node and locks it.Methods in org.apache.flink.runtime.zookeeper that return types with arguments of type RetrievableStateHandle Modifier and Type Method Description List<org.apache.flink.api.java.tuple.Tuple2<RetrievableStateHandle<T>,String>>ZooKeeperStateHandleStore. getAllAndLock()Gets all available state handles from ZooKeeper and locks the respective state nodes.
-