类 CountingBroadcastOutput<OUT>

  • 所有已实现的接口:
    BroadcastOutput<OUT>

    public class CountingBroadcastOutput<OUT>
    extends Object
    implements BroadcastOutput<OUT>
    The intermediate broadcast output that wrappers a list of internal outputs. It will broadcast the records to all the internal outputs and increment the counter.
    • 构造器详细资料

      • CountingBroadcastOutput

        public CountingBroadcastOutput​(org.apache.flink.metrics.Counter numRecordsOut,
                                       List<BroadcastOutput<OUT>> internalOutputs)
    • 方法详细资料

      • broadcastEmit

        public void broadcastEmit​(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<OUT> record)
                           throws IOException
        从接口复制的说明: BroadcastOutput
        Broadcasts the record to all the downstream operators.
        指定者:
        broadcastEmit 在接口中 BroadcastOutput<OUT>
        参数:
        record - the record to broadcast.
        抛出:
        IOException