@Internal public class DefaultOperatorStateBackend extends Object implements OperatorStateBackend
| Modifier and Type | Field and Description |
|---|---|
static String |
DEFAULT_OPERATOR_STATE_NAME
The default namespace for state in cases where no state name is provided
|
| Constructor and Description |
|---|
DefaultOperatorStateBackend(ClassLoader userClassLoader,
org.apache.flink.api.common.ExecutionConfig executionConfig,
boolean asynchronousSnapshots) |
| Modifier and Type | Method and Description |
|---|---|
void |
close() |
void |
dispose() |
<K,V> org.apache.flink.api.common.state.BroadcastState<K,V> |
getBroadcastState(org.apache.flink.api.common.state.MapStateDescriptor<K,V> stateDescriptor) |
org.apache.flink.api.common.ExecutionConfig |
getExecutionConfig() |
<S> org.apache.flink.api.common.state.ListState<S> |
getListState(org.apache.flink.api.common.state.ListStateDescriptor<S> stateDescriptor) |
<S> org.apache.flink.api.common.state.ListState<S> |
getOperatorState(org.apache.flink.api.common.state.ListStateDescriptor<S> stateDescriptor)
Deprecated.
This was deprecated as part of a refinement to the function names.
Please use
getListState(ListStateDescriptor) instead. |
Set<String> |
getRegisteredBroadcastStateNames() |
Set<String> |
getRegisteredStateNames() |
<T extends Serializable> |
getSerializableListState(String stateName)
Deprecated.
Using Java serialization for persisting state is not encouraged.
Please use
getListState(ListStateDescriptor) instead. |
<S> org.apache.flink.api.common.state.ListState<S> |
getUnionListState(org.apache.flink.api.common.state.ListStateDescriptor<S> stateDescriptor) |
void |
restore(Collection<OperatorStateHandle> restoreSnapshots)
Restores state that was previously snapshotted from the provided parameters.
|
RunnableFuture<SnapshotResult<OperatorStateHandle>> |
snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions)
Operation that writes a snapshot into a stream that is provided by the given
CheckpointStreamFactory and
returns a @RunnableFuture that gives a state handle to the snapshot. |
public static final String DEFAULT_OPERATOR_STATE_NAME
public DefaultOperatorStateBackend(ClassLoader userClassLoader, org.apache.flink.api.common.ExecutionConfig executionConfig, boolean asynchronousSnapshots)
public org.apache.flink.api.common.ExecutionConfig getExecutionConfig()
public Set<String> getRegisteredStateNames()
getRegisteredStateNames in interface org.apache.flink.api.common.state.OperatorStateStorepublic Set<String> getRegisteredBroadcastStateNames()
getRegisteredBroadcastStateNames in interface org.apache.flink.api.common.state.OperatorStateStorepublic void close()
throws IOException
close in interface Closeableclose in interface AutoCloseableIOExceptionpublic void dispose()
dispose in interface OperatorStateBackenddispose in interface org.apache.flink.util.Disposablepublic <K,V> org.apache.flink.api.common.state.BroadcastState<K,V> getBroadcastState(org.apache.flink.api.common.state.MapStateDescriptor<K,V> stateDescriptor)
throws org.apache.flink.util.StateMigrationException
getBroadcastState in interface org.apache.flink.api.common.state.OperatorStateStoreorg.apache.flink.util.StateMigrationExceptionpublic <S> org.apache.flink.api.common.state.ListState<S> getListState(org.apache.flink.api.common.state.ListStateDescriptor<S> stateDescriptor)
throws Exception
getListState in interface org.apache.flink.api.common.state.OperatorStateStoreExceptionpublic <S> org.apache.flink.api.common.state.ListState<S> getUnionListState(org.apache.flink.api.common.state.ListStateDescriptor<S> stateDescriptor)
throws Exception
getUnionListState in interface org.apache.flink.api.common.state.OperatorStateStoreException@Deprecated public <S> org.apache.flink.api.common.state.ListState<S> getOperatorState(org.apache.flink.api.common.state.ListStateDescriptor<S> stateDescriptor) throws Exception
getListState(ListStateDescriptor) instead.getOperatorState in interface org.apache.flink.api.common.state.OperatorStateStoreException@Deprecated public <T extends Serializable> org.apache.flink.api.common.state.ListState<T> getSerializableListState(String stateName) throws Exception
getListState(ListStateDescriptor) instead.getSerializableListState in interface org.apache.flink.api.common.state.OperatorStateStoreExceptionpublic RunnableFuture<SnapshotResult<OperatorStateHandle>> snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions) throws Exception
SnapshotableCheckpointStreamFactory and
returns a @RunnableFuture that gives a state handle to the snapshot. It is up to the implementation if
the operation is performed synchronous or asynchronous. In the later case, the returned Runnable must be executed
first before obtaining the handle.snapshot in interface Snapshotable<SnapshotResult<OperatorStateHandle>,Collection<OperatorStateHandle>>checkpointId - The ID of the checkpoint.timestamp - The timestamp of the checkpoint.streamFactory - The factory that we can use for writing our state to streams.checkpointOptions - Options for how to perform this checkpoint.StateObject.Exceptionpublic void restore(Collection<OperatorStateHandle> restoreSnapshots) throws Exception
Snapshotablerestore in interface Snapshotable<SnapshotResult<OperatorStateHandle>,Collection<OperatorStateHandle>>restoreSnapshots - the old state to restore.ExceptionCopyright © 2014–2018 The Apache Software Foundation. All rights reserved.