Flink处理函数实战之三:KeyedProcessFunction类,java消息中间件面试

Flink处理函数实战之三:KeyedProcessFunction类,java消息中间件面试,第1张

Flink处理函数实战之三:KeyedProcessFunction类,java消息中间件面试

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;

public class ProcessTime {

static class CountWithTimeoutFunction extends KeyedProcessFunction, Tuple2> {

// 自定义状态

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 value,

Context ctx,

Collector> 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)nn”,

currentKey.getField(0),

current.count,

current.lastModified,

time(current.lastModified),

timer,

time(timer)));

}

@Override

public void onTimer(

long timestamp,

onTimerContext ctx,

Collector> 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(result.key, result.count));

isTimeout = true;

}

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

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

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> timeOutWord = socketDataStream

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

.flatMap(new Splitter())

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

.assignTimestampsAndWatermarks(new AssignerWithPeriodicWatermarks>() {

@Override

public long extractTimestamp(Tuple2 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(tim

《一线大厂Java面试题解析+后端开发学习笔记+最新架构讲解视频+实战项目源码讲义》

【docs.qq.com/doc/DSmxTbFJ1cmN1R2dB】 完整内容开源分享

eStamp));

}

}

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

欢迎分享,转载请注明来源:内存溢出

原文地址: http://outofmemory.cn/zaji/5688527.html

(0)
打赏 微信扫一扫 微信扫一扫 支付宝扫一扫 支付宝扫一扫
上一篇 2022-12-17
下一篇 2022-12-17

发表评论

登录后才能评论

评论列表(0条)

保存