IN
- Input type@Internal public class QueryableValueStateOperator<IN> extends AbstractStreamOperator<IN>
Modifier and Type | Field and Description |
---|---|
protected String |
registrationName
Name under which the queryable state is registered.
|
protected S |
state
The state instance created on open.
|
protected StateDescriptor<? extends S,?> |
stateDescriptor
State descriptor for the queryable state instance.
|
chainingStrategy, config, latencyStats, LOG, metrics, output, processingTimeService
Constructor and Description |
---|
QueryableValueStateOperator(String registrationName,
StateDescriptor<ValueState<IN>,IN> stateDescriptor) |
Modifier and Type | Method and Description |
---|---|
void |
open()
This method is called immediately before any elements are processed, it should contain the
operator's initialization logic, e.g.
|
void |
processElement(StreamRecord<IN> element)
Processes one element that arrived at this operator.
|
close, dispose, getChainingStrategy, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getTimeServiceManager, getUserCodeClassloader, initializeState, initializeState, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, numEventTimeTimers, numProcessingTimeTimers, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processWatermark, processWatermark1, processWatermark2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setProcessingTimeService, setup, snapshotState, snapshotState
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
processLatencyMarker, processWatermark
close, dispose, getMetricGroup, getOperatorID, initializeState, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
notifyCheckpointAborted, notifyCheckpointComplete
getCurrentKey, setCurrentKey
protected final StateDescriptor<? extends S extends State,?> stateDescriptor
protected final String registrationName
protected transient S extends State state
public QueryableValueStateOperator(String registrationName, StateDescriptor<ValueState<IN>,IN> stateDescriptor)
public void processElement(StreamRecord<IN> element) throws Exception
OneInputStreamOperator
Exception
public void open() throws Exception
AbstractStreamOperator
The default implementation does nothing.
open
in interface StreamOperator<IN>
open
in class AbstractStreamOperator<IN>
Exception
- An exception in this method causes the operator to fail.Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.