类 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
    Proxy OperatorStateBackend for the wrapped Operator.
    • 构造器详细资料

      • 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
      • 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