flink ProcessFunction简介,实战,流程分析

1.ProcessFunction介绍

1.1 ProcessFunction基本构成

ProcessFunction是一个低级流处理操作,可以访问所有(非循环)流应用程序的基本构建块:

  • 事件(流元素)
  • state(容错,一致,仅在keyed stream上)
  • 定时器(事件时间和处理时间,仅限keyed stream)
image.png

ProcessFunction可以被看作是一个可以访问keyed state和定时器的FlatMapFunction。它可以对输入流中接收的每个事件进行调用处理。

状态

对于容错的state,ProcessFunction可以访问Flink的keyed state,可以通过其访问 RuntimeContext,类似于其他有状态函数访问keyed state的方式。

time

定时器允许应用程序对processing timeevent time.
的变化作出反应。每次调用该函数processElement(...)都会获得一个Context对象,该对象可以访问元素的事件时间戳和TimerService。的TimerService可用于注册为将来事件- /处理-时刻回调。

触发时间

达到计时器的特定时间时,将onTimer(...)调用该方法。在event time上注册时间为T的timer,一旦watermark大于或等于T,就会触发onTimer。在该调用期间,所有状态再次限定为创建计时器的key的状态,允许计时器操纵keyed state。

注意如果要访问键控状态和计时器,则必须应用ProcessFunction键控流:

stream.keyBy(...).process(new MyProcessFunction())

2.实战 机器宕机告警

2.1 需求

filebeat采集机器数据到kafka,对于某台机器2分钟内没有新数据流入kafka,则判定这台机器宕机。

2.2 Main函数

  StreamExecutionEnvironment env = ...; //
     env.setStreamTimeCharacteristic(TimeCharacteristic.EventTime); //使用eventTime

      DataSource<MetricEvent> source ;//读取kafka
      SingleOutputStreamOperator<SimplifyMetricEvent> data =  source.flatMap(new FirstFilterFunction()).assignTimestampsAndWatermarks(new MetricLagWatermarkExtractor()); 
     int timeLimit=2*60*1000;
   SingleOutputStreamOperator<SimplifyMetricEvent> 
   data.keyBy(SimplifyMetricEvent::getIp).process(new OutageFunction(timeLimit)).print();

注意:MetricLagWatermarkExtractor 一定要对异常数据做处理,比如时间戳大于当前时间,这个时间戳就不能作为watermark,否则后续onTimer方法的调用时间就不准确。

2.3 ProcessFunction

import org.apache.flink.api.common.state.ValueState;
import org.apache.flink.api.common.state.ValueStateDescriptor;
import org.apache.flink.api.common.typeinfo.TypeHint;
import org.apache.flink.api.common.typeinfo.TypeInformation;
import org.apache.flink.configuration.Configuration;
import org.apache.flink.streaming.api.functions.KeyedProcessFunction;
import org.apache.flink.util.Collector;

import java.util.ArrayList;
import java.util.List;


public class OutageFunction extends KeyedProcessFunction<String, SimplifyMetricEvent, SimplifyMetricEvent> {
   private ValueState<SimplifyMetricEvent> state;
   private int delay;
   @Override
   public void open(Configuration configuration) {
       TypeInformation<SimplifyMetricEvent> info = TypeInformation.of(new TypeHint<SimplifyMetricEvent>() {
       });
       TypeInformation<Boolean> resolveInfo = TypeInformation.of(new TypeHint<Boolean>() {
       });
       state = getRuntimeContext().getState(new ValueStateDescriptor<>("myState", info));
   }

   public OutageFunction(int delay) {
       this.delay = delay;
   }


   @Override
   public void processElement(SimplifyMetricEvent simplifyMetricEvent, Context ctx, Collector<SimplifyMetricEvent> collector) throws Exception {
       SimplifyMetricEvent current = state.value();

       if (current == null) {
           current = new SimplifyMetricEvent(simplifyMetricEvent.getClusterName(), simplifyMetricEvent.getHostIp(),
                   simplifyMetricEvent.getTimestamp(), simplifyMetricEvent.getResolve(), System.currentTimeMillis());
       }
       current.setTimestamp(simplifyMetricEvent.getTimestamp());
       current.setSystemTimestamp(System.currentTimeMillis());
       state.update(current);
       ctx.timerService().registerEventTimeTimer(current.getSystemTimestamp() + delay);

   }

   @Override
   public void onTimer(long timestamp, OnTimerContext ctx, Collector<SimplifyMetricEvent> out) throws Exception {
       // get the state for the key that scheduled the timer
       //获取计划定时器的key的状态
       SimplifyMetricEvent result = state.value();
       // 检查是否是过时的定时器或最新的定时器
       if (result != null && timestamp >= result.getSystemTimestamp() + delay) {
           out.collect(result);      //宕机发生,往下游发送事件
           ctx.timerService().registerEventTimeTimer(timestamp + delay);//注册下一个宕机事件
           result.setSystemTimestamp(timestamp); 
           state.update(result);
       }
   }
}

ctx.timerService().registerEventTimeTimer(current.getSystemTimestamp() + delay);就是定义一个事件触发器,触发的时间是current.getSystemTimestamp() + delay。到达该时间则调用
onTimer(long timestamp, OnTimerContext ctx, Collector<SimplifyMetricEvent> out)

3.流程解析

1

data:SingleOutputStreamOperator 调用keyBy形成 KeyedStream,调用process

@Internal
    public <R> SingleOutputStreamOperator<R> process(
            KeyedProcessFunction<KEY, T, R> keyedProcessFunction,
            TypeInformation<R> outputType) {

        KeyedProcessOperator<KEY, T, R> operator = new KeyedProcessOperator<>(clean(keyedProcessFunction));
        return transform("KeyedProcess", outputType, operator);
    }

keyedProcessFunction 就是上边我们自定义的OutageFunction。
这里生成的 KeyedProcessOperator

2

public class KeyedProcessOperator<K, IN, OUT>
        extends AbstractUdfStreamOperator<OUT, KeyedProcessFunction<K, IN, OUT>>
        implements OneInputStreamOperator<IN, OUT>, Triggerable<K, VoidNamespace> {

KeyedProcessOperator实现了 Triggerable

        @Override  //实现Triggerable
    public void onEventTime(InternalTimer<K, VoidNamespace> timer) throws Exception {
        collector.setAbsoluteTimestamp(timer.getTimestamp());
        invokeUserFunction(TimeDomain.EVENT_TIME, timer);
    }

    @Override //实现Triggerable
    public void onProcessingTime(InternalTimer<K, VoidNamespace> timer) throws Exception {
        collector.eraseTimestamp();
        invokeUserFunction(TimeDomain.PROCESSING_TIME, timer);
    }

    @Override
    public void processElement(StreamRecord<IN> element) throws Exception {
        collector.setTimestamp(element);
        context.element = element;
        userFunction.processElement(element.getValue(), context, collector);
        context.element = null;
    }

    private void invokeUserFunction(
            TimeDomain timeDomain,
            InternalTimer<K, VoidNamespace> timer) throws Exception {
        onTimerContext.timeDomain = timeDomain;
        onTimerContext.timer = timer;
        userFunction.onTimer(timer.getTimestamp(), onTimerContext, collector);
        onTimerContext.timeDomain = null;
        onTimerContext.timer = null;
    }

userFunction.processElement(element.getValue(), context, collector);
userFunction.onTimer(timer.getTimestamp(), onTimerContext, collector);
userFunction就是我们上面的OutageFunction
这里看到在onEventTime或者onProcessingTime方法调用的时候才会调用userFunction.onTimer。那么 onEventTime 什么时候触发呢?

3.以onEventTime为例

image.png

进入到InternalTimerServiceImpl

public void advanceWatermark(long time) throws Exception {
        currentWatermark = time;

        InternalTimer<K, N> timer;

        while ((timer = eventTimeTimersQueue.peek()) != null && timer.getTimestamp() <= time) {
            eventTimeTimersQueue.poll();
            keyContext.setCurrentKey(timer.getKey());
            triggerTarget.onEventTime(timer);
        }
    }

也就是说InternalTimerServiceImpl调用advanceWatermark时我们的onEventTime方法才调用。而advanceWatermark方法的入参time是当前operator的watermark所代表的时间。那么什么时候调用advanceWatermark呢?这个等下再看。
这个方法里面的eventTimeTimersQueue

       /**
     * Event time timers that are currently in-flight.
     */
    private final KeyGroupedInternalPriorityQueue<TimerHeapInternalTimer<K, N>> eventTimeTimersQueue;

当我们调用时ctx.timerService().registerEventTimeTimer(current.getSystemTimestamp() + delay);
就是调用

    @Override
    public void registerEventTimeTimer(N namespace, long time) {
        eventTimeTimersQueue.add(new TimerHeapInternalTimer<>(time, (K) keyContext.getCurrentKey(), namespace));
    }

向里eventTimeTimersQueue存储TimerHeapInternalTimer(包含key,timestamp等)。
当调用advanceWatermark时,更新currentWatermark,从eventTimeTimersQueue里peek出timer,判断当前watermark的时间是否大于timer里的时间,若大于,则从队列里弹出这个timer调用 triggerTarget.onEventTime(timer)
也就是调用 KeyedProcessOperator.onEventTime,最终调用到里我们自定义OutageFunctiononTimer方法。

3.总结一下

如果我们的env用的是 TimeCharacteristic.EventTime,那么我们自定义的 KeyedProcessFunctiononTimer触发时间是这个算子的watermark时间大于 ctx.timerService().registerEventTimeTimer(current.getSystemTimestamp() + delay)注册的时间时才会触发。
注意因为这里的触发时间和watermark强相关,在上游算子assignTimestampsAndWatermarks时一定正确处理wartermark的值。

todo:

什么时候调用InternalTimerServiceImpladvanceWatermark呢?

最后编辑于
?著作权归作者所有,转载或内容合作请联系作者
  • 序言:七十年代末,一起剥皮案震惊了整个滨河市,随后出现的几起案子,更是在滨河造成了极大的恐慌,老刑警刘岩,带你破解...
    沈念sama阅读 214,172评论 6 493
  • 序言:滨河连续发生了三起死亡事件,死亡现场离奇诡异,居然都是意外死亡,警方通过查阅死者的电脑和手机,发现死者居然都...
    沈念sama阅读 91,346评论 3 389
  • 文/潘晓璐 我一进店门,熙熙楼的掌柜王于贵愁眉苦脸地迎上来,“玉大人,你说我怎么就摊上这事。” “怎么了?”我有些...
    开封第一讲书人阅读 159,788评论 0 349
  • 文/不坏的土叔 我叫张陵,是天一观的道长。 经常有香客问我,道长,这世上最难降的妖魔是什么? 我笑而不...
    开封第一讲书人阅读 57,299评论 1 288
  • 正文 为了忘掉前任,我火速办了婚礼,结果婚礼上,老公的妹妹穿的比我还像新娘。我一直安慰自己,他们只是感情好,可当我...
    茶点故事阅读 66,409评论 6 386
  • 文/花漫 我一把揭开白布。 她就那样静静地躺着,像睡着了一般。 火红的嫁衣衬着肌肤如雪。 梳的纹丝不乱的头发上,一...
    开封第一讲书人阅读 50,467评论 1 292
  • 那天,我揣着相机与录音,去河边找鬼。 笑死,一个胖子当着我的面吹牛,可吹牛的内容都是我干的。 我是一名探鬼主播,决...
    沈念sama阅读 39,476评论 3 412
  • 文/苍兰香墨 我猛地睁开眼,长吁一口气:“原来是场噩梦啊……” “哼!你这毒妇竟也来了?” 一声冷哼从身侧响起,我...
    开封第一讲书人阅读 38,262评论 0 269
  • 序言:老挝万荣一对情侣失踪,失踪者是张志新(化名)和其女友刘颖,没想到半个月后,有当地人在树林里发现了一具尸体,经...
    沈念sama阅读 44,699评论 1 307
  • 正文 独居荒郊野岭守林人离奇死亡,尸身上长有42处带血的脓包…… 初始之章·张勋 以下内容为张勋视角 年9月15日...
    茶点故事阅读 36,994评论 2 328
  • 正文 我和宋清朗相恋三年,在试婚纱的时候发现自己被绿了。 大学时的朋友给我发了我未婚夫和他白月光在一起吃饭的照片。...
    茶点故事阅读 39,167评论 1 343
  • 序言:一个原本活蹦乱跳的男人离奇死亡,死状恐怖,灵堂内的尸体忽然破棺而出,到底是诈尸还是另有隐情,我是刑警宁泽,带...
    沈念sama阅读 34,827评论 4 337
  • 正文 年R本政府宣布,位于F岛的核电站,受9级特大地震影响,放射性物质发生泄漏。R本人自食恶果不足惜,却给世界环境...
    茶点故事阅读 40,499评论 3 322
  • 文/蒙蒙 一、第九天 我趴在偏房一处隐蔽的房顶上张望。 院中可真热闹,春花似锦、人声如沸。这庄子的主人今日做“春日...
    开封第一讲书人阅读 31,149评论 0 21
  • 文/苍兰香墨 我抬头看了看天上的太阳。三九已至,却和暖如春,着一层夹袄步出监牢的瞬间,已是汗流浃背。 一阵脚步声响...
    开封第一讲书人阅读 32,387评论 1 267
  • 我被黑心中介骗来泰国打工, 没想到刚下飞机就差点儿被人妖公主榨干…… 1. 我叫王不留,地道东北人。 一个月前我还...
    沈念sama阅读 47,028评论 2 365
  • 正文 我出身青楼,却偏偏与公主长得像,于是被迫代替她去往敌国和亲。 传闻我的和亲对象是个残疾皇子,可洞房花烛夜当晚...
    茶点故事阅读 44,055评论 2 352

推荐阅读更多精彩内容

  • 前言 最近在Xcode 工作space中建立了多个frameWork,进行功能组件开发。在主App里面运用shel...
    timeQuick阅读 1,916评论 1 2
  • 跟跑步结缘,始于我先生在汶川跑的一次马拉松!我生来就不喜欢锻炼运动,自己也很瘦,不需要通过运动运动减肥,感觉...
    曦曦小小阅读 575评论 0 2
  • 如果她是唐僧,应该可以把紧箍咒念得很好,不过那肥背塌腰扁平臀,比菜市害了病的猪肉都还松垮地摊在凳子上,要是哪个妖怪...
    Scarlett_Ch阅读 228评论 1 0
  • 2018年5月17日曾经一起战斗过的同事又走了3个,加上去年走的2个,曾经的七匹小狼只剩2个了,我和顾。 遥想9年...
    东南居士阅读 309评论 0 0