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

程序包分层结构:

类分层结构

  • java.lang.Object
    • 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.perround.AbstractPerRoundWrapperOperator<T,​S> (implements org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator)
        • org.apache.flink.iteration.operator.perround.MultipleInputPerRoundWrapperOperator<OUT> (implements org.apache.flink.streaming.api.operators.MultipleInputStreamOperator<OUT>)
        • org.apache.flink.iteration.operator.perround.OneInputPerRoundWrapperOperator<IN,​OUT> (implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,​OUT>)
        • org.apache.flink.iteration.operator.perround.TwoInputPerRoundWrapperOperator<IN1,​IN2,​OUT> (implements org.apache.flink.streaming.api.operators.TwoInputStreamOperator<IN1,​IN2,​OUT>)
    • org.apache.flink.iteration.operator.perround.PerRoundOperatorWrapper<T> (implements org.apache.flink.iteration.operator.OperatorWrapper<T,​R>)