当前位置:   article > 正文

【flink番外篇】5、flink的window(介绍、分类、函数及Tumbling、Sliding、session窗口应用)介绍及示例 - 完整版_flink window

flink window



文章目录
  • Flink 系列文章
  • 一、Flink的window介绍
  • 1、window介绍
  • 2、window API
  • 1)、WindowAssigner
  • 2)、Trigger
  • 3)、Evictor
  • 3、window的生命周期
  • 二、window的分类
  • 1、Tumbling Windows
  • 2、Sliding Windows
  • 3、Session Windows
  • 4、Global Windows
  • 5、按照时间time和数量count分类
  • 6、按照滑动间隔slide和窗口大小size分类
  • 三、窗口函数
  • 1、ReduceFunction
  • 2、AggregateFunction
  • 3、ProcessWindowFunction
  • 4、ProcessWindowFunction with Incremental Aggregation
  • 1)、Incremental Window Aggregation with ReduceFunction
  • 2)、Incremental Window Aggregation with AggregateFunction
  • 四、maven依赖
  • 五、示例:基于时间的滚动和滑动窗口
  • 1、滚动窗口实现统计地铁进站口人数
  • 1)、一般实现(Tuple2数据结构)及验证
  • 2)、面向对象实现(pojo数据结构)及验证
  • 3)、面向对象lambda实现(pojo的数据结构lambda)及验证
  • 4)、一般lambda实现(Tuple2数据结构)及验证
  • 2、滑动窗口实现统计地铁进站口人数
  • 1)、一般实现(Tuple2数据结构)及验证
  • 2)、面向对象实现(pojo数据结构)及验证
  • 六、示例:基于数量的滚动窗口与滑动窗口
  • 1、滚动窗口实现地铁进站口人数
  • 1)、实现
  • 2)、验证步骤
  • 2、滑动窗口实现地铁进站口人数
  • 1)、实现
  • 2)、验证步骤
  • 七、示例:会话窗口
  • 1、实现
  • 2、验证步骤



本文介绍了Flink window的分类以及三个示例分别实现滚动、滑动以及会话窗口,即基于时间和基于数量的滚动窗口与滑动窗口、会话窗口,其中包含详细的验证步骤与验证结果。

一、Flink的window介绍

1、window介绍

Windows是处理无限流的核心。Windows将流划分为有限大小的“buckets”,我们可以在其上进行计算。

窗口Flink程序的一般结构如下所示。第一个片段指的是键控流,而第二个片段指非键控流。可以看出,唯一的区别是对键控流的keyBy(…)调用和对非键控流变为windowAll(…)的window(…)。这也将作为页面其余部分的路线图。

流计算中一般在对流数据进行操作之前都会先进行开窗,即基于一个什么样的窗口上做这个计算。Flink提供了开箱即用的各种窗口,比如滑动窗口、滚动窗口、会话窗口以及非常灵活的自定义的窗口。

在流处理应用中,数据是连续不断的,有时需要做一些聚合类的处理,例如在过去的1分钟内有多少用户点击了我们的网页。
在这种情况下,必须定义一个窗口(window),用来收集最近1分钟内的数据,并对这个窗口内的数据进行计算。

2、window API

  • 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"
  • 1
  • 2
  • 3
  • 4
  • 5
  • 6
  • 7
  • 8
  • 1
  • 2
  • 3
  • 4
  • 5
  • 6
  • 7
  • 8
  • 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
  • 2
  • 3
  • 4
  • 5
  • 6
  • 7
  • 1
  • 2
  • 3
  • 4
  • 5
  • 6
  • 7

在上文中,方括号([…])中的命令是可选的。

使用keyby的流,应该使用window方法

未使用keyby的流,应该调用windowAll方法

1)、WindowAssigner

window/windowAll 方法接收的输入是一个 WindowAssigner, WindowAssigner 负责将每条输入的数据分发到正确的 window 中,Flink提供了很多各种场景用的WindowAssigner:

如果需要自己定制数据分发策略,则可以实现一个 class,继承自 WindowAssigner。

2)、Trigger

trigger 用来判断一个窗口是否需要被触发,每个 WindowAssigner 都自带一个默认的trigger,如果默认的 trigger 不能满足你的需求,则可以自定义一个类,继承自Trigger 即可。

  • onElement()
  • onEventTime()
  • onProcessingTime()
    此抽象类的这三个方法会返回一个 TriggerResult, TriggerResult 有如下几种可能的选择:
  • CONTINUE 不做任何事情
  • FIRE 触发 window
  • PURGE 清空整个 window 的元素并销毁窗口
  • FIRE_AND_PURGE 触发窗口,然后销毁窗口
3)、Evictor

evictor 主要用于做一些数据的自定义操作,可以在执行用户代码之前,也可以在执行用户代码之后。

  • evictBefore() 包含要在窗口函数之前应用的eviction逻辑,而evictAfter()包含将在窗口函数之后应用的逻辑。在应用窗口函数之前eviction的元素将不会被它处理。
  • CountEvictor:保留窗口中最多用户指定数量的元素,并丢弃窗口缓冲区开头的剩余元素。
  • DeltaEvictor:取一个DeltaFunction和一个阈值,计算窗口缓冲区中最后一个元素和其余元素之间的增量,并删除增量大于或等于阈值的元素。
  • TimeEvictor:以毫秒为单位的间隔作为参数,对于给定的窗口,它在其元素中找到最大时间戳max_ts,并删除所有时间戳小于max_ts-interval的元素。

Flink 提供了如下三种通用的 evictor:

  • CountEvictor 保留指定数量的元素
    TimeEvictor 设定一个阈值 interval,删除所有不再 max_ts - interval 范围内的元素,其中 max_ts 是窗口内时间戳的最大值
  • DeltaEvictor 通过执行用户给定的 DeltaFunction 以及预设的 theshold,判断是否删除一个元素。

3、window的生命周期

应该属于该窗口的第一个元素到达后,就会立即创建一个窗口,并且当时间(事件或处理时间)超过其结束时间戳加上用户指定的允许延迟时,该窗口将被完全删除(请参阅允许延迟)。

Flink只保证删除基于时间的窗口,而不保证删除其他类型的窗口,例如全局窗口(请参见窗口分配器)。

例如,使用基于事件时间的窗口策略,该策略每5分钟创建一个不重叠(或滚动)的窗口,并且允许的延迟为1分钟,当时间戳位于该时间间隔内的第一个元素到达时,Flink将为12:00到12:05之间的时间间隔创建一个新窗口,并且当水印超过12:06时间戳时,它将删除该窗口。

此外,每个窗口都将有一个触发器(请参阅触发器)和一个附加的函数(ProcessWindowFunction、ReduceFunction或AggregateFunction)(请参阅窗口函数)。

该函数将包含要应用于窗口内容的计算,而触发器指定了窗口被视为准备应用该函数的条件。

触发策略可能类似于“当窗口中的元素数超过4时”,或者“当水印经过窗口末尾时”。

触发器还可以决定在创建和删除窗口之间的任何时间清除窗口的内容。在这种情况下,清除仅指窗口中的元素,而不是窗口元数据。

这意味着仍然可以向该窗口添加新数据。

除此之外,您还可以指定一个Evictor,该Evictor能够在触发器触发后以及应用该函数之前和/或之后从窗口中删除元素。

简单的说,当有第一个属于该window的元素到达时就创建了一个window,当时间或事件触发该windowremoved的时候则结束。每个window都有一个Trigger和一个Function,function用于计算,trigger用于触发window条件。同时也可以使用Evictor在Trigger触发前后对window的元素进行处理。

二、window的分类

结合实际的业务应用选择适用的接口很重要,一般而言,TumblingTimeWindows、SlidingTimeWindows需要重点关注,而EventTimeSessionWindows和ProcessingTimeSessionWindows是Flink的session会话窗口,需要设置会话超时时间,如果超时则触发window计算。Flink 1.17版本已经实现的窗口见图。

【flink番外篇】5、flink的window(介绍、分类、函数及Tumbling、Sliding、session窗口应用)介绍及示例 - 完整版_flink

具体分类以及使用场景如下。

1、Tumbling Windows

滚动窗口分配器(Tumbling windows assigner)将每个元素分配给指定窗口大小的窗口。滚动窗口具有固定大小,不会重叠。例如,如果指定大小为 5 分钟的滚动窗口,则将评估当前窗口,并且每 5 分钟启动一个新窗口,如下图所示。

【flink番外篇】5、flink的window(介绍、分类、函数及Tumbling、Sliding、session窗口应用)介绍及示例 - 完整版_flink hive_02


示例代码

登录后复制
DataStream<T> input = ...;
  • 1
  • 1

// tumbling event-time windows
input
.keyBy(<key selector>)
.window(TumblingEventTimeWindows.of(Time.seconds(5)))
.<windowed transformation>(<window function>);

// tumbling processing-time windows
input
.keyBy(<key selector>)
.window(TumblingProcessingTimeWindows.of(Time.seconds(5)))
.<windowed transformation>(<window function>);

// daily tumbling event-time windows offset by -8 hours.
input
.keyBy(<key selector>)
.window(TumblingEventTimeWindows.of(Time.days(1), Time.hours(-8)))
.<windowed transformation>(<window function>);

2、Sliding Windows

滑动窗口分配器(sliding windows assigner)将元素分配给固定长度的窗口。与滚动窗口分配器类似,窗口的大小由窗口大小参数配置。窗口滑动参数控制滑动窗口的启动频率。因此,如果 sliding小于size,则滑动窗口可能会重叠。在这种情况下,元素被分配给多个窗口。例如,可以有大小为 10 分钟的窗口,该窗口滑动 5 分钟。这样,您每 5 分钟就会得到一个窗口,其中包含过去 10 分钟内到达的事件,如下图所示。

【flink番外篇】5、flink的window(介绍、分类、函数及Tumbling、Sliding、session窗口应用)介绍及示例 - 完整版_flink sql_03


示例代码

ataStream<T> input = …;
  • 1
  • 1

// sliding event-time windows
input
.keyBy(<key selector>)
.window(SlidingEventTimeWindows.of(Time.seconds(10), Time.seconds(5)))
.<windowed transformation>(<window function>);

// sliding processing-time windows
input
.keyBy(<key selector>)
.window(SlidingProcessingTimeWindows.of(Time.seconds(10), Time.seconds(5)))
.<windowed transformation>(<window function>);

// sliding processing-time windows offset by -8 hours
input
.keyBy(<key selector>)
.window(SlidingProcessingTimeWindows.of(Time.hours(12), Time.hours(1), Time.hours(-8)))
.<windowed transformation>(<window function>);

3、Session Windows

会话窗口分配器(session windows assigner)按活动会话对元素进行分组。与滚动窗口和滑动窗口相比,会话窗口不重叠,也没有固定的开始和结束时间。相反,当会话窗口在一段时间内未收到元素时(即,当出现不活动间隙时),会话窗口将关闭。会话窗口分配器可以配置静态会话间隙或会话间隙提取器功能,该函数定义不活动时间的时间。当此时间段到期时,当前会话将关闭,后续元素将分配给新的会话窗口。

会话窗口分配器按活动会话对元素进行分组。

与滚动窗口和滑动窗口不同,会话窗口不重叠,也没有固定的开始和结束时间。

相反,当会话窗口在一定时间段内没有接收到元素时,即,当出现不活动间隙时,会话窗口将关闭。

会话窗口分配器可以配置有静态会话间隙,也可以配置有会话间隙提取器功能,该功能定义不活动时段的长度。

当这段时间到期时,当前会话将关闭,随后的元素将分配给新的会话窗口。

【flink番外篇】5、flink的window(介绍、分类、函数及Tumbling、Sliding、session窗口应用)介绍及示例 - 完整版_flink sql_04

示例代码

DataStream<T> input = …;
  • 1
  • 1

// event-time session windows with static gap
input
.keyBy(<key selector>)
.window(EventTimeSessionWindows.withGap(Time.minutes(10)))
.<windowed transformation>(<window function>);

// event-time session windows with dynamic gap
input
.keyBy(<key selector>)
.window(EventTimeSessionWindows.withDynamicGap((element) -> {
// determine and return session gap
}))
.<windowed transformation>(<window function>);

// processing-time session windows with static gap
input
.keyBy(<key selector>)
.window(ProcessingTimeSessionWindows.withGap(Time.minutes(10)))
.<windowed transformation>(<window function>);

// processing-time session windows with dynamic gap
input
.keyBy(<key selector>)
.window(ProcessingTimeSessionWindows.withDynamicGap((element) -> {
// determine and return session gap
}))
.<windowed transformation>(<window function>);

由于会话窗口没有固定的开始和结束,因此它们的计算方式与翻转和滑动窗口不同。在内部,会话窗口运算符为每个到达记录创建一个新窗口,如果窗口彼此靠近而不是定义的间隙,则将它们合并在一起。为了可合并,会话窗口运算符需要一个合并触发器和一个合并窗口函数,例如 ReduceFunction、AggregateFunction 或 ProcessWindowFunction。

4、Global Windows

全局窗口分配器(global windows assigner)将具有相同键的所有元素分配给同一个全局窗口。只有自己自定义触发器的时候该窗口才能使用。否则,将不会执行任何计算,因为全局窗口没有一个自然的终点,我们可以在该端点处理聚合元素。

【flink番外篇】5、flink的window(介绍、分类、函数及Tumbling、Sliding、session窗口应用)介绍及示例 - 完整版_flink sql_05

示例代码

登录后复制
DataStream<T> input = …;
  • 1
  • 1

input
.keyBy(<key selector>)
.window(GlobalWindows.create())
.<windowed transformation>(<window function>);

5、按照时间time和数量count分类

  • time-window,时间窗口,根据时间划分窗口,如:每xx小时统计最近xx小时的数据
  • count-window,数量窗口,根据数量划分窗口,如:每xx条/行数据统计最近xx条/行数据

【flink番外篇】5、flink的window(介绍、分类、函数及Tumbling、Sliding、session窗口应用)介绍及示例 - 完整版_大数据_06

6、按照滑动间隔slide和窗口大小size分类

  • tumbling-window,滚动窗口,size=slide,如,每隔10s统计最近10s的数据
  • 【flink番外篇】5、flink的window(介绍、分类、函数及Tumbling、Sliding、session窗口应用)介绍及示例 - 完整版_大数据_07

  • sliding-window,滑动窗口,size>slide,如,每隔5s统计最近10s的数据
  • 【flink番外篇】5、flink的window(介绍、分类、函数及Tumbling、Sliding、session窗口应用)介绍及示例 - 完整版_flink hive_08

当size<slide的时候,如每隔15s统计最近10s的数据,会有数据丢失,视具体情况而定是否使用

三、窗口函数

定义窗口分配器(window assigner)后,需要指定要在每个窗口上执行的计算。这是 window 函数的职责,一旦系统确定窗口已准备好处理,它就用于处理每个(可能是keyed)窗口的元素。

window 函数有 ReduceFunction、AggregateFunction 或 ProcessWindowFunction 。前两个可以更有效地执行,因为 Flink 可以在每个窗口到达时增量聚合元素。ProcessWindowFunction 获取窗口中包含的所有元素的可迭代对象,以及有关元素所属窗口的其他元信息。

使用 ProcessWindowFunction 的窗口化转换不能像其他情况那样有效地执行,因为 Flink 在调用函数之前必须在内部缓冲窗口的所有元素。通过将 ProcessWindowFunction 与 ReduceFunction 或 AggregateFunction 结合使用来获取窗口元素的增量聚合和 ProcessWindowFunction 接收的其他窗口元数据,可以缓解此问题。

1、ReduceFunction

ReduceFunction 指定如何将输入中的两个元素组合在一起以生成相同类型的输出元素。Flink 使用 ReduceFunction 以增量方式聚合窗口的元素。

  • 代码示例-计算2个字段的和
登录后复制
DataStream<Tuple2<String, Long>> input = …;
  • 1
  • 1

input
.keyBy(<key selector>)
.window(<window assigner>)
.reduce(new ReduceFunction<Tuple2<String, Long>> {
public Tuple2<String, Long> reduce(Tuple2<String, Long> v1, Tuple2<String, Long> v2) {
return new Tuple2<>(v1.f0, v1.f1 + v2.f1);
}
});

2、AggregateFunction

聚合函数是 ReduceFunction 的通用版本,具有三种类型:输入类型 (IN)、累加器类型 (ACC) 和输出类型 (OUT)。输入类型是输入流中的元素类型,AggregateFunction 具有将一个输入元素添加到累加器的方法。该接口还具有用于创建初始累加器、将两个累加器合并为一个累加器以及从累加器中提取输出(OUT 类型)的方法。与 ReduceFunction 相同,Flink 将在窗口的输入元素到达时增量聚合它们。

  • 代码示例-计算两个字段的平均值
登录后复制
private static class AverageAggregate
implements AggregateFunction<Tuple2<String, Long>, Tuple2<Long, Long>, Double> {
@Override
public Tuple2<Long, Long> createAccumulator() {
return new Tuple2<>(0L, 0L);
}
  • 1
  • 2
  • 3
  • 4
  • 5
  • 6
  • 1
  • 2
  • 3
  • 4
  • 5
  • 6

@Override
public Tuple2<Long, Long> add(Tuple2<String, Long> value, Tuple2<Long, Long> accumulator) {
return new Tuple2<>(accumulator.f0 + value.f1, accumulator.f1 + 1L);
}

@Override
public Double getResult(Tuple2<Long, Long> accumulator) {
return ((double) accumulator.f0) / accumulator.f1;
}

@Override
public Tuple2<Long, Long> merge(Tuple2<Long, Long> a, Tuple2<Long, Long> b) {
return new Tuple2<>(a.f0 + b.f0, a.f1 + b.f1);
}
}

DataStream<Tuple2<String, Long>> input = …;

input
.keyBy(<key selector>)
.window(<window assigner>)
.aggregate(new AverageAggregate());

3、ProcessWindowFunction

ProcessWindowFunction 获取一个包含窗口所有元素的 Iterable,以及一个可以访问时间和状态信息的 Context 对象,这使其能够提供比其他窗口函数更大的灵活性。这是以性能和资源消耗为代价的,因为元素不能增量聚合,而是需要在内部缓冲,直到窗口被认为准备好进行处理。

  • 代码示例-统计个数
登录后复制
DataStream<Tuple2<String, Long>> input = …;
  • 1
  • 1

input
.keyBy(t -> t.f0)
.window(TumblingEventTimeWindows.of(Time.minutes(5)))
.process(new MyProcessWindowFunction());

/* … */

public class MyProcessWindowFunction
extends ProcessWindowFunction<Tuple2<String, Long>, String, String, TimeWindow> {

@Override
public void process(String key, Context context, Iterable<Tuple2<String, Long>> input, Collector<String> out) {
long count = 0;
for (Tuple2<String, Long> in: input) {
count++;
}
out.collect("Window: " + context.window() + "count: " + count);
}
}

将 ProcessWindowFunction 用于简单的聚合(如计数)效率非常低。一般是将 ReduceFunction 或 AggregateFunction 与 ProcessWindowFunction 结合使用,以获取增量聚合和 ProcessWindowFunction 的添加信息。

4、ProcessWindowFunction with Incremental Aggregation

ProcessWindowFunction 可以与 ReduceFunction 或 AggregateFunction 结合使用,以便在元素到达窗口时以增量方式聚合元素。当窗口关闭时,将向进程窗口函数提供聚合结果。这允许它以增量方式计算窗口,同时可以访问 ProcessWindowFunction 的其他窗口元信息。

1)、Incremental Window Aggregation with ReduceFunction

下面的示例演示如何将增量 ReduceFunction 与 ProcessWindowFunction 结合使用,以返回窗口中的最小事件以及窗口的开始时间。

登录后复制
DataStream<SensorReading> input = …;
  • 1
  • 1

input
.keyBy(<key selector>)
.window(<window assigner>)
.reduce(new MyReduceFunction(), new MyProcessWindowFunction());

// Function definitions

private static class MyReduceFunction implements ReduceFunction<SensorReading> {

public SensorReading reduce(SensorReading r1, SensorReading r2) {
return r1.value() > r2.value() ? r2 : r1;
}
}

private static class MyProcessWindowFunction
extends ProcessWindowFunction<SensorReading, Tuple2<Long, SensorReading>, String, TimeWindow> {

public void process(String key,
Context context,
Iterable<SensorReading> minReadings,
Collector<Tuple2<Long, SensorReading>> out) {
SensorReading min = minReadings.iterator().next();
out.collect(new Tuple2<Long, SensorReading>(context.window().getStart(), min));
}
}

2)、Incremental Window Aggregation with AggregateFunction

下面的示例演示如何将增量聚合函数与 ProcessWindowFunction 结合使用以计算平均值,并发出键和窗口以及平均值。

登录后复制
DataStream<Tuple2<String, Long>> input = …;
  • 1
  • 1

input
.keyBy(<key selector>)
.window(<window assigner>)
.aggregate(new AverageAggregate(), new MyProcessWindowFunction());

// Function definitions

/**

  • The accumulator is used to keep a running sum and a count. The {@code getResult} method
  • computes the average.
    */
    private static class AverageAggregate
    implements AggregateFunction<Tuple2<String, Long>, Tuple2<Long, Long>, Double> {
    @Override
    public Tuple2<Long, Long> createAccumulator() {
    return new Tuple2<>(0L, 0L);
    }

@Override
public Tuple2<Long, Long> add(Tuple2<String, Long> value, Tuple2<Long, Long> accumulator) {
return new Tuple2<>(accumulator.f0 + value.f1, accumulator.f1 + 1L);
}

@Override
public Double getResult(Tuple2<Long, Long> accumulator) {
return ((double) accumulator.f0) / accumulator.f1;
}

@Override
public Tuple2<Long, Long> merge(Tuple2<Long, Long> a, Tuple2<Long, Long> b) {
return new Tuple2<>(a.f0 + b.f0, a.f1 + b.f1);
}
}

private static class MyProcessWindowFunction
extends ProcessWindowFunction<Double, Tuple2<String, Double>, String, TimeWindow> {

public void process(String key,
Context context,
Iterable<Double> averages,
Collector<Tuple2<String, Double>> out) {
Double average = averages.iterator().next();
out.collect(new Tuple2<>(key, average));
}
}

四、maven依赖

登录后复制
<properties>
<encoding>UTF-8</encoding>
<project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>
<maven.compiler.source>1.8</maven.compiler.source>
<maven.compiler.target>1.8</maven.compiler.target>
<java.version>1.8</java.version>
<scala.version>2.12</scala.version>
<flink.version>1.17.0</flink.version>
</properties>
<dependencies>
<dependency>
<groupId>org.apache.flink</groupId>
<artifactId>flink-clients_2.12</artifactId>
<version>KaTeX parse error: Expected 'EOF', got '&' at position 16: {flink.version}&̲lt;/version&gt;…{flink.version}</version>
</dependency>
<dependency>
<groupId>org.apache.flink</groupId>
<artifactId>flink-java</artifactId>
<version>KaTeX parse error: Expected 'EOF', got '&' at position 16: {flink.version}&̲lt;/version&gt;…{flink.version}</version>
</dependency>
<dependency>
<groupId>org.apache.flink</groupId>
<artifactId>flink-streaming-java_2.12</artifactId>
<version>${flink.version}</version>
</dependency>
  • 1
  • 2
  • 3
  • 4
  • 5
  • 6
  • 7
  • 8
  • 9
  • 10
  • 11
  • 12
  • 13
  • 14
  • 15
  • 16
  • 17
  • 18
  • 19
  • 20
  • 21
  • 22
  • 23
  • 24
  • 1
  • 2
  • 3
  • 4
  • 5
  • 6
  • 7
  • 8
  • 9
  • 10
  • 11
  • 12
  • 13
  • 14
  • 15
  • 16
  • 17
  • 18
  • 19
  • 20
  • 21
  • 22
  • 23
  • 24

    &lt;!-- 日志 --&gt;
    &lt;dependency&gt;
        &lt;groupId&gt;org.slf4j&lt;/groupId&gt;
        &lt;artifactId&gt;slf4j-log4j12&lt;/artifactId&gt;
        &lt;version&gt;1.7.7&lt;/version&gt;
        &lt;scope&gt;runtime&lt;/scope&gt;
    &lt;/dependency&gt;
    &lt;dependency&gt;
        &lt;groupId&gt;log4j&lt;/groupId&gt;
        &lt;artifactId&gt;log4j&lt;/artifactId&gt;
        &lt;version&gt;1.2.17&lt;/version&gt;
        &lt;scope&gt;runtime&lt;/scope&gt;
    &lt;/dependency&gt;
    &lt;dependency&gt;
        &lt;groupId&gt;org.projectlombok&lt;/groupId&gt;
        &lt;artifactId&gt;lombok&lt;/artifactId&gt;
        &lt;version&gt;1.18.2&lt;/version&gt;
        &lt;scope&gt;provided&lt;/scope&gt;
    &lt;/dependency&gt;
&lt;/dependencies&gt;</code></pre></div><div class="toolbar"></div></div></div><h2 id="h23">五、示例:基于时间的滚动和滑动窗口</h2><h3 id="h24">1、滚动窗口实现统计地铁进站口人数</h3><p>实现:每10s统计一次地铁进站每个入口人数,最近10s每个进站口的人数</p><h4 id="h25">1)、一般实现(Tuple2数据结构)及验证</h4><div><div class="code-toolbar"><div class="hljs-cto"><div class="operation_box"><button data-clipboard-target="#code_id_12" class="copy_btn disable">登录后复制</button> <a title="登录后一键下载全文代码" class="downloadCode"><i class="iconblog blogimport  "></i></a> </div><pre class="language-plain prettyprint" tabindex="0"><code class="language-plain has-numbering" id="code_id_12">import org.apache.flink.api.common.RuntimeExecutionMode;
  • 1
  • 2
  • 3
  • 4
  • 5
  • 6
  • 7
  • 8
  • 9
  • 10
  • 11
  • 12
  • 13
  • 14
  • 15
  • 16
  • 17
  • 18
  • 19
  • 20

import org.apache.flink.api.common.functions.MapFunction;
import org.apache.flink.api.common.functions.ReduceFunction;
import org.apache.flink.api.java.tuple.Tuple;
import org.apache.flink.api.java.tuple.Tuple2;
import org.apache.flink.streaming.api.datastream.DataStream;
import org.apache.flink.streaming.api.datastream.KeyedStream;
import org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator;
import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment;
import org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows;
import org.apache.flink.streaming.api.windowing.time.Time;
import org.apache.flink.api.java.functions.KeySelector;

/**

  • @author alanchan
  • 基于滚动窗口的入门示例
  • 每10s统计一次地铁进站每个入口人数,最近10s每个进站口的人数
  • size=slide

*/
public class TumblingTimeWindowsDemo1 {

/**
 * @param args
 * @throws Exception
 */
public static void main(String[] args) throws Exception {
	// env
	StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
	env.setRuntimeMode(RuntimeExecutionMode.AUTOMATIC);

	// source
	// nc
	// 数据结构: 入口编号,人数
	// 12,50
	// 11,28
	DataStream&lt;String&gt; lines = env.socketTextStream("192.168.10.42", 9999);
	
	// transformation
	DataStream&lt;Tuple2&lt;String, Integer&gt;&gt; subwayExit = lines.map(new MapFunction&lt;String, Tuple2&lt;String, Integer&gt;&gt;() {

		@Override
		public Tuple2&lt;String, Integer&gt; map(String line) throws Exception {
			String[] arr = line.split(",");

			return Tuple2.of(arr[0], Integer.parseInt(arr[1]));
		}
	});
	
	//按照地铁口分组
  • 1
  • 2
  • 3
  • 4
  • 5
  • 6
  • 7
  • 8
  • 9
  • 10
  • 11
  • 12
  • 13
  • 14
  • 15
  • 16
  • 17
  • 18
  • 19
  • 20
  • 21
  • 22
  • 23
  • 24
  • 25
  • 26
  • 27
  • 28

// KeyedStream<Tuple2<String, Integer>, String> keyedDS = subwayExit.keyBy(new KeySelector<Tuple2<String, Integer>, String>() {
// @Override
// public String getKey(Tuple2<String, Integer> value) throws Exception {
// return value.f0;
// }
// });
//另外一种分组方式
KeyedStream<Tuple2<String, Integer>, Tuple> keyedDS = subwayExit.keyBy(0);

	DataStream&lt;Tuple2&lt;String, Integer&gt;&gt; result1 = keyedDS.window(TumblingProcessingTimeWindows.of(Time.seconds(10)))
			//另外一种聚合方式实现
  • 1
  • 2

// .reduce(new ReduceFunction<Tuple2<String, Integer>>() {
//
// @Override
// public Tuple2<String, Integer> reduce(Tuple2<String, Integer> value1, Tuple2<String, Integer> value2) throws Exception {
//
// return Tuple2.of(value1.f0, value1.f1 + value2.f1);
// }
//
// });
.sum(1);

	// sink
	result1.print();

	// execute
	env.execute();
}
  • 1
  • 2
  • 3
  • 4
  • 5
  • 6

}

验证步骤

  • 1、启动nc
登录后复制
nc -lk 9999
     
     
  • 1.
    • 1
    • 2
    • 2、启动应用程序
    • 3、nc控制台输入
    登录后复制
    [alanchan@server2 src]$ nc -lk 9999
    no1,1
    no2,1
    no1,2
    no1,3
    no2,6
    • 1.
    • 2.
    • 3.
    • 4.
    • 5.
    • 6.
    • 1
    • 2
    • 3
    • 4
    • 5
    • 1
    • 2
    • 3
    • 4
    • 5
    • 6
    • 7
    • 4、查看应用程序控制台输出
    2)、面向对象实现(pojo数据结构)及验证
    • bean
    登录后复制
    import lombok.AllArgsConstructor;
    import lombok.Data;
    import lombok.NoArgsConstructor;
    • 1
    • 2
    • 3
    • 1
    • 2
    • 3

    /**

    • @author alanchan

    */
    @Data
    @AllArgsConstructor
    @NoArgsConstructor
    public class SubWay {
    // 地铁站进站口
    private String No;
    // 某一时段人数
    private Integer userCount;
    }

    • 1.
    • 2.
    • 3.
    • 4.
    • 5.
    • 6.
    • 7.
    • 8.
    • 9.
    • 10.
    • 11.
    • 12.
    • 13.
    • 14.
    • 15.
    • 16.
    • 17.
    • 实现
    登录后复制
    import org.apache.flink.api.common.RuntimeExecutionMode;
    import org.apache.flink.api.common.functions.MapFunction;
    import org.apache.flink.api.java.functions.KeySelector;
    import org.apache.flink.streaming.api.datastream.DataStream;
    import org.apache.flink.streaming.api.datastream.KeyedStream;
    import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment;
    import org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows;
    import org.apache.flink.streaming.api.windowing.time.Time;
    • 1
    • 2
    • 3
    • 4
    • 5
    • 6
    • 7
    • 1
    • 2
    • 3
    • 4
    • 5
    • 6
    • 7

    /**

    • @author alanchan
    • 基于滚动窗口的入门示例
    • 每10s统计一次地铁进站每个入口人数,最近10s每个进站口的人数
    • size=slide

    */
    public class TumblingTimeWindowsDemo2 {

    /**
     * @param args
     * @throws Exception
     */
    public static void main(String[] args) throws Exception {
    	// env
    	StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
    	env.setRuntimeMode(RuntimeExecutionMode.AUTOMATIC);
    
    	// source
    	// nc
    	// 数据结构: 入口编号,人数
    	// 12,50
    	// 11,28
    	DataStream&lt;String&gt; lines = env.socketTextStream("192.168.10.42", 9999);
    
    	// transformation
    	DataStream&lt;Subway&gt; subwayExit = lines.map(new MapFunction&lt;String, Subway&gt;() {
    
    		@Override
    		public Subway map(String line) throws Exception {
    			String[] arr = line.split(",");
    
    			return new Subway(arr[0], Integer.parseInt(arr[1]));
    		}
    	});
    
    	// 按照地铁口分组
    	KeyedStream&lt;Subway, String&gt; keyedDS = subwayExit.keyBy(new KeySelector&lt;Subway, String&gt;() {
    		@Override
    		public String getKey(Subway value) throws Exception {
    			return value.getNo();
    		}
    	});
    	
    	//userCount是Subway的属性名称
    	DataStream&lt;Subway&gt; result = keyedDS.window(TumblingProcessingTimeWindows.of(Time.seconds(10))).sum("userCount");
    	// sink
    	result.print();
    
    	// execute
    	env.execute();
    }
    
    • 1
    • 2
    • 3
    • 4
    • 5
    • 6
    • 7
    • 8
    • 9
    • 10
    • 11
    • 12
    • 13
    • 14
    • 15
    • 16
    • 17
    • 18
    • 19
    • 20
    • 21
    • 22
    • 23
    • 24
    • 25
    • 26
    • 27
    • 28
    • 29
    • 30
    • 31
    • 32
    • 33
    • 34
    • 35
    • 36
    • 37
    • 38
    • 39
    • 40
    • 41
    • 42
    • 43

    }

    • 1.
    • 2.
    • 3.
    • 4.
    • 5.
    • 6.
    • 7.
    • 8.
    • 9.
    • 10.
    • 11.
    • 12.
    • 13.
    • 14.
    • 15.
    • 16.
    • 17.
    • 18.
    • 19.
    • 20.
    • 21.
    • 22.
    • 23.
    • 24.
    • 25.
    • 26.
    • 27.
    • 28.
    • 29.
    • 30.
    • 31.
    • 32.
    • 33.
    • 34.
    • 35.
    • 36.
    • 37.
    • 38.
    • 39.
    • 40.
    • 41.
    • 42.
    • 43.
    • 44.
    • 45.
    • 46.
    • 47.
    • 48.
    • 49.
    • 50.
    • 51.
    • 52.
    • 53.
    • 54.
    • 55.
    • 56.
    • 57.
    • 58.
    • 59.
    • 60.
    • 61.
    • 62.
    • 63.
    • 验证步骤
      1、启动nc
    登录后复制
    nc -lk 9999
         
         
    • 1.
      • 1
      • 2

      2、启动应用程序

      3、nc控制台输入

      登录后复制
      [alanchan@server2 src]$ nc -lk 9999
      no,1
      no2,1
      no2,4
      no1,2
      • 1.
      • 2.
      • 3.
      • 4.
      • 5.
      • 1
      • 2
      • 3
      • 4
      • 1
      • 2
      • 3
      • 4
      • 5
      • 6

      4、查看应用程序控制台输出

      【flink番外篇】5、flink的window(介绍、分类、函数及Tumbling、Sliding、session窗口应用)介绍及示例 - 完整版_flink sql_09

      3)、面向对象lambda实现(pojo的数据结构lambda)及验证

      Subway的bean参考上文示例中的内容。

      登录后复制
      import java.util.Arrays;
      
      • 1
      • 1

      import org.apache.flink.api.common.RuntimeExecutionMode;
      import org.apache.flink.api.common.functions.MapFunction;
      import org.apache.flink.api.common.typeinfo.Types;
      import org.apache.flink.api.java.tuple.Tuple2;
      import org.apache.flink.streaming.api.datastream.DataStream;
      import org.apache.flink.streaming.api.datastream.KeyedStream;
      import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment;
      import org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows;
      import org.apache.flink.streaming.api.windowing.time.Time;
      import org.apache.flink.util.Collector;
      import org.apache.flink.api.common.typeinfo.Types;

      /**

      • @author alanchan

      */
      public class TumblingTimeWindowsDemo3 {

      /**
       * @param args
       * @throws Exception
       */
      public static void main(String[] args) throws Exception {
      	// env
      	StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
      	env.setRuntimeMode(RuntimeExecutionMode.AUTOMATIC);
      
      	// source
      	// nc
      	// 数据结构: 入口编号,人数
      	// 12,50
      	// 11,28
      	DataStream&lt;String&gt; lines = env.socketTextStream("192.168.10.42", 9999);
      
      	// transformation
      
      • 1
      • 2
      • 3
      • 4
      • 5
      • 6
      • 7
      • 8
      • 9
      • 10
      • 11
      • 12
      • 13
      • 14
      • 15
      • 16
      • 17

      // DataStream<Subway> subwayExit = lines.map(new MapFunction<String, Subway>() {
      //
      // @Override
      // public Subway map(String line) throws Exception {
      // String[] arr = line.split(“,”);
      // return new Subway(arr[0], Integer.parseInt(arr[1]));
      // }
      // });
      DataStream<Subway> subwayExit = lines.map(new Splitter());

      	// 按照地铁口分组
      	KeyedStream&lt;Subway, String&gt; keyedDS = subwayExit.keyBy(Subway::getNo);
      	// subwayExit.keyBy(subway-&gt;subway.getNo())
      
      	DataStream&lt;Subway&gt; result = keyedDS.window(TumblingProcessingTimeWindows.of(Time.seconds(10))).sum("userCount");
      	
      	// sink
      	result.print();
      
      	// execute
      	env.execute();
      }
      
      public static class Splitter implements MapFunction&lt;String, Subway&gt; {
      	@Override
      	public Subway map(String value) {
      		String[] arr = value.split(",");
      		return new Subway(arr[0], Integer.parseInt(arr[1]));
      	}
      }
      
      • 1
      • 2
      • 3
      • 4
      • 5
      • 6
      • 7
      • 8
      • 9
      • 10
      • 11
      • 12
      • 13
      • 14
      • 15
      • 16
      • 17
      • 18
      • 19
      • 20

      }

      • 1.
      • 2.
      • 3.
      • 4.
      • 5.
      • 6.
      • 7.
      • 8.
      • 9.
      • 10.
      • 11.
      • 12.
      • 13.
      • 14.
      • 15.
      • 16.
      • 17.
      • 18.
      • 19.
      • 20.
      • 21.
      • 22.
      • 23.
      • 24.
      • 25.
      • 26.
      • 27.
      • 28.
      • 29.
      • 30.
      • 31.
      • 32.
      • 33.
      • 34.
      • 35.
      • 36.
      • 37.
      • 38.
      • 39.
      • 40.
      • 41.
      • 42.
      • 43.
      • 44.
      • 45.
      • 46.
      • 47.
      • 48.
      • 49.
      • 50.
      • 51.
      • 52.
      • 53.
      • 54.
      • 55.
      • 56.
      • 57.
      • 58.
      • 59.
      • 60.
      • 61.
      • 62.
      • 63.
      • 64.
      • 65.
      • 66.
      • 67.
      • 68.

      验证步骤

      • 1、启动nc
      登录后复制
      nc -lk 9999
           
           
      • 1.
        • 1
        • 2

        2、启动应用程序

        3、nc控制台输入

        登录后复制
        [alanchan@server2 src]$ nc -lk 9999
        n1,2
        n2,3
        n1,4
        n1,5
        • 1.
        • 2.
        • 3.
        • 4.
        • 5.
        • 1
        • 2
        • 3
        • 4
        • 1
        • 2
        • 3
        • 4
        • 5
        • 6

        4、查看应用程序控制台输出

        【flink番外篇】5、flink的window(介绍、分类、函数及Tumbling、Sliding、session窗口应用)介绍及示例 - 完整版_flink hive_10

        4)、一般lambda实现(Tuple2数据结构)及验证
        • 实现
        登录后复制
        import java.util.Arrays;
        
        • 1
        • 1

        import org.apache.flink.api.common.RuntimeExecutionMode;
        import org.apache.flink.api.common.functions.MapFunction;
        import org.apache.flink.api.common.typeinfo.Types;
        import org.apache.flink.api.java.tuple.Tuple2;
        import org.apache.flink.streaming.api.datastream.DataStream;
        import org.apache.flink.streaming.api.datastream.KeyedStream;
        import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment;
        import org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows;
        import org.apache.flink.streaming.api.windowing.time.Time;
        import org.apache.flink.util.Collector;
        import org.apache.flink.api.common.typeinfo.Types;

        /**

        • @author alanchan

        */
        public class TumblingTimeWindowsDemo4 {

        /**
         * @param args
         * @throws Exception
         */
        public static void main(String[] args) throws Exception {
        	// env
        	StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
        	env.setRuntimeMode(RuntimeExecutionMode.AUTOMATIC);
        
        	DataStream&lt;Tuple2&lt;String, Integer&gt;&gt; dataStream = env
                    .socketTextStream("192.168.10.42", 9999)
                    .map(new Splitter())
                    .keyBy(value -&gt; value.f0)
                    .window(TumblingProcessingTimeWindows.of(Time.seconds(10)))
                    .sum(1);
        	// sink
        	dataStream.print();
        
        	// execute
        	env.execute();
        }
        
        public static class Splitter implements MapFunction&lt;String, Tuple2&lt;String, Integer&gt;&gt; {
        	@Override
        	public Tuple2&lt;String, Integer&gt; map(String value) {
        		String[] arr = value.split(",");
        		return new Tuple2(arr[0], Integer.parseInt(arr[1]));
        	}
        }
        
        • 1
        • 2
        • 3
        • 4
        • 5
        • 6
        • 7
        • 8
        • 9
        • 10
        • 11
        • 12
        • 13
        • 14
        • 15
        • 16
        • 17
        • 18
        • 19
        • 20
        • 21
        • 22
        • 23
        • 24
        • 25
        • 26
        • 27
        • 28
        • 29

        }

        • 1.
        • 2.
        • 3.
        • 4.
        • 5.
        • 6.
        • 7.
        • 8.
        • 9.
        • 10.
        • 11.
        • 12.
        • 13.
        • 14.
        • 15.
        • 16.
        • 17.
        • 18.
        • 19.
        • 20.
        • 21.
        • 22.
        • 23.
        • 24.
        • 25.
        • 26.
        • 27.
        • 28.
        • 29.
        • 30.
        • 31.
        • 32.
        • 33.
        • 34.
        • 35.
        • 36.
        • 37.
        • 38.
        • 39.
        • 40.
        • 41.
        • 42.
        • 43.
        • 44.
        • 45.
        • 46.
        • 47.
        • 48.
        • 49.
        • 50.
        • 51.

        验证步骤

        • 1、启动nc
        登录后复制
        nc -lk 9999
             
             
        • 1.
          • 1
          • 2

          2、启动应用程序

          3、nc控制台输入

          登录后复制
          [alanchan@server2 src]$ nc -lk 9999
          n3,1
          n3,5
          n4,6
          n4,8
          n3,3
          • 1.
          • 2.
          • 3.
          • 4.
          • 5.
          • 6.
          • 1
          • 2
          • 3
          • 4
          • 5
          • 1
          • 2
          • 3
          • 4
          • 5
          • 6
          • 7

          4、查看应用程序控制台输出

          【flink番外篇】5、flink的window(介绍、分类、函数及Tumbling、Sliding、session窗口应用)介绍及示例 - 完整版_flink sql_11

          2、滑动窗口实现统计地铁进站口人数

          每分钟统计一次地铁进站每个入口人数,最近2分钟每个进站口的人数

          lambda实现方式不再赘述

          1)、一般实现(Tuple2数据结构)及验证
          • 实现
          登录后复制
          import org.apache.flink.api.common.RuntimeExecutionMode;
          import org.apache.flink.api.common.functions.MapFunction;
          import org.apache.flink.api.java.functions.KeySelector;
          import org.apache.flink.api.java.tuple.Tuple2;
          import org.apache.flink.streaming.api.datastream.DataStream;
          import org.apache.flink.streaming.api.datastream.KeyedStream;
          import org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator;
          import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment;
          import org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows;
          import org.apache.flink.streaming.api.windowing.time.Time;
          • 1
          • 2
          • 3
          • 4
          • 5
          • 6
          • 7
          • 8
          • 9
          • 10
          • 1
          • 2
          • 3
          • 4
          • 5
          • 6
          • 7
          • 8
          • 9
          • 10

          /**

          • @author alanchan
          • 基于滑动窗口的入门示例
          • 每分钟统计一次地铁进站每个入口人数,最近2分钟每个进站口的人数
          • size>slide

          */
          public class SlidingProcessingTimeWindowsDemo1 {

          /**
           * @param args
           * @throws Exception
           */
          public static void main(String[] args) throws Exception {
          	// env
          	StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
          	env.setRuntimeMode(RuntimeExecutionMode.AUTOMATIC);
          
          	// source
          	// nc
          	// 数据结构: 入口编号,人数
          	// 12,50
          	// 11,28
          	DataStream&lt;String&gt; lines = env.socketTextStream("192.168.10.42", 9999);
          
          	// transformation
          	DataStream&lt;Tuple2&lt;String, Integer&gt;&gt; subwayExit = lines.map(new MapFunction&lt;String, Tuple2&lt;String, Integer&gt;&gt;() {
          
          		@Override
          		public Tuple2&lt;String, Integer&gt; map(String line) throws Exception {
          			String[] arr = line.split(",");
          			return Tuple2.of(arr[0], Integer.parseInt(arr[1]));
          		}
          	});
          
          	// 按照地铁口分组
          	KeyedStream&lt;Tuple2&lt;String, Integer&gt;, String&gt; keyedDS = subwayExit.keyBy(new KeySelector&lt;Tuple2&lt;String, Integer&gt;, String&gt;() {
          		@Override
          		public String getKey(Tuple2&lt;String, Integer&gt; value) throws Exception {
          			return value.f0;
          		}
          	});
          
          	SingleOutputStreamOperator&lt;Tuple2&lt;String, Integer&gt;&gt; result = keyedDS.window(SlidingProcessingTimeWindows.of(Time.seconds(10), Time.seconds(5))).sum(1);
          
          	// sink
          	result.print();
          
          	// execute
          	env.execute();
          }
          
          • 1
          • 2
          • 3
          • 4
          • 5
          • 6
          • 7
          • 8
          • 9
          • 10
          • 11
          • 12
          • 13
          • 14
          • 15
          • 16
          • 17
          • 18
          • 19
          • 20
          • 21
          • 22
          • 23
          • 24
          • 25
          • 26
          • 27
          • 28
          • 29
          • 30
          • 31
          • 32
          • 33
          • 34
          • 35
          • 36
          • 37
          • 38
          • 39
          • 40
          • 41
          • 42

          }

          • 1.
          • 2.
          • 3.
          • 4.
          • 5.
          • 6.
          • 7.
          • 8.
          • 9.
          • 10.
          • 11.
          • 12.
          • 13.
          • 14.
          • 15.
          • 16.
          • 17.
          • 18.
          • 19.
          • 20.
          • 21.
          • 22.
          • 23.
          • 24.
          • 25.
          • 26.
          • 27.
          • 28.
          • 29.
          • 30.
          • 31.
          • 32.
          • 33.
          • 34.
          • 35.
          • 36.
          • 37.
          • 38.
          • 39.
          • 40.
          • 41.
          • 42.
          • 43.
          • 44.
          • 45.
          • 46.
          • 47.
          • 48.
          • 49.
          • 50.
          • 51.
          • 52.
          • 53.
          • 54.
          • 55.
          • 56.
          • 57.
          • 58.
          • 59.
          • 60.
          • 61.
          • 62.
          • 63.
          • 64.
          • 验证步骤
            1、启动nc
          登录后复制
          nc -lk 9999
               
               
          • 1.
            • 1
            • 2

            2、启动应用程序

            3、nc控制台输入

            登录后复制
            [alanchan@server2 src]$ nc -lk 9999
            1,2
            1,3
            1,4
            2,3
            2,4,
            1,2
            1,3
            • 1.
            • 2.
            • 3.
            • 4.
            • 5.
            • 6.
            • 7.
            • 8.
            • 1
            • 2
            • 3
            • 4
            • 5
            • 6
            • 7
            • 1
            • 2
            • 3
            • 4
            • 5
            • 6
            • 7
            • 8
            • 9

            4、查看应用程序控制台输出

            通过验证发现输出数据与预期一致

            登录后复制
            7> (1,5)
            4> (2,3)
            7> (1,9)
            4> (2,7)
            7> (1,6)
            4> (2,4)
            7> (1,5)
            7> (1,3)
            • 1.
            • 2.
            • 3.
            • 4.
            • 5.
            • 6.
            • 7.
            • 8.
            • 1
            • 2
            • 3
            • 4
            • 5
            • 6
            • 7
            • 1
            • 2
            • 3
            • 4
            • 5
            • 6
            • 7
            • 8
            • 9
            2)、面向对象实现(pojo数据结构)及验证
            • 实现
            登录后复制
            import org.apache.flink.api.common.RuntimeExecutionMode;
            import org.apache.flink.api.common.functions.MapFunction;
            import org.apache.flink.api.java.functions.KeySelector;
            import org.apache.flink.api.java.tuple.Tuple2;
            import org.apache.flink.streaming.api.datastream.DataStream;
            import org.apache.flink.streaming.api.datastream.KeyedStream;
            import org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator;
            import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment;
            import org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows;
            import org.apache.flink.streaming.api.windowing.time.Time;
            • 1
            • 2
            • 3
            • 4
            • 5
            • 6
            • 7
            • 8
            • 9
            • 10
            • 1
            • 2
            • 3
            • 4
            • 5
            • 6
            • 7
            • 8
            • 9
            • 10

            /**

            • @author alanchan

            */
            public class SlidingProcessingTimeWindowsDemo2 {

            /**
             * @param args
             * @throws Exception 
             */
            public static void main(String[] args) throws Exception {
            	// env
            	StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
            	env.setRuntimeMode(RuntimeExecutionMode.AUTOMATIC);
            
            	// source
            	// nc
            	// 数据结构: 入口编号,人数
            	// 12,50
            	// 11,28
            	DataStream&lt;String&gt; lines = env.socketTextStream("192.168.10.42", 9999);
            
            	// transformation
            	DataStream&lt;Subway&gt; subwayExit = lines.map(new MapFunction&lt;String, Subway&gt;() {
            
            		@Override
            		public Subway map(String line) throws Exception {
            			String[] arr = line.split(",");
            			return new Subway(arr[0], Integer.parseInt(arr[1]));
            		}
            	});
            
            	// 按照地铁口分组
            	KeyedStream&lt;Subway, String&gt; keyedDS = subwayExit.keyBy(new KeySelector&lt;Subway, String&gt;() {
            		@Override
            		public String getKey(Subway value) throws Exception {
            			return value.getNo();
            		}
            	});
            
            	SingleOutputStreamOperator&lt;Subway&gt; result = keyedDS.window(SlidingProcessingTimeWindows.of(Time.seconds(10), Time.seconds(5))).sum("userCount");
            
            	// sink
            	result.print();
            
            	// execute
            	env.execute();
            
            }
            
            • 1
            • 2
            • 3
            • 4
            • 5
            • 6
            • 7
            • 8
            • 9
            • 10
            • 11
            • 12
            • 13
            • 14
            • 15
            • 16
            • 17
            • 18
            • 19
            • 20
            • 21
            • 22
            • 23
            • 24
            • 25
            • 26
            • 27
            • 28
            • 29
            • 30
            • 31
            • 32
            • 33
            • 34
            • 35
            • 36
            • 37
            • 38
            • 39
            • 40
            • 41
            • 42
            • 43

            }

            • 1.
            • 2.
            • 3.
            • 4.
            • 5.
            • 6.
            • 7.
            • 8.
            • 9.
            • 10.
            • 11.
            • 12.
            • 13.
            • 14.
            • 15.
            • 16.
            • 17.
            • 18.
            • 19.
            • 20.
            • 21.
            • 22.
            • 23.
            • 24.
            • 25.
            • 26.
            • 27.
            • 28.
            • 29.
            • 30.
            • 31.
            • 32.
            • 33.
            • 34.
            • 35.
            • 36.
            • 37.
            • 38.
            • 39.
            • 40.
            • 41.
            • 42.
            • 43.
            • 44.
            • 45.
            • 46.
            • 47.
            • 48.
            • 49.
            • 50.
            • 51.
            • 52.
            • 53.
            • 54.
            • 55.
            • 56.
            • 57.
            • 58.
            • 59.
            • 60.
            • 61.
            • 62.
            • 验证步骤
              1、启动nc
            登录后复制
            nc -lk 9999
                 
                 
            • 1.
              • 1
              • 2

              2、启动应用程序

              3、nc控制台输入

              登录后复制
              [alanchan@server2 src]$ nc -lk 9999
              2,2
              3,3
              2,4
              2,5
              3,5
              4,5
              3,5
              • 1.
              • 2.
              • 3.
              • 4.
              • 5.
              • 6.
              • 7.
              • 8.
              • 1
              • 2
              • 3
              • 4
              • 5
              • 6
              • 7
              • 1
              • 2
              • 3
              • 4
              • 5
              • 6
              • 7
              • 8
              • 9

              4、查看应用程序控制台输出

              通过查看输出结果与预期一致。

              登录后复制
              5> Subway(No=3, userCount=3)
              4> Subway(No=2, userCount=2)
              4> Subway(No=2, userCount=6)
              5> Subway(No=3, userCount=3)
              1> Subway(No=4, userCount=5)
              5> Subway(No=3, userCount=5)
              4> Subway(No=2, userCount=9)
              5> Subway(No=3, userCount=10)
              4> Subway(No=2, userCount=5)
              1> Subway(No=4, userCount=5)
              5> Subway(No=3, userCount=5)
              • 1.
              • 2.
              • 3.
              • 4.
              • 5.
              • 6.
              • 7.
              • 8.
              • 9.
              • 10.
              • 11.
              • 1
              • 2
              • 3
              • 4
              • 5
              • 6
              • 7
              • 8
              • 9
              • 10
              • 1
              • 2
              • 3
              • 4
              • 5
              • 6
              • 7
              • 8
              • 9
              • 10
              • 11
              • 12

              六、示例:基于数量的滚动窗口与滑动窗口

              1、滚动窗口实现地铁进站口人数

              实现统计在最近5条消息中,各自进站口通过的人数数量,相同的key每出现5次进行统计

              本示例仅以面向对象方式实现,一般实现在具体的开发中视情况而定。

              1)、实现
              登录后复制
              import org.apache.flink.api.common.RuntimeExecutionMode;
              import org.apache.flink.api.common.functions.MapFunction;
              import org.apache.flink.api.java.functions.KeySelector;
              import org.apache.flink.streaming.api.datastream.DataStream;
              import org.apache.flink.streaming.api.datastream.KeyedStream;
              import org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator;
              import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment;
              • 1
              • 2
              • 3
              • 4
              • 5
              • 6
              • 7
              • 1
              • 2
              • 3
              • 4
              • 5
              • 6
              • 7

              /**

              • @author alanchan

              • 统计在最近5条消息中,各自进站口通过的人数数量,相同的key每出现5次进行统计
                */
                public class TumblingCountWindowDemo {

                /**

                • @param args

                • @throws Exception
                  */
                  public static void main(String[] args) throws Exception {
                  // env
                  StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
                  env.setRuntimeMode(RuntimeExecutionMode.AUTOMATIC);

                  // source
                  // nc
                  // 数据结构: 入口编号,人数
                  // 12,50
                  // 11,28
                  DataStream<String> lines = env.socketTextStream(“192.168.10.42”, 9999);

                  // transformation
                  SingleOutputStreamOperator<Subway> subwayDS = lines.map(new MapFunction<String, Subway>() {
                  @Override
                  public Subway map(String value) throws Exception {
                  String[] arr = value.split(“,”);
                  return new Subway(arr[0], Integer.parseInt(arr[1]));
                  }
                  });

              // KeyedStream<Subway, String> keyedDS = subwayDS.keyBy(Subway::getNo);

              	KeyedStream&lt;Subway, String&gt; keyedDS = subwayDS.keyBy(new KeySelector&lt;Subway, String&gt;() {
              		@Override
              		public String getKey(Subway value) throws Exception {
              			return value.getNo();
              		}
              	});
              
              	// 统计在最近5条消息中,各自进站口通过的人数数量,相同的key每出现5次进行统计
              	SingleOutputStreamOperator&lt;Subway&gt; result1 = keyedDS.countWindow(5).sum("userCount");
              	
              	// sink
              	result1.print();
              	
              	// execute
              	env.execute();
              
              }
              
              • 1
              • 2
              • 3
              • 4
              • 5
              • 6
              • 7
              • 8
              • 9
              • 10
              • 11
              • 12
              • 13
              • 14
              • 15
              • 16
              • 17

              }

              • 1.
              • 2.
              • 3.
              • 4.
              • 5.
              • 6.
              • 7.
              • 8.
              • 9.
              • 10.
              • 11.
              • 12.
              • 13.
              • 14.
              • 15.
              • 16.
              • 17.
              • 18.
              • 19.
              • 20.
              • 21.
              • 22.
              • 23.
              • 24.
              • 25.
              • 26.
              • 27.
              • 28.
              • 29.
              • 30.
              • 31.
              • 32.
              • 33.
              • 34.
              • 35.
              • 36.
              • 37.
              • 38.
              • 39.
              • 40.
              • 41.
              • 42.
              • 43.
              • 44.
              • 45.
              • 46.
              • 47.
              • 48.
              • 49.
              • 50.
              • 51.
              • 52.
              • 53.
              • 54.
              • 55.
              • 56.
              • 57.
              • 58.
              • 59.
              • 60.
              2)、验证步骤

              1、启动nc

              登录后复制
              nc -lk 9999
                   
                   
              • 1.
                • 1
                • 2

                2、启动应用程序

                3、nc控制台输入

                登录后复制
                [alanchan@server2 src]$ nc -lk 9999
                1,5
                1,6
                1,2
                1,4
                2,4
                3,6
                23,11
                1,8
                • 1.
                • 2.
                • 3.
                • 4.
                • 5.
                • 6.
                • 7.
                • 8.
                • 9.
                • 1
                • 2
                • 3
                • 4
                • 5
                • 6
                • 7
                • 8
                • 1
                • 2
                • 3
                • 4
                • 5
                • 6
                • 7
                • 8
                • 9
                • 10

                4、查看应用程序控制台输出

                通过查看输出结果与预期一致。

                【flink番外篇】5、flink的window(介绍、分类、函数及Tumbling、Sliding、session窗口应用)介绍及示例 - 完整版_flink hive_12

                2、滑动窗口实现地铁进站口人数

                统计在最近5条消息中,各自进站口通过的人数数量,相同的key每出现3次进行统计

                本示例仅以面向对象方式实现,一般实现在具体的开发中视情况而定。

                1)、实现
                登录后复制
                import org.apache.flink.api.common.RuntimeExecutionMode;
                import org.apache.flink.api.common.functions.MapFunction;
                import org.apache.flink.api.java.functions.KeySelector;
                import org.apache.flink.streaming.api.datastream.DataStream;
                import org.apache.flink.streaming.api.datastream.KeyedStream;
                import org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator;
                import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment;
                • 1
                • 2
                • 3
                • 4
                • 5
                • 6
                • 7
                • 1
                • 2
                • 3
                • 4
                • 5
                • 6
                • 7

                /**

                • @author alanchan

                */
                public class SlidingCountWindowDemo {

                /**
                 * @param args
                 * @throws Exception 
                 */
                public static void main(String[] args) throws Exception {
                
                	// env
                	StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
                	env.setRuntimeMode(RuntimeExecutionMode.AUTOMATIC);
                
                	// source
                	// nc
                	// 数据结构: 入口编号,人数
                	// 12,50
                	// 11,28
                	DataStream&lt;String&gt; lines = env.socketTextStream("192.168.10.42", 9999);
                
                	// transformation
                	SingleOutputStreamOperator&lt;Subway&gt; subwayDS = lines.map(new MapFunction&lt;String, Subway&gt;() {
                		@Override
                		public Subway map(String value) throws Exception {
                			String[] arr = value.split(",");
                			return new Subway(arr[0], Integer.parseInt(arr[1]));
                		}
                	});
                
                • 1
                • 2
                • 3
                • 4
                • 5
                • 6
                • 7
                • 8
                • 9
                • 10
                • 11
                • 12
                • 13
                • 14
                • 15
                • 16
                • 17
                • 18
                • 19
                • 20
                • 21
                • 22
                • 23
                • 24
                • 25

                // KeyedStream<Subway, String> keyedDS = subwayDS.keyBy(Subway::getNo);

                	KeyedStream&lt;Subway, String&gt; keyedDS = subwayDS.keyBy(new KeySelector&lt;Subway, String&gt;() {
                		@Override
                		public String getKey(Subway value) throws Exception {
                			return value.getNo();
                		}
                	});
                
                	// 统计在最近5条消息中,各自进站口通过的人数数量,相同的key每出现3次进行统计
                
                • 1
                • 2
                • 3
                • 4
                • 5
                • 6
                • 7
                • 8

                // public WindowedStream<T, KEY, GlobalWindow> countWindow(long size, long slide) {
                // return window(GlobalWindows.create())
                // .evictor(CountEvictor.of(size))
                // .trigger(CountTrigger.of(slide));
                // }
                SingleOutputStreamOperator<Subway> result1 = keyedDS.countWindow(5, 3).sum(“userCount”);

                	// sink
                	result1.print();
                
                	// execute
                	env.execute();
                }
                
                • 1
                • 2
                • 3
                • 4
                • 5
                • 6

                }

                • 1.
                • 2.
                • 3.
                • 4.
                • 5.
                • 6.
                • 7.
                • 8.
                • 9.
                • 10.
                • 11.
                • 12.
                • 13.
                • 14.
                • 15.
                • 16.
                • 17.
                • 18.
                • 19.
                • 20.
                • 21.
                • 22.
                • 23.
                • 24.
                • 25.
                • 26.
                • 27.
                • 28.
                • 29.
                • 30.
                • 31.
                • 32.
                • 33.
                • 34.
                • 35.
                • 36.
                • 37.
                • 38.
                • 39.
                • 40.
                • 41.
                • 42.
                • 43.
                • 44.
                • 45.
                • 46.
                • 47.
                • 48.
                • 49.
                • 50.
                • 51.
                • 52.
                • 53.
                • 54.
                • 55.
                • 56.
                • 57.
                • 58.
                • 59.
                • 60.
                • 61.
                • 62.
                • 63.
                • 64.
                • 65.
                2)、验证步骤

                1、启动nc

                登录后复制
                nc -lk 9999
                     
                     
                • 1.
                  • 1
                  • 2

                  2、启动应用程序

                  3、nc控制台输入

                  登录后复制
                  [alanchan@server2 src]$ nc -lk 9999
                  1,2
                  1,3
                  2,3
                  3,4
                  1,2
                  • 1.
                  • 2.
                  • 3.
                  • 4.
                  • 5.
                  • 6.
                  • 1
                  • 2
                  • 3
                  • 4
                  • 5
                  • 1
                  • 2
                  • 3
                  • 4
                  • 5
                  • 6
                  • 7

                  4、查看应用程序控制台输出

                  通过查看输出结果与预期一致。

                  【flink番外篇】5、flink的window(介绍、分类、函数及Tumbling、Sliding、session窗口应用)介绍及示例 - 完整版_clickhouse_13

                  七、示例:会话窗口

                  实现设置会话超时时间为10s,如果上一个窗口有数据,10s内没有数据则触发上个窗口的计算。

                  1、实现

                  登录后复制
                  import org.apache.flink.api.common.RuntimeExecutionMode;
                  import org.apache.flink.api.common.functions.MapFunction;
                  import org.apache.flink.api.java.functions.KeySelector;
                  import org.apache.flink.streaming.api.datastream.DataStream;
                  import org.apache.flink.streaming.api.datastream.KeyedStream;
                  import org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator;
                  import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment;
                  import org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows;
                  import org.apache.flink.streaming.api.windowing.time.Time;
                  • 1
                  • 2
                  • 3
                  • 4
                  • 5
                  • 6
                  • 7
                  • 8
                  • 9
                  • 1
                  • 2
                  • 3
                  • 4
                  • 5
                  • 6
                  • 7
                  • 8
                  • 9

                  /**

                  • @author alanchan

                  */
                  public class TimeSessionWindowsDemo {

                  /**
                   * @param args
                   * @throws Exception 
                   */
                  public static void main(String[] args) throws Exception {
                  	// env
                  	StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
                  	env.setRuntimeMode(RuntimeExecutionMode.AUTOMATIC);
                  
                  	// source
                  	DataStream&lt;String&gt; lines = env.socketTextStream("192.168.10.42", 9999);
                  
                  	// transformation
                  	SingleOutputStreamOperator&lt;Subway&gt; carDS = lines.map(new MapFunction&lt;String, Subway&gt;() {
                  		@Override
                  		public Subway map(String value) throws Exception {
                  			String[] arr = value.split(",");
                  			return new Subway(arr[0], Integer.parseInt(arr[1]));
                  		}
                  	});
                  	
                  	//KeyedStream&lt;Subway, String&gt; keyedDS = subwayDS.keyBy(Subway::getNo);
                  	KeyedStream&lt;Subway, String&gt; keyedDS = carDS.keyBy(new KeySelector&lt;Subway, String&gt;() {
                  		@Override
                  		public String getKey(Subway value) throws Exception {
                  			return value.getNo();
                  		}
                  	});
                  
                  	// 设置会话超时时间为10s,10s内没有数据则触发上个窗口的计算,如果上一个窗口有数据
                  	SingleOutputStreamOperator&lt;Subway&gt; result = keyedDS.window(ProcessingTimeSessionWindows.withGap(Time.seconds(10))).sum("userCount");
                  	
                  	// sink
                  	result.print();
                  
                  	// execute
                  	env.execute();
                  
                  }
                  
                  • 1
                  • 2
                  • 3
                  • 4
                  • 5
                  • 6
                  • 7
                  • 8
                  • 9
                  • 10
                  • 11
                  • 12
                  • 13
                  • 14
                  • 15
                  • 16
                  • 17
                  • 18
                  • 19
                  • 20
                  • 21
                  • 22
                  • 23
                  • 24
                  • 25
                  • 26
                  • 27
                  • 28
                  • 29
                  • 30
                  • 31
                  • 32
                  • 33
                  • 34
                  • 35
                  • 36
                  • 37
                  • 38
                  • 39

                  }

                  • 1.
                  • 2.
                  • 3.
                  • 4.
                  • 5.
                  • 6.
                  • 7.
                  • 8.
                  • 9.
                  • 10.
                  • 11.
                  • 12.
                  • 13.
                  • 14.
                  • 15.
                  • 16.
                  • 17.
                  • 18.
                  • 19.
                  • 20.
                  • 21.
                  • 22.
                  • 23.
                  • 24.
                  • 25.
                  • 26.
                  • 27.
                  • 28.
                  • 29.
                  • 30.
                  • 31.
                  • 32.
                  • 33.
                  • 34.
                  • 35.
                  • 36.
                  • 37.
                  • 38.
                  • 39.
                  • 40.
                  • 41.
                  • 42.
                  • 43.
                  • 44.
                  • 45.
                  • 46.
                  • 47.
                  • 48.
                  • 49.
                  • 50.
                  • 51.
                  • 52.
                  • 53.
                  • 54.
                  • 55.
                  • 56.
                  • 57.

                  2、验证步骤

                  1、启动nc

                  登录后复制
                  nc -lk 9999
                       
                       
                  • 1.
                    • 1
                    • 2

                    2、启动应用程序

                    3、nc控制台输入

                    登录后复制
                    [alanchan@server2 src]$ nc -lk 9999
                    1,2
                    1,3
                    2,3
                    3,4
                    1,2
                    • 1.
                    • 2.
                    • 3.
                    • 4.
                    • 5.
                    • 6.
                    • 1
                    • 2
                    • 3
                    • 4
                    • 5
                    • 1
                    • 2
                    • 3
                    • 4
                    • 5
                    • 6
                    • 7

                    4、查看应用程序控制台输出

                    通过查看输出结果与预期一致。

                    【flink番外篇】5、flink的window(介绍、分类、函数及Tumbling、Sliding、session窗口应用)介绍及示例 - 完整版_大数据_14

                    以上,本文介绍了Flink window的分类以及三个示例分别实现滚动、滑动以及会话窗口,即基于时间和基于数量的滚动窗口与滑动窗口、会话窗口,其中包含详细的验证步骤与验证结果。

                    声明:本文内容由网友自发贡献,不代表【wpsshop博客】立场,版权归原作者所有,本站不承担相应法律责任。如您发现有侵权的内容,请联系我们。转载请注明出处:https://www.wpsshop.cn/w/盐析白兔/article/detail/1019199
                    推荐阅读
                    相关标签
                      

                    闽ICP备14008679号