public class ProxyKeyedStateBackend<K> extends Object implements org.apache.flink.runtime.state.CheckpointableKeyedStateBackend<K>
KeyedStateBackend for the wrapped operators.| 构造器和说明 | 
|---|
ProxyKeyedStateBackend(org.apache.flink.runtime.state.CheckpointableKeyedStateBackend<K> wrappedBackend,
                      StateNamePrefix stateNamePrefix)  | 
| 限定符和类型 | 方法和说明 | 
|---|---|
<N,S extends org.apache.flink.api.common.state.State,T> | 
applyToAllKeys(N namespace,
              org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer,
              org.apache.flink.api.common.state.StateDescriptor<S,T> stateDescriptor,
              org.apache.flink.runtime.state.KeyedStateFunction<K,S> function)  | 
void | 
close()  | 
<T extends org.apache.flink.runtime.state.heap.HeapPriorityQueueElement & org.apache.flink.runtime.state.PriorityComparable<? super T> & org.apache.flink.runtime.state.Keyed<?>> | 
create(String stateName,
      org.apache.flink.api.common.typeutils.TypeSerializer<T> byteOrderedElementSerializer)  | 
<N,SV,SEV,S extends org.apache.flink.api.common.state.State,IS extends S> | 
createInternalState(org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer,
                   org.apache.flink.api.common.state.StateDescriptor<S,SV> stateDesc,
                   org.apache.flink.runtime.state.StateSnapshotTransformer.StateSnapshotTransformFactory<SEV> snapshotTransformFactory)  | 
protected <S extends org.apache.flink.api.common.state.State,T> | 
createNewDescriptor(org.apache.flink.api.common.state.StateDescriptor<S,T> descriptor)  | 
boolean | 
deregisterKeySelectionListener(org.apache.flink.runtime.state.KeyedStateBackend.KeySelectionListener<K> listener)  | 
void | 
dispose()  | 
K | 
getCurrentKey()  | 
org.apache.flink.runtime.state.KeyGroupRange | 
getKeyGroupRange()  | 
<N> java.util.stream.Stream<K> | 
getKeys(String state,
       N namespace)  | 
<N> java.util.stream.Stream<org.apache.flink.api.java.tuple.Tuple2<K,N>> | 
getKeysAndNamespaces(String state)  | 
org.apache.flink.api.common.typeutils.TypeSerializer<K> | 
getKeySerializer()  | 
<N,S extends org.apache.flink.api.common.state.State,T> | 
getOrCreateKeyedState(org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer,
                     org.apache.flink.api.common.state.StateDescriptor<S,T> stateDescriptor)  | 
<N,S extends org.apache.flink.api.common.state.State> | 
getPartitionedState(N namespace,
                   org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer,
                   org.apache.flink.api.common.state.StateDescriptor<S,?> stateDescriptor)  | 
void | 
registerKeySelectionListener(org.apache.flink.runtime.state.KeyedStateBackend.KeySelectionListener<K> listener)  | 
org.apache.flink.runtime.state.SavepointResources<K> | 
savepoint()  | 
void | 
setCurrentKey(K newKey)  | 
RunnableFuture<org.apache.flink.runtime.state.SnapshotResult<org.apache.flink.runtime.state.KeyedStateHandle>> | 
snapshot(long checkpointId,
        long timestamp,
        org.apache.flink.runtime.state.CheckpointStreamFactory streamFactory,
        org.apache.flink.runtime.checkpoint.CheckpointOptions checkpointOptions)  | 
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitpublic ProxyKeyedStateBackend(org.apache.flink.runtime.state.CheckpointableKeyedStateBackend<K> wrappedBackend, StateNamePrefix stateNamePrefix)
public void setCurrentKey(K newKey)
setCurrentKey 在接口中 org.apache.flink.runtime.state.KeyedStateBackend<K>public K getCurrentKey()
getCurrentKey 在接口中 org.apache.flink.runtime.state.KeyedStateBackend<K>public org.apache.flink.api.common.typeutils.TypeSerializer<K> getKeySerializer()
getKeySerializer 在接口中 org.apache.flink.runtime.state.KeyedStateBackend<K>public <N,S extends org.apache.flink.api.common.state.State,T> void applyToAllKeys(N namespace,
                                                                                   org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer,
                                                                                   org.apache.flink.api.common.state.StateDescriptor<S,T> stateDescriptor,
                                                                                   org.apache.flink.runtime.state.KeyedStateFunction<K,S> function)
                                                                            throws Exception
public <N> java.util.stream.Stream<K> getKeys(String state, N namespace)
getKeys 在接口中 org.apache.flink.runtime.state.KeyedStateBackend<K>public <N> java.util.stream.Stream<org.apache.flink.api.java.tuple.Tuple2<K,N>> getKeysAndNamespaces(String state)
getKeysAndNamespaces 在接口中 org.apache.flink.runtime.state.KeyedStateBackend<K>public <N,S extends org.apache.flink.api.common.state.State,T> S getOrCreateKeyedState(org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer,
                                                                                       org.apache.flink.api.common.state.StateDescriptor<S,T> stateDescriptor)
                                                                                throws Exception
public <N,S extends org.apache.flink.api.common.state.State> S getPartitionedState(N namespace,
                                                                                   org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer,
                                                                                   org.apache.flink.api.common.state.StateDescriptor<S,?> stateDescriptor)
                                                                            throws Exception
public void registerKeySelectionListener(org.apache.flink.runtime.state.KeyedStateBackend.KeySelectionListener<K> listener)
registerKeySelectionListener 在接口中 org.apache.flink.runtime.state.KeyedStateBackend<K>public boolean deregisterKeySelectionListener(org.apache.flink.runtime.state.KeyedStateBackend.KeySelectionListener<K> listener)
deregisterKeySelectionListener 在接口中 org.apache.flink.runtime.state.KeyedStateBackend<K>@Nonnull public <N,SV,SEV,S extends org.apache.flink.api.common.state.State,IS extends S> IS createInternalState(@Nonnull org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer, @Nonnull org.apache.flink.api.common.state.StateDescriptor<S,SV> stateDesc, @Nonnull org.apache.flink.runtime.state.StateSnapshotTransformer.StateSnapshotTransformFactory<SEV> snapshotTransformFactory) throws Exception
createInternalState 在接口中 org.apache.flink.runtime.state.KeyedStateFactoryExceptionprotected <S extends org.apache.flink.api.common.state.State,T> org.apache.flink.api.common.state.StateDescriptor<S,T> createNewDescriptor(org.apache.flink.api.common.state.StateDescriptor<S,T> descriptor)
public org.apache.flink.runtime.state.KeyGroupRange getKeyGroupRange()
getKeyGroupRange 在接口中 org.apache.flink.runtime.state.CheckpointableKeyedStateBackend<K>@Nonnull public org.apache.flink.runtime.state.SavepointResources<K> savepoint() throws Exception
public void dispose()
dispose 在接口中 org.apache.flink.runtime.state.KeyedStateBackend<K>dispose 在接口中 org.apache.flink.util.Disposablepublic void close()
           throws IOException
close 在接口中 Closeableclose 在接口中 AutoCloseableIOException@Nonnull public <T extends org.apache.flink.runtime.state.heap.HeapPriorityQueueElement & org.apache.flink.runtime.state.PriorityComparable<? super T> & org.apache.flink.runtime.state.Keyed<?>> org.apache.flink.runtime.state.KeyGroupedInternalPriorityQueue<T> create(@Nonnull String stateName, @Nonnull org.apache.flink.api.common.typeutils.TypeSerializer<T> byteOrderedElementSerializer)
create 在接口中 org.apache.flink.runtime.state.PriorityQueueSetFactory@Nonnull public RunnableFuture<org.apache.flink.runtime.state.SnapshotResult<org.apache.flink.runtime.state.KeyedStateHandle>> 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.KeyedStateHandle>>ExceptionCopyright © 2019–2022 The Apache Software Foundation. All rights reserved.