Uses of Class
org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
-
Packages that use LatencyMarker Package Description org.apache.flink.state.api.output.operators org.apache.flink.streaming.api.operators org.apache.flink.streaming.runtime.io org.apache.flink.streaming.runtime.streamrecord org.apache.flink.streaming.runtime.tasks This package contains classes that realize streaming tasks.org.apache.flink.streaming.util org.apache.flink.table.runtime.operators.multipleinput.input org.apache.flink.table.runtime.operators.multipleinput.output org.apache.flink.table.runtime.operators.sink -
-
Uses of LatencyMarker in org.apache.flink.state.api.output.operators
Methods in org.apache.flink.state.api.output.operators with parameters of type LatencyMarker Modifier and Type Method Description void
StateBootstrapWrapperOperator. processLatencyMarker(LatencyMarker latencyMarker)
-
Uses of LatencyMarker in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators with parameters of type LatencyMarker Modifier and Type Method Description void
CountingOutput. emitLatencyMarker(LatencyMarker latencyMarker)
void
Output. emitLatencyMarker(LatencyMarker latencyMarker)
void
TimestampedCollector. emitLatencyMarker(LatencyMarker latencyMarker)
void
AbstractInput. processLatencyMarker(LatencyMarker latencyMarker)
void
AbstractStreamOperator. processLatencyMarker(LatencyMarker latencyMarker)
void
Input. processLatencyMarker(LatencyMarker latencyMarker)
Processes aLatencyMarker
that arrived on the first input of this two-input operator.void
AbstractStreamOperator. processLatencyMarker1(LatencyMarker latencyMarker)
void
TwoInputStreamOperator. processLatencyMarker1(LatencyMarker latencyMarker)
Processes aLatencyMarker
that arrived on the first input of this two-input operator.void
AbstractStreamOperator. processLatencyMarker2(LatencyMarker latencyMarker)
void
TwoInputStreamOperator. processLatencyMarker2(LatencyMarker latencyMarker)
Processes aLatencyMarker
that arrived on the second input of this two-input operator.protected void
AbstractStreamOperator. reportOrForwardLatencyMarker(LatencyMarker marker)
protected void
AbstractStreamOperatorV2. reportOrForwardLatencyMarker(LatencyMarker marker)
protected void
StreamSink. reportOrForwardLatencyMarker(LatencyMarker marker)
-
Uses of LatencyMarker in org.apache.flink.streaming.runtime.io
Methods in org.apache.flink.streaming.runtime.io with parameters of type LatencyMarker Modifier and Type Method Description void
FinishedDataOutput. emitLatencyMarker(LatencyMarker latencyMarker)
void
PushingAsyncDataInput.DataOutput. emitLatencyMarker(LatencyMarker latencyMarker)
void
RecordWriterOutput. emitLatencyMarker(LatencyMarker latencyMarker)
-
Uses of LatencyMarker in org.apache.flink.streaming.runtime.streamrecord
Methods in org.apache.flink.streaming.runtime.streamrecord that return LatencyMarker Modifier and Type Method Description LatencyMarker
StreamElement. asLatencyMarker()
Casts this element into a LatencyMarker. -
Uses of LatencyMarker in org.apache.flink.streaming.runtime.tasks
Methods in org.apache.flink.streaming.runtime.tasks with parameters of type LatencyMarker Modifier and Type Method Description void
FinishedOnRestoreMainOperatorOutput. emitLatencyMarker(LatencyMarker latencyMarker)
void
SourceOperatorStreamTask.AsyncDataOutputToOutput. emitLatencyMarker(LatencyMarker latencyMarker)
void
FinishedOnRestoreInput. processLatencyMarker(LatencyMarker latencyMarker)
-
Uses of LatencyMarker in org.apache.flink.streaming.util
Methods in org.apache.flink.streaming.util with parameters of type LatencyMarker Modifier and Type Method Description void
LatencyStats. reportLatency(LatencyMarker marker)
-
Uses of LatencyMarker in org.apache.flink.table.runtime.operators.multipleinput.input
Methods in org.apache.flink.table.runtime.operators.multipleinput.input with parameters of type LatencyMarker Modifier and Type Method Description void
FirstInputOfTwoInput. processLatencyMarker(LatencyMarker latencyMarker)
void
OneInput. processLatencyMarker(LatencyMarker latencyMarker)
void
SecondInputOfTwoInput. processLatencyMarker(LatencyMarker latencyMarker)
-
Uses of LatencyMarker in org.apache.flink.table.runtime.operators.multipleinput.output
Methods in org.apache.flink.table.runtime.operators.multipleinput.output with parameters of type LatencyMarker Modifier and Type Method Description void
BroadcastingOutput. emitLatencyMarker(LatencyMarker latencyMarker)
void
CopyingSecondInputOfTwoInputStreamOperatorOutput. emitLatencyMarker(LatencyMarker latencyMarker)
void
FirstInputOfTwoInputStreamOperatorOutput. emitLatencyMarker(LatencyMarker latencyMarker)
void
OneInputStreamOperatorOutput. emitLatencyMarker(LatencyMarker latencyMarker)
void
SecondInputOfTwoInputStreamOperatorOutput. emitLatencyMarker(LatencyMarker latencyMarker)
-
Uses of LatencyMarker in org.apache.flink.table.runtime.operators.sink
Methods in org.apache.flink.table.runtime.operators.sink with parameters of type LatencyMarker Modifier and Type Method Description protected void
SinkOperator. reportOrForwardLatencyMarker(LatencyMarker marker)
-