@Internal public class DefaultOperatorStateBackend extends Object implements OperatorStateBackend
限定符和类型 | 字段和说明 |
---|---|
static String |
DEFAULT_OPERATOR_STATE_NAME
The default namespace for state in cases where no state name is provided
|
构造器和说明 |
---|
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,
AbstractSnapshotStrategy<OperatorStateHandle> snapshotStrategy) |
限定符和类型 | 方法和说明 |
---|---|
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)
已过时。
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)
已过时。
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) |
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 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, AbstractSnapshotStrategy<OperatorStateHandle> snapshotStrategy)
public org.apache.flink.api.common.ExecutionConfig getExecutionConfig()
public Set<String> getRegisteredStateNames()
getRegisteredStateNames
在接口中 org.apache.flink.api.common.state.OperatorStateStore
public Set<String> getRegisteredBroadcastStateNames()
getRegisteredBroadcastStateNames
在接口中 org.apache.flink.api.common.state.OperatorStateStore
public void close() throws IOException
close
在接口中 Closeable
close
在接口中 AutoCloseable
IOException
public void dispose()
dispose
在接口中 OperatorStateBackend
dispose
在接口中 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
在接口中 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
在接口中 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
在接口中 org.apache.flink.api.common.state.OperatorStateStore
Exception
@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
在接口中 org.apache.flink.api.common.state.OperatorStateStore
Exception
@Deprecated public <T extends Serializable> org.apache.flink.api.common.state.ListState<T> getSerializableListState(String stateName) throws Exception
getListState(ListStateDescriptor)
instead.getSerializableListState
在接口中 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
SnapshotStrategy
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
在接口中 SnapshotStrategy<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–2020 The Apache Software Foundation. All rights reserved.