类 ProxyOperatorStateBackend
- java.lang.Object
-
- org.apache.flink.iteration.proxy.state.ProxyOperatorStateBackend
-
- 所有已实现的接口:
Closeable,AutoCloseable,org.apache.flink.api.common.state.OperatorStateStore,org.apache.flink.runtime.state.OperatorStateBackend,org.apache.flink.runtime.state.Snapshotable<org.apache.flink.runtime.state.SnapshotResult<org.apache.flink.runtime.state.OperatorStateHandle>>,org.apache.flink.util.Disposable
public class ProxyOperatorStateBackend extends Object implements org.apache.flink.runtime.state.OperatorStateBackend
ProxyOperatorStateBackendfor the wrapped Operator.
-
-
构造器概要
构造器 构造器 说明 ProxyOperatorStateBackend(org.apache.flink.runtime.state.OperatorStateBackend wrappedBackend, StateNamePrefix stateNamePrefix)
-
方法概要
所有方法 实例方法 具体方法 修饰符和类型 方法 说明 voidclose()voiddispose()<K,V>
org.apache.flink.api.common.state.BroadcastState<K,V>getBroadcastState(org.apache.flink.api.common.state.MapStateDescriptor<K,V> stateDescriptor)<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<org.apache.flink.runtime.state.SnapshotResult<org.apache.flink.runtime.state.OperatorStateHandle>>snapshot(long checkpointId, long timestamp, org.apache.flink.runtime.state.CheckpointStreamFactory streamFactory, org.apache.flink.runtime.checkpoint.CheckpointOptions checkpointOptions)
-
-
-
构造器详细资料
-
ProxyOperatorStateBackend
public ProxyOperatorStateBackend(org.apache.flink.runtime.state.OperatorStateBackend wrappedBackend, StateNamePrefix stateNamePrefix)
-
-
方法详细资料
-
getBroadcastState
public <K,V> org.apache.flink.api.common.state.BroadcastState<K,V> getBroadcastState(org.apache.flink.api.common.state.MapStateDescriptor<K,V> stateDescriptor) throws Exception- 指定者:
getBroadcastState在接口中org.apache.flink.api.common.state.OperatorStateStore- 抛出:
Exception
-
getListState
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
-
getUnionListState
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
-
getRegisteredStateNames
public Set<String> getRegisteredStateNames()
- 指定者:
getRegisteredStateNames在接口中org.apache.flink.api.common.state.OperatorStateStore
-
getRegisteredBroadcastStateNames
public Set<String> getRegisteredBroadcastStateNames()
- 指定者:
getRegisteredBroadcastStateNames在接口中org.apache.flink.api.common.state.OperatorStateStore
-
dispose
public void dispose()
- 指定者:
dispose在接口中org.apache.flink.util.Disposable- 指定者:
dispose在接口中org.apache.flink.runtime.state.OperatorStateBackend
-
close
public void close() throws IOException- 指定者:
close在接口中AutoCloseable- 指定者:
close在接口中Closeable- 抛出:
IOException
-
snapshot
@Nonnull public RunnableFuture<org.apache.flink.runtime.state.SnapshotResult<org.apache.flink.runtime.state.OperatorStateHandle>> snapshot(long checkpointId, long timestamp, @Nonnull org.apache.flink.runtime.state.CheckpointStreamFactory streamFactory, @Nonnull org.apache.flink.runtime.checkpoint.CheckpointOptions checkpointOptions) throws Exception
- 指定者:
snapshot在接口中org.apache.flink.runtime.state.Snapshotable<org.apache.flink.runtime.state.SnapshotResult<org.apache.flink.runtime.state.OperatorStateHandle>>- 抛出:
Exception
-
-