Flink处理函数实战之三:KeyedProcessFunction类

《一线大厂Java面试题解析+核心总结学习笔记+最新讲解视频+实战项目源码》点击传送门,即可获取!

if(StringUtils.isNullOrWhitespaceOnly(s)) {

System.out.println(“invalid line”);

return;

}

for(String word : s.split(" ")) {

collector.collect(new Tuple2<String, Integer>(word, 1));

}

}

}

  1. 最后是整个逻辑功能的主体:ProcessTime.java,这里面有自定义的KeyedProcessFunction子类,还有程序入口的main方法,代码在下面列出来之后,还会对关键部分做介绍:

package com.bolingcavalry.keyedprocessfunction;

import com.bolingcavalry.Splitter;

import org.apache.flink.api.common.state.ValueState;

import org.apache.flink.api.common.state.ValueStateDescriptor;

import org.apache.flink.api.java.tuple.Tuple;

import org.apache.flink.api.java.tuple.Tuple2;

import org.apache.flink.configuration.Configuration;

import org.apache.flink.streaming.api.TimeCharacteristic;

import org.apache.flink.streaming.api.datastream.DataStream;

import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment;

import org.apache.flink.streaming.api.functions.AssignerWithPeriodicWatermarks;

import org.apache.flink.streaming.api.functions.KeyedProcessFunction;

import org.apache.flink.streaming.api.watermark.Watermark;

import org.apache.flink.util.Collector;

import java.text.SimpleDateFormat;

import java.util.Date;

/**

  • @author will

  • @email zq2599@gmail.com

  • @date 2020-05-17 13:43

  • @description 体验KeyedProcessFunction类(时间类型是处理时间)

*/

public class ProcessTime {

/**

  • KeyedProcessFunction的子类,作用是将每个单词最新出现时间记录到backend,并创建定时器,

  • 定时器触发的时候,检查这个单词距离上次出现是否已经达到10秒,如果是,就发射给下游算子

*/

static class CountWithTimeoutFunction extends KeyedProcessFunction<Tuple, Tuple2<String, Integer>, Tuple2<String, Long>> {

// 自定义状态

private ValueState state;

@Override

public void open(Configuration parameters) throws Exception {

// 初始化状态,name是myState

state = getRuntimeContext().getState(new ValueStateDescriptor<>(“myState”, CountWithTimestamp.class));

}

@Override

public void processElement(

Tuple2<String, Integer> value,

Context ctx,

Collector<Tuple2<String, Long>> out) throws Exception {

// 取得当前是哪个单词

Tuple currentKey = ctx.getCurrentKey();

// 从backend取得当前单词的myState状态

CountWithTimestamp current = state.value();

// 如果myState还从未没有赋值过,就在此初始化

if (current == null) {

current = new CountWithTimestamp();

current.key = value.f0;

}

// 单词数量加一

current.count++;

// 取当前元素的时间戳,作为该单词最后一次出现的时间

current.lastModified = ctx.timestamp();

// 重新保存到backend,包括该单词出现的次数,以及最后一次出现的时间

state.update(current);

// 为当前单词创建定时器,十秒后后触发

long timer = current.lastModified + 10000;

ctx.timerService().registerProcessingTimeTimer(timer);

// 打印所有信息,用于核对数据正确性

System.out.println(String.format(“process, %s, %d, lastModified : %d (%s), timer : %d (%s)\n\n”,

currentKey.getField(0),

current.count,

current.lastModified,

time(current.lastModified),

timer,

time(timer)));

}

/**

  • 定时器触发后执行的方法

  • @param timestamp 这个时间戳代表的是该定时器的触发时间

  • @param ctx

  • @param out

  • @throws Exception

*/

@Override

public void onTimer(

long timestamp,

OnTimerContext ctx,

Collector<Tuple2<String, Long>> out) throws Exception {

// 取得当前单词

Tuple currentKey = ctx.getCurrentKey();

// 取得该单词的myState状态

CountWithTimestamp result = state.value();

// 当前元素是否已经连续10秒未出现的标志

boolean isTimeout = false;

// timestamp是定时器触发时间,如果等于最后一次更新时间+10秒,就表示这十秒内已经收到过该单词了,

// 这种连续十秒没有出现的元素,被发送到下游算子

if (timestamp == result.lastModified + 10000) {

// 发送

out.collect(new Tuple2<String, Long>(result.key, result.count));

isTimeout = true;

}

// 打印数据,用于核对是否符合预期

System.out.println(String.format(“ontimer, %s, %d, lastModified : %d (%s), stamp : %d (%s), isTimeout : %s\n\n”,

currentKey.getField(0),

result.count,

result.lastModified,

time(result.lastModified),

timestamp,

time(timestamp),

String.valueOf(isTimeout)));

}

}

public static void main(String[] args) throws Exception {

final StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();

// 并行度1

env.setParallelism(1);

// 处理时间

env.setStreamTimeCharacteristic(TimeCharacteristic.ProcessingTime);

// 监听本地9999端口,读取字符串

DataStream socketDataStream = env.socketTextStream(“localhost”, 9999);

// 所有输入的单词,如果超过10秒没有再次出现,都可以通过CountWithTimeoutFunction得到

DataStream<Tuple2<String, Long>> timeOutWord = socketDataStream

// 对收到的字符串用空格做分割,得到多个单词

.flatMap(new Splitter())

// 设置时间戳分配器,用当前时间作为时间戳

.assignTimestampsAndWatermarks(new AssignerWithPeriodicWatermarks<Tuple2<String, Integer>>() {

@Override

public long extractTimestamp(Tuple2<String, Integer> element, long previousElementTimestamp) {

// 使用当前系统时间作为时间戳

return System.currentTimeMillis();

}

@Override

public Watermark getCurrentWatermark() {

// 本例不需要watermark,返回null

return null;

}

})

// 将单词作为key分区

.keyBy(0)

// 按单词分区后的数据,交给自定义KeyedProcessFunction处理

.process(new CountWithTimeoutFunction());

// 所有输入的单词,如果超过10秒没有再次出现,就在此打印出来

timeOutWord.print();

env.execute(“ProcessFunction demo : KeyedProcessFunction”);

}

public static String time(long timeStamp) {

return new SimpleDateFormat(“yyyy-MM-dd hh:mm:ss”).format(new Date(timeStamp));

}

}

上述代码有几处需要重点关注的:

  1. 通过assignTimestampsAndWatermarks设置时间戳的时候,getCurrentWatermark返回null,因为用不上watermark;

  2. processElement方法中,state.value()可以取得当前单词的状态,state.update(current)可以设置当前单词的状态,这个功能的详情请参考《深入了解ProcessFunction的状态操作(Flink-1.10)》

  3. registerProcessingTimeTimer方法设置了定时器的触发时间,注意这里的定时器是基于processTime,和官方demo中的eventTime是不同的;

  4. 定时器触发后,onTimer方法被执行,里面有这个定时器的全部信息,尤其是入参timestamp,这是原本设置的该定时器的触发时间;

验证

  1. 在控制台执行命令nc -l 9999,这样就可以从控制台向本机的9999端口发送字符串了;

  2. 在IDEA上直接执行ProcessTime类的main方法,程序运行就开始监听本机的9999端口了;

最后

各位读者,由于本篇幅度过长,为了避免影响阅读体验,下面我就大概概括了整理了

《一线大厂Java面试题解析+核心总结学习笔记+最新讲解视频+实战项目源码》点击传送门,即可获取!
c -l 9999,这样就可以从控制台向本机的9999端口发送字符串了;

  1. 在IDEA上直接执行ProcessTime类的main方法,程序运行就开始监听本机的9999端口了;

最后

各位读者,由于本篇幅度过长,为了避免影响阅读体验,下面我就大概概括了整理了

[外链图片转存中…(img-IUkL098N-1714477138341)]

[外链图片转存中…(img-Rn1U7S8D-1714477138341)]

[外链图片转存中…(img-vQ1akNj2-1714477138342)]

[外链图片转存中…(img-AZuu9EPP-1714477138342)]

《一线大厂Java面试题解析+核心总结学习笔记+最新讲解视频+实战项目源码》点击传送门,即可获取!

  • 9
    点赞
  • 12
    收藏
    觉得还不错? 一键收藏
  • 0
    评论
评论
添加红包

请填写红包祝福语或标题

红包个数最小为10个

红包金额最低5元

当前余额3.43前往充值 >
需支付:10.00
成就一亿技术人!
领取后你会自动成为博主和红包主的粉丝 规则
hope_wisdom
发出的红包
实付
使用余额支付
点击重新获取
扫码支付
钱包余额 0

抵扣说明:

1.余额是钱包充值的虚拟货币,按照1:1的比例进行支付金额的抵扣。
2.余额无法直接购买下载,可以购买VIP、付费专栏及课程。

余额充值