Class KeyedStateReaderFunction<K,OUT>
- java.lang.Object
-
- org.apache.flink.api.common.functions.AbstractRichFunction
-
- org.apache.flink.state.api.functions.KeyedStateReaderFunction<K,OUT>
-
- Type Parameters:
K
- Type of the keysOUT
- Type of the output elements.
- All Implemented Interfaces:
Serializable
,Function
,RichFunction
@PublicEvolving public abstract class KeyedStateReaderFunction<K,OUT> extends AbstractRichFunction
A function that processes keys from a restored operatorFor every key
readKey(Object, Context, Collector)
is invoked. This can produce zero or more elements as output.NOTE: State descriptors must be eagerly registered in
open(OpenContext)
. Any attempt to dynamically register states inside ofreadKey
will result in aRuntimeException
.NOTE: A
KeyedStateReaderFunction
is always aRichFunction
. Therefore, access to theRuntimeContext
is always available and setup and teardown methods can be implemented. SeeRichFunction.open(OpenContext)
andRichFunction.close()
.- See Also:
- Serialized Form
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static interface
KeyedStateReaderFunction.Context
Context thatKeyedStateReaderFunction
's can use for getting additional data about an input record.
-
Constructor Summary
Constructors Constructor Description KeyedStateReaderFunction()
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description abstract void
readKey(K key, KeyedStateReaderFunction.Context ctx, Collector<OUT> out)
Process one key from the restored state backend.-
Methods inherited from class org.apache.flink.api.common.functions.AbstractRichFunction
close, getIterationRuntimeContext, getRuntimeContext, open, setRuntimeContext
-
-
-
-
Method Detail
-
readKey
public abstract void readKey(K key, KeyedStateReaderFunction.Context ctx, Collector<OUT> out) throws Exception
Process one key from the restored state backend.This function can read partitioned state from the restored state backend and output zero or more elements using the
Collector
parameter.- Parameters:
key
- The input value.out
- The collector for returning result values.- Throws:
Exception
- This method may throw exceptions. Throwing an exception will cause the operation to fail and may trigger recovery.
-
-