类 ProxyKeyedStateBackend<K>
- java.lang.Object
-
- org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend<K>
-
- 所有已实现的接口:
Closeable,AutoCloseable,org.apache.flink.runtime.state.CheckpointableKeyedStateBackend<K>,org.apache.flink.runtime.state.KeyedStateBackend<K>,org.apache.flink.runtime.state.KeyedStateFactory,org.apache.flink.runtime.state.PriorityQueueSetFactory,org.apache.flink.runtime.state.Snapshotable<org.apache.flink.runtime.state.SnapshotResult<org.apache.flink.runtime.state.KeyedStateHandle>>,org.apache.flink.util.Disposable
public class ProxyKeyedStateBackend<K> extends Object implements org.apache.flink.runtime.state.CheckpointableKeyedStateBackend<K>
ProxyKeyedStateBackendfor the wrapped operators.
-
-
嵌套类概要
-
从接口继承的嵌套类/接口 org.apache.flink.runtime.state.KeyedStateBackend
org.apache.flink.runtime.state.KeyedStateBackend.KeySelectionListener<K extends Object>
-
-
构造器概要
构造器 构造器 说明 ProxyKeyedStateBackend(org.apache.flink.runtime.state.CheckpointableKeyedStateBackend<K> wrappedBackend, StateNamePrefix stateNamePrefix)
-
方法概要
所有方法 实例方法 具体方法 修饰符和类型 方法 说明 <N,S extends org.apache.flink.api.common.state.State,T>
voidapplyToAllKeys(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)voidclose()<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(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>
IScreateInternalState(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>
org.apache.flink.api.common.state.StateDescriptor<S,T>createNewDescriptor(org.apache.flink.api.common.state.StateDescriptor<S,T> descriptor)booleanderegisterKeySelectionListener(org.apache.flink.runtime.state.KeyedStateBackend.KeySelectionListener<K> listener)voiddispose()KgetCurrentKey()org.apache.flink.runtime.state.KeyGroupRangegetKeyGroupRange()<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>
SgetOrCreateKeyedState(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>
SgetPartitionedState(N namespace, org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer, org.apache.flink.api.common.state.StateDescriptor<S,?> stateDescriptor)voidregisterKeySelectionListener(org.apache.flink.runtime.state.KeyedStateBackend.KeySelectionListener<K> listener)org.apache.flink.runtime.state.SavepointResources<K>savepoint()voidsetCurrentKey(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)-
从类继承的方法 java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
-
-
-
构造器详细资料
-
ProxyKeyedStateBackend
public ProxyKeyedStateBackend(org.apache.flink.runtime.state.CheckpointableKeyedStateBackend<K> wrappedBackend, StateNamePrefix stateNamePrefix)
-
-
方法详细资料
-
setCurrentKey
public void setCurrentKey(K newKey)
- 指定者:
setCurrentKey在接口中org.apache.flink.runtime.state.KeyedStateBackend<K>
-
getCurrentKey
public K getCurrentKey()
- 指定者:
getCurrentKey在接口中org.apache.flink.runtime.state.KeyedStateBackend<K>
-
getKeySerializer
public org.apache.flink.api.common.typeutils.TypeSerializer<K> getKeySerializer()
- 指定者:
getKeySerializer在接口中org.apache.flink.runtime.state.KeyedStateBackend<K>
-
applyToAllKeys
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
-
getKeys
public <N> java.util.stream.Stream<K> getKeys(String state, N namespace)
- 指定者:
getKeys在接口中org.apache.flink.runtime.state.KeyedStateBackend<K>
-
getKeysAndNamespaces
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>
-
getOrCreateKeyedState
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
-
getPartitionedState
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
-
registerKeySelectionListener
public void registerKeySelectionListener(org.apache.flink.runtime.state.KeyedStateBackend.KeySelectionListener<K> listener)
- 指定者:
registerKeySelectionListener在接口中org.apache.flink.runtime.state.KeyedStateBackend<K>
-
deregisterKeySelectionListener
public boolean deregisterKeySelectionListener(org.apache.flink.runtime.state.KeyedStateBackend.KeySelectionListener<K> listener)
- 指定者:
deregisterKeySelectionListener在接口中org.apache.flink.runtime.state.KeyedStateBackend<K>
-
createInternalState
@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.KeyedStateFactory- 抛出:
Exception
-
createNewDescriptor
protected <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)
-
getKeyGroupRange
public org.apache.flink.runtime.state.KeyGroupRange getKeyGroupRange()
- 指定者:
getKeyGroupRange在接口中org.apache.flink.runtime.state.CheckpointableKeyedStateBackend<K>
-
savepoint
@Nonnull public org.apache.flink.runtime.state.SavepointResources<K> savepoint() throws Exception
-
dispose
public void dispose()
- 指定者:
dispose在接口中org.apache.flink.util.Disposable- 指定者:
dispose在接口中org.apache.flink.runtime.state.KeyedStateBackend<K>
-
close
public void close() throws IOException- 指定者:
close在接口中AutoCloseable- 指定者:
close在接口中Closeable- 抛出:
IOException
-
create
@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
-
snapshot
@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
-
-