@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(org.apache.flink.api.common.ExecutionConfig executionConfig,
org.apache.flink.core.fs.CloseableRegistry closeStreamOnCancelRegistry,
Map<String,PartitionableListState<?>> registeredOperatorStates,
Map<String,BackendWritableBroadcastState<?,?>> registeredBroadcastStates,
Map<String,PartitionableListState<?>> accessedStatesByName,
Map<String,BackendWritableBroadcastState<?,?>> accessedBroadcastStatesByName,
SnapshotStrategyRunner<OperatorStateHandle,?> snapshotStrategyRunner) |
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) |
Set<String> |
getRegisteredBroadcastStateNames() |
Set<String> |
getRegisteredStateNames() |
<S> org.apache.flink.api.common.state.ListState<S> |
getUnionListState(org.apache.flink.api.common.state.ListStateDescriptor<S> stateDescriptor) |
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(org.apache.flink.api.common.ExecutionConfig executionConfig, org.apache.flink.core.fs.CloseableRegistry closeStreamOnCancelRegistry, Map<String,PartitionableListState<?>> registeredOperatorStates, Map<String,BackendWritableBroadcastState<?,?>> registeredBroadcastStates, Map<String,PartitionableListState<?>> accessedStatesByName, Map<String,BackendWritableBroadcastState<?,?>> accessedBroadcastStatesByName, SnapshotStrategyRunner<OperatorStateHandle,?> snapshotStrategyRunner)
public org.apache.flink.api.common.ExecutionConfig getExecutionConfig()
public Set<String> getRegisteredStateNames()
getRegisteredStateNames
in interface org.apache.flink.api.common.state.OperatorStateStore
public Set<String> getRegisteredBroadcastStateNames()
getRegisteredBroadcastStateNames
in interface org.apache.flink.api.common.state.OperatorStateStore
public void close() throws IOException
close
in interface Closeable
close
in interface AutoCloseable
IOException
public void dispose()
dispose
in interface OperatorStateBackend
dispose
in interface org.apache.flink.util.Disposable
public <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.OperatorStateStore
org.apache.flink.util.StateMigrationException
public <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.OperatorStateStore
Exception
public <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.OperatorStateStore
Exception
@Nonnull public RunnableFuture<SnapshotResult<OperatorStateHandle>> snapshot(long checkpointId, long timestamp, @Nonnull CheckpointStreamFactory streamFactory, @Nonnull CheckpointOptions checkpointOptions) throws Exception
Snapshotable
CheckpointStreamFactory
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>>
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
.Exception
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.