Uses of Interface
org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceAware
-
-
Uses of ProcessingTimeServiceAware in org.apache.flink.streaming.api.functions.source
Classes in org.apache.flink.streaming.api.functions.source that implement ProcessingTimeServiceAware Modifier and Type Class Description class
ContinuousFileReaderOperatorFactory<OUT,T extends TimestampedInputSplit>
ContinuousFileReaderOperator
factory. -
Uses of ProcessingTimeServiceAware in org.apache.flink.streaming.api.operators
Classes in org.apache.flink.streaming.api.operators that implement ProcessingTimeServiceAware Modifier and Type Class Description class
AbstractStreamOperatorFactory<OUT>
Base class for all stream operator factories.class
SimpleInputFormatOperatorFactory<OUT>
Input format source operator factory which just wrap existedStreamSource
.class
SimpleOperatorFactory<OUT>
Simple factory which just wrap existedStreamOperator
.class
SimpleOutputFormatOperatorFactory<IN,OUT>
A simple operator factory which create an operator containing anOutputFormat
.class
SimpleUdfStreamOperatorFactory<OUT>
Udf stream operator factory which just wrap existedAbstractUdfStreamOperator
.class
SourceOperatorFactory<OUT>
The Factory class forSourceOperator
. -
Uses of ProcessingTimeServiceAware in org.apache.flink.streaming.api.operators.collect
Classes in org.apache.flink.streaming.api.operators.collect that implement ProcessingTimeServiceAware Modifier and Type Class Description class
CollectSinkOperatorFactory<IN>
The Factory class forCollectSinkOperator
. -
Uses of ProcessingTimeServiceAware in org.apache.flink.streaming.runtime.operators
Classes in org.apache.flink.streaming.runtime.operators that implement ProcessingTimeServiceAware Modifier and Type Class Description class
TimestampsAndWatermarksOperatorFactory<T>
-
Uses of ProcessingTimeServiceAware in org.apache.flink.streaming.runtime.operators.sink
Classes in org.apache.flink.streaming.runtime.operators.sink that implement ProcessingTimeServiceAware Modifier and Type Class Description class
CommitterOperatorFactory<CommT>
AStreamOperatorFactory
forCommitterOperator
.class
SinkWriterOperatorFactory<InputT,CommT>
AStreamOperatorFactory
forSinkWriterOperator
. -
Uses of ProcessingTimeServiceAware in org.apache.flink.streaming.runtime.operators.windowing
Classes in org.apache.flink.streaming.runtime.operators.windowing that implement ProcessingTimeServiceAware Modifier and Type Class Description class
EvictingWindowOperatorFactory<K,IN,OUT,W extends Window>
class
WindowOperatorFactory<K,IN,ACC,OUT,W extends Window>
-