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 classContinuousFileReaderOperatorFactory<OUT,T extends TimestampedInputSplit>ContinuousFileReaderOperatorfactory. -
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 classAbstractStreamOperatorFactory<OUT>Base class for all stream operator factories.classSimpleInputFormatOperatorFactory<OUT>Input format source operator factory which just wrap existedStreamSource.classSimpleOperatorFactory<OUT>Simple factory which just wrap existedStreamOperator.classSimpleOutputFormatOperatorFactory<IN,OUT>A simple operator factory which create an operator containing anOutputFormat.classSimpleUdfStreamOperatorFactory<OUT>Udf stream operator factory which just wrap existedAbstractUdfStreamOperator.classSourceOperatorFactory<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 classCollectSinkOperatorFactory<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 classTimestampsAndWatermarksOperatorFactory<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 classCommitterOperatorFactory<CommT>AStreamOperatorFactoryforCommitterOperator.classSinkWriterOperatorFactory<InputT,CommT>AStreamOperatorFactoryforSinkWriterOperator. -
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 classEvictingWindowOperatorFactory<K,IN,OUT,W extends Window>classWindowOperatorFactory<K,IN,ACC,OUT,W extends Window>
-