public class ProxyOperatorStateBackend extends Object implements org.apache.flink.runtime.state.OperatorStateBackend
OperatorStateBackend for the wrapped Operator.| 构造器和说明 |
|---|
ProxyOperatorStateBackend(org.apache.flink.runtime.state.OperatorStateBackend wrappedBackend,
StateNamePrefix stateNamePrefix) |
| 限定符和类型 | 方法和说明 |
|---|---|
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) |
<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) |
public ProxyOperatorStateBackend(org.apache.flink.runtime.state.OperatorStateBackend wrappedBackend,
StateNamePrefix stateNamePrefix)
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.OperatorStateStoreExceptionpublic <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.OperatorStateStoreExceptionpublic <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.OperatorStateStoreExceptionpublic Set<String> getRegisteredStateNames()
getRegisteredStateNames 在接口中 org.apache.flink.api.common.state.OperatorStateStorepublic Set<String> getRegisteredBroadcastStateNames()
getRegisteredBroadcastStateNames 在接口中 org.apache.flink.api.common.state.OperatorStateStorepublic void dispose()
dispose 在接口中 org.apache.flink.runtime.state.OperatorStateBackenddispose 在接口中 org.apache.flink.util.Disposablepublic void close()
throws IOException
close 在接口中 Closeableclose 在接口中 AutoCloseableIOException@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>>ExceptionCopyright © 2019–2022 The Apache Software Foundation. All rights reserved.