为了账号安全,请及时绑定邮箱和手机立即绑定

Apache Flink - 事件时间窗口

Apache Flink - 事件时间窗口

米琪卡哇伊 2021-08-19 17:44:20
我想在 Apache flink 中创建键控窗口,以便每个键的窗口在键的第一个事件到达后 n 分钟执行。是否可以使用事件时间特性来完成(因为处理时间取决于系统时钟,并且不确定第一个事件何时到达)。如果可能,请解释事件时间和水印的分配也给事件,并解释如何在 n 分钟后调用进程窗口函数。以下是一部分代码,可以让您了解我目前在做什么:            //Make keyed events so as to start a window for a key            KeyedStream<SourceData, Tuple> keyedEvents =                     env.addSource(new MySource(configData),"JSON Source")                    .assignTimestampsAndWatermarks(new MyTimeStamps())                    .setParallelism(1)                    .keyBy("service");            //Start a window for windowTime time            DataStream<ResultData> resultData=                    keyedEvents                    .timeWindow(Time.minutes(winTime))                    .process(new ProcessEventWindow(configData))                    .name("Event Collection Window")                    .setParallelism(25);那么,我将如何分配事件时间和水印,以便窗口遵循第一个事件的事件时间作为起点并在 10 分钟后执行(第一个事件的开始时间对于不同的键可能不同)。任何帮助将非常感激。        /------------ ( window of 10 minutes )Streams          |------------ ( window of 10 minutes )            \------------ ( window of 10 minutes )编辑:我用于分配时间戳和水印的类public class MyTimeStamps implements AssignerWithPeriodicWatermarks<SourceData> {    @Override    public long extractTimestamp(SourceData element, long previousElementTimestamp) {          //Will return epoch of currentTime        return GlobalUtilities.getCurrentEpoch();    }    @Override    public Watermark getCurrentWatermark() {        // TODO Auto-generated method stub        //Will return epoch of currentTime + 10 minutes        return new Watermark(GlobalUtilities.getTimeShiftNMinutesEpoch(10));    }}
查看完整描述

2 回答

?
阿晨1998

TA贡献2037条经验 获得超6个赞

我认为对于您的用例,最好使用ProcessFunction。您可以做的是在第一个事件到来时注册一个 EventTimeTimer。比在onTimer方法中发出结果。


就像是:


public class ProcessFunctionImpl extends ProcessFunction<SourceData, ResultData> {


    @Override

    public void processElement(SourceData value, Context ctx, Collector<ResultData> out)

        throws Exception {


        // retrieve the current aggregate

        ResultData current = state.value();

        if (current == null) {

            // first event arrived

            current = new ResultData();

            // register end of window

            ctx.timerService().registerEventTimeTimer(ctx.timestamp() + 10 * 60 * 1000 /* 10 minutes */);

        }


        // update the state's aggregate

        current += value;


        // write the state back

        state.update(current);

    }


    @Override

    public void onTimer(long timestamp, OnTimerContext ctx, Collector<ResultData> out)

        throws Exception {


        // get the state for the key that scheduled the timer

        ResultData result = state.value();


        out.collect(result);


        // reset the window state

        state.clear();

    }

}


查看完整回答
反对 回复 2021-08-19
?
皈依舞

TA贡献1851条经验 获得超3个赞

不久前我有一个关于事件时间窗口的类似问题。这是我的流的样子


val env = StreamExecutionEnvironment.getExecutionEnvironment

env.setStreamTimeCharacteristic(TimeCharacteristic.EventTime)


//Consumer Setup


val stream = env.addSource(consumer)

  .assignTimestampsAndWatermarks(new WMAssigner)


// Additional Setup here


stream

  .keyBy { data => data.findValue("service") }

  .window(TumblingEventTimeWindows.of(Time.minutes(10)))

  .process { new WindowProcessor }


  //Sinks go here

我的 WMAssigner 类看起来像这样(注意:这允许 1 分钟的乱序事件发生,如果您不想延迟,您可以扩展不同的时间戳提取器):


class WMAssigner extends BoundedOutOfOrdernessTimestampExtractor[ObjectNode] (Time.seconds(60)) {

  override def extractTimestamp(element: ObjectNode): Long = {

    val tsStr = element.findValue("data").findValue("ts").toString replaceAll("\"", "")

    tsStr.toLong

  }

}

我想用于水印的时间戳是 data.ts 字段。


我的窗口处理器:


class WindowProcessor extends ProcessWindowFunction[ObjectNode,String,String,TimeWindow] {

  override def process(key: String, context: Context, elements: Iterable[ObjectNode], out: Collector[String]): Unit = {

    val out = ""

    elements.foreach( value => {

      out = value.findValue("data").findValue("outData")

    }

    out.collect(out)

  }

}

如果有任何不清楚的地方,请告诉我


查看完整回答
反对 回复 2021-08-19
  • 2 回答
  • 0 关注
  • 161 浏览

添加回答

举报

0/150
提交
取消
意见反馈 帮助中心 APP下载
官方微信