Package | Description |
---|---|
org.apache.flink.runtime.state | |
org.apache.flink.runtime.state.heap |
This package contains the classes for key/value state backends that store the state
on the JVM heap as objects.
|
Modifier and Type | Method and Description |
---|---|
<N,S extends org.apache.flink.api.common.state.State,T> |
KeyedStateBackend.applyToAllKeys(N namespace,
org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer,
org.apache.flink.api.common.state.StateDescriptor<S,T> stateDescriptor,
KeyedStateFunction<K,S> function)
Applies the provided
KeyedStateFunction to the state with the provided
StateDescriptor of all the currently active keys. |
<N,S extends org.apache.flink.api.common.state.State,T> |
AbstractKeyedStateBackend.applyToAllKeys(N namespace,
org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer,
org.apache.flink.api.common.state.StateDescriptor<S,T> stateDescriptor,
KeyedStateFunction<K,S> function) |
Modifier and Type | Method and Description |
---|---|
<N,S extends org.apache.flink.api.common.state.State,T> |
HeapKeyedStateBackend.applyToAllKeys(N namespace,
org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer,
org.apache.flink.api.common.state.StateDescriptor<S,T> stateDescriptor,
KeyedStateFunction<K,S> function) |
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.