深入浅出Flink 12 之 Window操作

本文深入探讨Flink中的Keyed Windows,包括Tumbling和Sliding window函数,Trigger自定义,Evictor策略,增量聚合与全量聚合的实现,并介绍了window join的三种类型:Tumbling、Sliding和Session Window Join。
摘要由CSDN通过智能技术生成

1 Keyed Windows

stream
 .keyBy(...) <- keyed versus non-keyed windows
 .window(...) <- required: "assigner"
 [.trigger(...)] <- optional: "trigger" (else default
trigger)
 [.evictor(...)] <- optional: "evictor" (else no evictor)
 [.allowedLateness(...)] <- optional: "lateness" (else zero)
 [.sideOutputLateData(...)] <- optional: "output tag" (else no side
output for late data)
 .reduce/aggregate/fold/apply() <- required: "function"
 [.getSideOutput(...)] <- optional: "output tag"

Non-Keyed Windows

stream
 .windowAll(...) <- required: "assigner"
 [.trigger(...)] <- optional: "trigger" (else default
trigger)
 [.evictor(...)] <- optional: "evictor" (else no evictor)
 [.allowedLateness(...)] <- optional: "lateness" (else zero)
 [.sideOutputLateData(...)] <- optional: "output tag" (else no side
output for late data)
 .reduce/aggregate/fold/apply() <- required: "function"
 [.getSideOutput(...)] <- optional: "output tag"

1.1 window function

Tumbling window和slide window

//1:滚动窗⼝
 stream.keyBy(0)
		 .window(TumblingEventTimeWindows.of(Time.seconds(2)))
 		.sum(1)
		 .print();
 //2:滑动窗⼝
 stream.keyBy(0)
 	.window(SlidingProcessingTimeWindows.of(Time.seconds(6),Time.seconds(4)))
 	.sum(1)
	 .print();

需求:实时计算单词出现的次数,但是并不是每次接受到单词以后就输出单词出现的次数,⽽是当过了5秒以后没
收到这个单词,就输出这个单词的次数

解决问题的思路

1. 利⽤state存储key,count和key到达的时间
2. 没接收到⼀个单词,更新状态中的数据
3. 对于每个key都注册⼀个定时器,如果过了5秒没接收到这个key到话,那么就触发这个定时器,这个定
时器就判断当前的event time是否等于这个key的最后修改时间+5s,如果等于则输出key以及对应的
count

需求实现

/**
* 5秒没有单词输出,则输出该单词的单词次数
*/
public class KeyedProcessFunctionWordCount {
 public static void main(String[] args) throws Exception {
 // 1. 初始化⼀个流执⾏环境
 StreamExecutionEnvironment env =
 StreamExecutionEnvironment.createLocalEnvironmentWithWebUI(new
Configuration());

 // 设置每个 operator 的并⾏度
 env.setParallelism(1);
 
 // socket 数据源不是⼀个可以并⾏的数据源
 DataStreamSource<String> dataStreamSource =
 env.socketTextStream("localhost", 9999);
 
 // 3. Data Process
 // non keyed stream
 DataStream<Tuple2<String, Integer>> wordOnes =
 dataStreamSource.flatMap(new WordOneFlatMapFunction());
 
 // 3.2 按照单词进⾏分组, 聚合计算每个单词出现的次数
 // keyed stream
 KeyedStream<Tuple2<String, Integer>, Tuple> wordGroup = wordOnes
 .keyBy(0);
 
 wordGroup.process(new CountWithTimeoutFunction()).print();
 
 // 5. 启动并执⾏流程序
 env.execute("Streaming WordCount");
 }
private static class CountWithTimeoutFunction extends
KeyedProcessFunction<
Tuple, Tuple2<String, Integer>, Tuple2<String, Integer>> {
 private ValueState<CountWithTimestamp> state;
 
 @Override
 public void open(Configuration parameters) throws Exception {
 
 state = getRuntimeContext()
 		.getState(new ValueStateDescriptor<CountWithTimestamp>(
 "myState", CountWithTimestamp.class));
 
 }
/**
 * 处理每⼀个接收到的单词(元素)
 * @param element 输⼊元素
 * @param ctx 上下⽂
 * @param out ⽤于输出
 * @throws Exception
 */
 @Override
 public void processElement(Tuple2<String, Integer> element, Context
ctx,
 Collector<Tuple2<String, Integer>> out)
throws Exception {
 	// 拿到当前 key 的对应的状态
 CountWithTimestamp currentState = state.value();
 if (currentState == null) {
 		currentState = new CountWithTimestamp();
		 currentState.key = element.f0;
 }
	// 更新这个 key 出现的次数
 currentState.count++;
	 // 更新这个 key 到达的时间,最后修改这个状态时间为当前的 Processing Time
 currentState.lastModified =
ctx.timerService().currentProcessingTime();
 // 更新状态
		 state.update(currentState);
 // 注册⼀个定时器
 // 注册⼀个以 Processing Time 为准的定时器
 // 定时器触发的时间是当前 key 的最后修改时间加上 5 秒
 		ctx.timerService()
 			.registerProcessingTimeTimer(currentState.lastModified +
				5000);
 }
/**
 * 定时器需要运⾏的逻辑
 * @param timestamp 定时器触发的时间戳
* @param ctx 上下⽂
 * @param out ⽤于输出
 * @throws Exception
 */
 @Override
 public void onTimer(long timestamp, OnTimerContext ctx,
 Collector<Tuple2<String, Integer>> out) throws
Exception {
 		// 先拿到当前 key 的状态
 CountWithTimestamp curr = state.value();
 		// 检查这个 key 是不是 5 秒钟没有接收到数据
 if (timestamp == curr.lastModified + 5000) {
 			out.collect(Tuple2.of(curr.key, curr.count));
 			state.clear();
 		}
 }

 private static class CountWithTimestamp {
	 public String key;
	 public int count;
 	public long lastModified;
 }
 private static class WordOneFlatMapFunction
 implements FlatMapFunction<String, Tuple2<Strin
  • 0
    点赞
  • 1
    收藏
    觉得还不错? 一键收藏
  • 0
    评论
评论
添加红包

请填写红包祝福语或标题

红包个数最小为10个

红包金额最低5元

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

抵扣说明:

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

余额充值