Class Hierarchy
- java.lang.Object
- org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes<Type,Key,Aggregate,Result>
- 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.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator<KEY,IN,OUT,STATE,F> (implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>, org.apache.flink.streaming.runtime.operators.Triggerable)
- org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator<IN,ACC,OUT,W> (implements org.apache.flink.api.java.typeutils.InputTypeConfigurable, org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>, org.apache.flink.streaming.runtime.operators.Triggerable)
- org.apache.flink.streaming.runtime.operators.windowing.WindowOperator<K,IN,ACC,OUT,W> (implements org.apache.flink.api.java.typeutils.InputTypeConfigurable, org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>, org.apache.flink.streaming.runtime.operators.Triggerable)
- org.apache.flink.streaming.runtime.operators.windowing.KeyMap<K,V> (implements java.lang.Iterable<T>)
- org.apache.flink.streaming.runtime.operators.windowing.KeyMap.Entry<K,V>
- org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context (implements org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext)
- org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context (implements org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext)
- org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer<K,W> (implements java.lang.Comparable<T>)
Interface Hierarchy
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.