public class OneInput extends InputBase implements AsyncStateProcessing
Constructor and Description |
---|
OneInput(OneInputStreamOperator<RowData,RowData> operator) |
Modifier and Type | Method and Description |
---|---|
<T> ThrowingConsumer<StreamRecord<T>,Exception> |
getRecordProcessor(int inputId)
Get the record processor that could process record from input, which is the only entry for
async processing.
|
boolean |
isAsyncStateProcessingEnabled()
Get if the async state processing is enabled for this input/operator.
|
void |
processElement(StreamRecord<RowData> element)
Processes one element that arrived on this input of the
MultipleInputStreamOperator . |
void |
processLatencyMarker(LatencyMarker latencyMarker)
Processes a
LatencyMarker that arrived on the first input of this two-input operator. |
void |
processWatermark(Watermark mark)
Processes a
Watermark that arrived on the first input of this two-input operator. |
void |
processWatermarkStatus(WatermarkStatus watermarkStatus)
Processes a
WatermarkStatus that arrived on this input of the MultipleInputStreamOperator . |
hasKeyContext, setKeyContextElement
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
makeRecordProcessor
processRecordAttributes
hasKeyContext1, hasKeyContext2
public OneInput(OneInputStreamOperator<RowData,RowData> operator)
public void processElement(StreamRecord<RowData> element) throws Exception
Input
MultipleInputStreamOperator
.
This method is guaranteed to not be called concurrently with other methods of the operator.processElement
in interface Input<RowData>
Exception
public void processWatermark(Watermark mark) throws Exception
Input
Watermark
that arrived on the first input of this two-input operator.
This method is guaranteed to not be called concurrently with other methods of the operator.processWatermark
in interface Input<RowData>
Exception
Watermark
public void processLatencyMarker(LatencyMarker latencyMarker) throws Exception
Input
LatencyMarker
that arrived on the first input of this two-input operator.
This method is guaranteed to not be called concurrently with other methods of the operator.processLatencyMarker
in interface Input<RowData>
Exception
LatencyMarker
public void processWatermarkStatus(WatermarkStatus watermarkStatus) throws Exception
Input
WatermarkStatus
that arrived on this input of the MultipleInputStreamOperator
. This method is guaranteed to not be called concurrently with
other methods of the operator.processWatermarkStatus
in interface Input<RowData>
Exception
WatermarkStatus
@Internal public final boolean isAsyncStateProcessingEnabled()
AsyncStateProcessing
isAsyncStateProcessingEnabled
in interface AsyncStateProcessing
@Internal public final <T> ThrowingConsumer<StreamRecord<T>,Exception> getRecordProcessor(int inputId)
AsyncStateProcessing
getRecordProcessor
in interface AsyncStateProcessing
inputId
- the input identifier, start from 1. Borrow the design from org.apache.flink.streaming.api.operators.AbstractInput#inputId
. This is only relevant if
there is multiple inputs for the instance.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.