程序包org.apache.flink.iteration.operator的分层结构

程序包分层结构:

类分层结构

  • java.lang.Object
    • org.apache.flink.streaming.api.operators.AbstractStreamOperator<OUT> (implements java.io.Serializable, org.apache.flink.streaming.api.operators.SetupableStreamOperator<OUT>, org.apache.flink.streaming.api.operators.StreamOperator<OUT>, org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator)
      • org.apache.flink.iteration.operator.HeadOperator (implements org.apache.flink.streaming.api.operators.BoundedOneInput, org.apache.flink.statefun.flink.core.feedback.FeedbackConsumer<T>, org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,​OUT>, org.apache.flink.runtime.operators.coordination.OperatorEventHandler)
      • org.apache.flink.iteration.operator.InputOperator<T> (implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,​OUT>)
      • org.apache.flink.iteration.operator.OutputOperator<T> (implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,​OUT>)
      • org.apache.flink.iteration.operator.ReplayOperator<T> (implements org.apache.flink.streaming.api.operators.BoundedMultiInput, org.apache.flink.iteration.progresstrack.OperatorEpochWatermarkTrackerListener, org.apache.flink.streaming.api.operators.TwoInputStreamOperator<IN1,​IN2,​OUT>)
      • org.apache.flink.iteration.operator.TailOperator (implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,​OUT>)
    • org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory<OUT> (implements org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceAware, org.apache.flink.streaming.api.operators.StreamOperatorFactory<OUT>)
      • org.apache.flink.iteration.operator.HeadOperatorFactory (implements org.apache.flink.streaming.api.operators.CoordinatedOperatorFactory<OUT>, org.apache.flink.streaming.api.operators.OneInputStreamOperatorFactory<IN,​OUT>, org.apache.flink.streaming.api.operators.YieldingOperatorFactory<OUT>)
      • org.apache.flink.iteration.operator.WrapperOperatorFactory<OUT>
    • org.apache.flink.iteration.operator.AbstractWrapperOperator<T> (implements org.apache.flink.streaming.api.operators.BoundedMultiInput, org.apache.flink.iteration.progresstrack.OperatorEpochWatermarkTrackerListener, org.apache.flink.streaming.api.operators.StreamOperator<OUT>)
    • org.apache.flink.iteration.operator.OperatorStateUtils
    • org.apache.flink.iteration.operator.OperatorUtils

接口分层结构