F
- The type of the user function.KEY
- The key type.N
- The namespace type.OUT
- The output type.@Internal public abstract class StateReaderOperator<F extends Function,KEY,N,OUT> extends Object implements KeyContext, AutoCloseable, Serializable
Modifier and Type | Field and Description |
---|---|
protected F |
function |
protected TypeSerializer<N> |
namespaceSerializer |
Modifier | Constructor and Description |
---|---|
protected |
StateReaderOperator(F function,
TypeInformation<KEY> keyType,
TypeSerializer<N> namespaceSerializer) |
Modifier and Type | Method and Description |
---|---|
void |
close() |
Object |
getCurrentKey() |
ExecutionConfig |
getExecutionConfig() |
protected InternalTimerService<N> |
getInternalTimerService(String name) |
KeyedStateBackend<KEY> |
getKeyedStateBackend() |
abstract CloseableIterator<Tuple2<KEY,N>> |
getKeysAndNamespaces(SavepointRuntimeContext ctx) |
TypeInformation<KEY> |
getKeyType() |
void |
open() |
abstract void |
processElement(KEY key,
N namespace,
Collector<OUT> out) |
void |
setCurrentKey(Object key) |
void |
setup(ExecutionConfig executionConfig,
KeyedStateBackend<KEY> keyKeyedStateBackend,
InternalTimeServiceManager<KEY> timerServiceManager,
SavepointRuntimeContext ctx) |
protected final TypeSerializer<N> namespaceSerializer
protected StateReaderOperator(F function, TypeInformation<KEY> keyType, TypeSerializer<N> namespaceSerializer)
public abstract void processElement(KEY key, N namespace, Collector<OUT> out) throws Exception
Exception
public abstract CloseableIterator<Tuple2<KEY,N>> getKeysAndNamespaces(SavepointRuntimeContext ctx) throws Exception
Exception
public final void setup(ExecutionConfig executionConfig, KeyedStateBackend<KEY> keyKeyedStateBackend, InternalTimeServiceManager<KEY> timerServiceManager, SavepointRuntimeContext ctx)
protected final InternalTimerService<N> getInternalTimerService(String name)
public void close() throws Exception
close
in interface AutoCloseable
Exception
public final void setCurrentKey(Object key)
setCurrentKey
in interface KeyContext
public final Object getCurrentKey()
getCurrentKey
in interface KeyContext
public final KeyedStateBackend<KEY> getKeyedStateBackend()
public final TypeInformation<KEY> getKeyType()
public final ExecutionConfig getExecutionConfig()
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.