Class Hierarchy
- java.lang.Object
- org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext (implements org.apache.flink.api.common.functions.RuntimeContext)
- org.apache.flink.streaming.api.operators.AbstractStreamOperator<OUT> (implements java.io.Serializable, org.apache.flink.streaming.api.operators.StreamOperator<OUT>)
- org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator<OUT,F> (implements org.apache.flink.streaming.api.operators.OutputTypeConfigurable<OUT>)
- org.apache.flink.streaming.api.operators.StreamFilter<IN> (implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>)
- org.apache.flink.streaming.api.operators.StreamFlatMap<IN,OUT> (implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>)
- org.apache.flink.streaming.api.operators.StreamGroupedFold<IN,OUT,KEY> (implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>, org.apache.flink.streaming.api.operators.OutputTypeConfigurable<OUT>)
- org.apache.flink.streaming.api.operators.StreamGroupedReduce<IN> (implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>)
- org.apache.flink.streaming.api.operators.StreamMap<IN,OUT> (implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>)
- org.apache.flink.streaming.api.operators.StreamSink<IN> (implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>)
- org.apache.flink.streaming.api.operators.StreamSource<OUT,SRC> (implements org.apache.flink.streaming.api.operators.StreamOperator<OUT>)
- org.apache.flink.streaming.api.operators.StreamCounter<IN> (implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>)
- org.apache.flink.streaming.api.operators.StreamProject<IN,OUT> (implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>)
- org.apache.flink.streaming.api.operators.StreamSource.AutomaticWatermarkContext<T> (implements org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext<T>)
- org.apache.flink.streaming.api.operators.StreamSource.ManualWatermarkContext<T> (implements org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext<T>)
- org.apache.flink.streaming.api.operators.StreamSource.NonTimestampContext<T> (implements org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext<T>)
- org.apache.flink.streaming.api.operators.TimestampedCollector<T> (implements org.apache.flink.util.Collector<T>)
Interface Hierarchy
Enum Hierarchy
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.