[Flink] Flink Job之Web UI

0 序言

  • 在本地电脑开发、调试,或集群环境下运行Flink Job时,需要利用Web UI观测作业内部的运行情况。
  • WEB UI,对我们观测Flink作业的总体运行情况(系统负载)、快速定位和解决问题,至关重要。
  • 全文基于如下版本演示:

scala.version = 2.11 / 2.12 ;flink.version = 1.13.1

1 Flink Job Web UI 概述

2 操作指南 : FlinkJob 启用 Web UI

Step1 引入依赖

<dependency>
    <groupId>org.apache.flink</groupId>
    <artifactId>flink-runtime-web_${scala.version}</artifactId>
    <version>${flink.version}</version>
    <scope>compile</scope>
</dependency>

Step2 程序中配置、启用 WEB-UI

import org.apache.flink.configuration.Configuration;
import org.apache.flink.configuration.RestOptions;
import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment;

// step1 定义作业配置
Configuration jobConfiguration = new Configuration();
//设置WebUI绑定的本地端口
//jobConfiguration.setInteger(RestOptions.PORT, 18081);//"rest.port" / RestOptions.PORT 均可 | 注: 8081 是默认端口
jobConfiguration.setString(RestOptions.BIND_PORT, "18081");

//step2 基于作业配置,创建执行环境
//StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();//方式1 : 不启用 WEB UI
StreamExecutionEnvironment env = StreamExecutionEnvironment.createLocalEnvironmentWithWebUI(configuration);//方式2 : 本地运行模式 + 启用 WEB UI 【后续基于此做演示】
//StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment(configuration);//方式3 : 集群运行模式 + 启用 WEB UI

//step3 ... 作业的运行逻辑

//step4 启动作业 (此处若有异常,不建议try...catch... 捕获。因:它会抛给上层flink, flink根据异常来做相应的重启策略等处理)
env.execute("StreamWordCount");

【注意事项】

  • scala.version = 2.11 / 2.12 ;flink.version = 1.13.1 :支持 Local WEB UI(亲测)

本文基于本版本配置↑进行演示。

  • scala.version = 2.11 / 2.12 ;flink.version = 1.12.6 :存在BUG/不支持 Local WEB UI(亲测)

访问页面(http://127.0.0.1:18081)时,将报错:{"errors":["Unable to load requested file /index.html."]}
参见 : WEB UI failure in Flink 1.12 - Apache Issue/FLINK-18288

{"errors":["Unable to load requested file /index.html."]}

示例

【完整示例】(网友)

【完整代码】(本文)

package cn.seres.bd;

import org.apache.flink.api.common.functions.MapFunction;
import org.apache.flink.api.java.tuple.Tuple;
import org.apache.flink.api.java.tuple.Tuple3;
import org.apache.flink.configuration.Configuration;
import org.apache.flink.configuration.RestOptions;
import org.apache.flink.streaming.api.TimeCharacteristic;
import org.apache.flink.streaming.api.datastream.DataStream;
import org.apache.flink.streaming.api.datastream.DataStreamSource;
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.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor;
import org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows;
import org.apache.flink.streaming.api.windowing.time.Time;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;

public class SampleWindowJob {

    private final static Logger logger = LoggerFactory.getLogger(SampleWindowJob.class);

    public static void main(String[] args) throws Exception {
        //1. 作业配置
        Configuration jobConfiguration = new Configuration();
        // 设置WebUI绑定的本地端口
        //jobConfiguration.setInteger(RestOptions.PORT, 8081);//"rest.port" / RestOptions.PORT / RestOptions.BIND_PORT
        jobConfiguration.setString(RestOptions.BIND_PORT, "18081");

        //2. 创建流处理的执行环境
        StreamExecutionEnvironment env = StreamExecutionEnvironment.createLocalEnvironmentWithWebUI(jobConfiguration); // StreamExecutionEnvironment.getExecutionEnvironment();
        //声明使用 eventTime
        env.setStreamTimeCharacteristic(TimeCharacteristic.EventTime);

        //3. 使用 StreamExecutionEnvironment 创建 DataStream
        //Source(可以有多个Source)
        //Socket 监听本地端口 8888
        // 接收一个socket文本流
        DataStreamSource<String> lines = env.socketTextStream("localhost", 8888);
		
		//4. 数据流的数据处理 
        //4.1 输入的活动数据转换
        DataStream<Tuple3<String, Long, Integer>> windowCountDataStream =
            lines.map(new MapFunction<String, Tuple3<String, Long, Integer>>() {
                @Override
                public Tuple3<String, Long, Integer> map(String line) throws Exception {
                    String[] words = line.split(" ");
                    return new Tuple3<String, Long, Integer>(words[0], Long.valueOf(words[1]), 1);
                }
            });

        //4.2 描述 flink 如何获取数据中的 event 时间戳进行判断
        // 描述延迟的 watermark 1秒
        Time maxOutOfOrderness = Time.milliseconds(1000);

        DataStream<Tuple3<String, Long, Integer>> textWithEventTimeDataStream =
            windowCountDataStream.assignTimestampsAndWatermarks(//分配时间戳和基于 EventTime 的 水位线
                new BoundedOutOfOrdernessTimestampExtractor<Tuple3<String, Long, Integer>>(maxOutOfOrderness) {//有界的乱序时间戳采集器
                    @Override
                    public long extractTimestamp(Tuple3<String, Long, Integer> stringLongIntegerTuple3) {
                        return stringLongIntegerTuple3.f1;//采用 事件数据中提供的事件时间戳
                    }
                }
            ).setParallelism(1);

        DataStream<Tuple3<String, Long, Integer>> textWithEventTimeDataStream = windowCountDataStream.assignTimestampsAndWatermarks(new BoundedOutOfOrdernessTimestampExtractor<Tuple3<String, Long, Integer>>(maxOutOfOrderness) {
            @Override
            public long extractTimestamp(Tuple3<String, Long, Integer> stringLongIntegerTuple3) {
                return stringLongIntegerTuple3.f1;
            }
        }).setParallelism(1);

        //4.3 按 key 分组,keyBy 之后是分到各个分区,再开 window 去处理 | KeyedStream<T, KEY>
        KeyedStream<Tuple3<String, Long, Integer>, Tuple> textKeyStream = textWithEventTimeDataStream
            .keyBy(0);//按照 Tuple3<String, Long, Integer> 元素 中的第 0+1 个字段进行分区
        
        textKeyStream.print("textKey: ");

        //4.4 设置5秒的(会话窗口)活动时间间隔
        SingleOutputStreamOperator<Tuple3<String, Long, Integer>> sessionWindowStream = textKeyStream
            .window( EventTimeSessionWindows.withGap(Time.milliseconds(5000L)) )// 创建 时间间隔/gap = 5s 的 时间会话窗口
            .sum(2);//截取 Tuple3<String, Long, Integer> 元素中的 第 2+1 个字段的值


        //4.5 调用 Sink (Sink必须调用)
        sessionWindowStream.print("windows: ").setParallelism(1);
        
		
		//5. 启动 (此处若有异常不建议try...catch... 捕获。因为:它会抛给上层flink,flink根据异常来做相应的重启策略等处理)
        env.execute("StreamWordCount");
    }
}

Step3 启动作业

  • 提前启动 netcat :

运行环境:WINDOWS 10
安装教程:(参见 : [network] netcat install in windows os - 博客园/千千寰宇)

# nc -L -p 8888 -v
listening on [any] 8888 ...

作业启动、及启动日志

  • 作业启动日志

D:\Program\Java\jdk1.8.0_261\bin\java.exe -javaagent:D:\Program\IDEA\IDEA_COMMUNITY_2023.2\lib\idea_rt.jar=49757:D:\Program\IDEA\IDEA_COMMUNITY_2023.2\bin -Dfile.encoding=UTF-8 -classpath D:\Program\Java\jdk1.8.0_261\jre\lib\charsets.jar;D:\Program\Java\jdk1.8.0_261\jre\lib\deploy.jar;D:\Program\Java\jdk1.8.0_261\jre\lib\ext\access-bridge-64.jar;...;D:\Program_Data\maven_repository\junit\junit\4.13.1\junit-4.13.1.jar;D:\Program_Data\maven_repository\org\hamcrest\hamcrest-core\1.3\hamcrest-core-1.3.jar cn.seres.bd.SampleWindowJob
2024-02-02 12:16:25,291 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutorResourceUtils [] - The configuration option taskmanager.cpu.cores required for local execution is not set, setting it to the maximal possible value.
2024-02-02 12:16:25,327 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutorResourceUtils [] - The configuration option taskmanager.memory.task.heap.size required for local execution is not set, setting it to the maximal possible value.
2024-02-02 12:16:25,328 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutorResourceUtils [] - The configuration option taskmanager.memory.task.off-heap.size required for local execution is not set, setting it to the maximal possible value.
2024-02-02 12:16:25,331 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutorResourceUtils [] - The configuration option taskmanager.memory.network.min required for local execution is not set, setting it to its default value 64 mb.
2024-02-02 12:16:25,331 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutorResourceUtils [] - The configuration option taskmanager.memory.network.max required for local execution is not set, setting it to its default value 64 mb.
2024-02-02 12:16:25,331 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutorResourceUtils [] - The configuration option taskmanager.memory.managed.size required for local execution is not set, setting it to its default value 128 mb.
2024-02-02 12:16:25,370 INFO  org.apache.flink.runtime.minicluster.MiniCluster             [] - Starting Flink Mini Cluster
2024-02-02 12:16:25,374 INFO  org.apache.flink.runtime.minicluster.MiniCluster             [] - Starting Metrics Registry
2024-02-02 12:16:25,463 INFO  org.apache.flink.runtime.metrics.MetricRegistryImpl          [] - No metrics reporter configured, no metrics will be exposed/reported.
2024-02-02 12:16:25,463 INFO  org.apache.flink.runtime.minicluster.MiniCluster             [] - Starting RPC Service(s)
2024-02-02 12:16:25,725 INFO  org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils        [] - Trying to start local actor system
2024-02-02 12:16:26,669 INFO  org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils        [] - Actor system started at akka://flink
2024-02-02 12:16:26,685 INFO  org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils        [] - Trying to start local actor system
2024-02-02 12:16:26,824 INFO  org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils        [] - Actor system started at akka://flink-metrics
2024-02-02 12:16:26,848 INFO  org.apache.flink.runtime.rpc.akka.AkkaRpcService             [] - Starting RPC endpoint for org.apache.flink.runtime.metrics.dump.MetricQueryService at akka://flink-metrics/user/rpc/MetricQueryService .
2024-02-02 12:16:26,880 INFO  org.apache.flink.runtime.minicluster.MiniCluster             [] - Starting high-availability services
2024-02-02 12:16:27,287 INFO  org.apache.flink.runtime.blob.BlobServer                     [] - Created BLOB server storage directory C:\Users\111111\AppData\Local\Temp\blobStore-ffc728c1-70dd-4110-9852-8dc37f8c2a0c
2024-02-02 12:16:27,299 INFO  org.apache.flink.runtime.blob.BlobServer                     [] - Started BLOB server at 0.0.0.0:49803 - max concurrent requests: 50 - max backlog: 1000
2024-02-02 12:16:27,304 INFO  org.apache.flink.runtime.blob.PermanentBlobCache             [] - Created BLOB cache storage directory C:\Users\111111\AppData\Local\Temp\blobStore-105ba0fa-5565-4d8c-9b05-752bd3bc48d7
2024-02-02 12:16:27,307 INFO  org.apache.flink.runtime.blob.TransientBlobCache             [] - Created BLOB cache storage directory C:\Users\111111\AppData\Local\Temp\blobStore-2568bb5c-64d6-4257-b8bd-04f56a9c2fff
2024-02-02 12:16:27,308 INFO  org.apache.flink.runtime.minicluster.MiniCluster             [] - Starting 1 TaskManger(s)
2024-02-02 12:16:27,314 INFO  org.apache.flink.runtime.taskexecutor.TaskManagerRunner      [] - Starting TaskManager with ResourceID: ebc91612-46c6-4a25-b294-dbb06130bc1f
2024-02-02 12:16:27,364 INFO  org.apache.flink.runtime.taskexecutor.TaskManagerServices    [] - Temporary file directory 'C:\Users\111111\AppData\Local\Temp': total 200 GB, usable 38 GB (19.00% usable)
2024-02-02 12:16:27,371 INFO  org.apache.flink.runtime.io.disk.FileChannelManagerImpl      [] - FileChannelManager uses directory C:\Users\111111\AppData\Local\Temp\flink-io-72450374-f7ba-48fa-a850-5d3fc42ab2fa for spill files.
2024-02-02 12:16:27,383 INFO  org.apache.flink.runtime.io.disk.FileChannelManagerImpl      [] - FileChannelManager uses directory C:\Users\111111\AppData\Local\Temp\flink-netty-shuffle-572d4857-c919-4652-892f-d99e312b4e90 for spill files.
2024-02-02 12:16:27,420 INFO  org.apache.flink.runtime.io.network.buffer.NetworkBufferPool [] - Allocated 64 MB for network buffer pool (number of memory segments: 2048, bytes per segment: 32768).
2024-02-02 12:16:27,437 INFO  org.apache.flink.runtime.io.network.NettyShuffleEnvironment  [] - Starting the network environment and its components.
2024-02-02 12:16:27,438 INFO  org.apache.flink.runtime.taskexecutor.KvStateService         [] - Starting the kvState service and its components.
2024-02-02 12:16:27,474 INFO  org.apache.flink.runtime.rpc.akka.AkkaRpcService             [] - Starting RPC endpoint for org.apache.flink.runtime.taskexecutor.TaskExecutor at akka://flink/user/rpc/taskmanager_0 .
2024-02-02 12:16:27,492 INFO  org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService [] - Start job leader service.
2024-02-02 12:16:27,493 INFO  org.apache.flink.runtime.filecache.FileCache                 [] - User file cache uses directory C:\Users\111111\AppData\Local\Temp\flink-dist-cache-b71dcac0-f640-40cd-b321-a368725c8646
2024-02-02 12:16:27,564 INFO  org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint   [] - Starting rest endpoint.
2024-02-02 12:16:28,069 WARN  org.apache.flink.runtime.webmonitor.WebMonitorUtils          [] - Log file environment variable 'log.file' is not set.
2024-02-02 12:16:28,069 WARN  org.apache.flink.runtime.webmonitor.WebMonitorUtils          [] - JobManager log files are unavailable in the web dashboard. Log file location not found in environment variable 'log.file' or configuration key 'web.log.path'.
2024-02-02 12:16:28,991 INFO  org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint   [] - Rest endpoint listening at localhost:18081
2024-02-02 12:16:28,992 INFO  org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService [] - Proposing leadership to contender http://localhost:18081
2024-02-02 12:16:28,995 INFO  org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint   [] - Web frontend listening at http://localhost:18081.
2024-02-02 12:16:28,995 INFO  org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint   [] - http://localhost:18081 was granted leadership with leaderSessionID=9c2e23cb-9494-4059-a345-879a0500706c
2024-02-02 12:16:28,995 INFO  org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService [] - Received confirmation of leadership for leader http://localhost:18081 , session=9c2e23cb-9494-4059-a345-879a0500706c
2024-02-02 12:16:29,028 INFO  org.apache.flink.runtime.rpc.akka.AkkaRpcService             [] - Starting RPC endpoint for org.apache.flink.runtime.resourcemanager.StandaloneResourceManager at akka://flink/user/rpc/resourcemanager_1 .
2024-02-02 12:16:29,048 INFO  org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService [] - Proposing leadership to contender LeaderContender: DefaultDispatcherRunner
2024-02-02 12:16:29,049 INFO  org.apache.flink.runtime.resourcemanager.StandaloneResourceManager [] - Starting the resource manager.
2024-02-02 12:16:29,049 INFO  org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService [] - Proposing leadership to contender LeaderContender: StandaloneResourceManager
2024-02-02 12:16:29,051 INFO  org.apache.flink.runtime.resourcemanager.StandaloneResourceManager [] - ResourceManager akka://flink/user/rpc/resourcemanager_1 was granted leadership with fencing token 8a94b1bce55955e3305b170b2f30446e
2024-02-02 12:16:29,053 INFO  org.apache.flink.runtime.minicluster.MiniCluster             [] - Flink Mini Cluster started successfully
2024-02-02 12:16:29,054 INFO  org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess [] - Start SessionDispatcherLeaderProcess.
2024-02-02 12:16:29,057 INFO  org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess [] - Recover all persisted job graphs.
2024-02-02 12:16:29,058 INFO  org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess [] - Successfully recovered 0 persisted job graphs.
2024-02-02 12:16:29,061 INFO  org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService [] - Received confirmation of leadership for leader akka://flink/user/rpc/resourcemanager_1 , session=305b170b-2f30-446e-8a94-b1bce55955e3
2024-02-02 12:16:29,064 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Connecting to ResourceManager akka://flink/user/rpc/resourcemanager_1(8a94b1bce55955e3305b170b2f30446e).
2024-02-02 12:16:29,066 INFO  org.apache.flink.runtime.rpc.akka.AkkaRpcService             [] - Starting RPC endpoint for org.apache.flink.runtime.dispatcher.StandaloneDispatcher at akka://flink/user/rpc/dispatcher_2 .
2024-02-02 12:16:29,072 INFO  org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService [] - Received confirmation of leadership for leader akka://flink/user/rpc/dispatcher_2 , session=16f8ec8b-e8dd-4ac0-877d-caa9967b1699
2024-02-02 12:16:29,090 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Resolved ResourceManager address, beginning registration
2024-02-02 12:16:29,096 INFO  org.apache.flink.runtime.resourcemanager.StandaloneResourceManager [] - Registering TaskManager with ResourceID ebc91612-46c6-4a25-b294-dbb06130bc1f (akka://flink/user/rpc/taskmanager_0) at ResourceManager
2024-02-02 12:16:29,098 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Successful registration at resource manager akka://flink/user/rpc/resourcemanager_1 under registration id 8d1fc27a684f47d195f8ca48c4f74c7f.
2024-02-02 12:16:29,100 INFO  org.apache.flink.runtime.dispatcher.StandaloneDispatcher     [] - Received JobGraph submission 85c0f65ffc6ffca03c4c1f5897080a17 (StreamWordCount).
2024-02-02 12:16:29,101 INFO  org.apache.flink.runtime.dispatcher.StandaloneDispatcher     [] - Submitting job 85c0f65ffc6ffca03c4c1f5897080a17 (StreamWordCount).
2024-02-02 12:16:29,122 INFO  org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService [] - Proposing leadership to contender LeaderContender: JobMasterServiceLeadershipRunner
2024-02-02 12:16:29,136 INFO  org.apache.flink.runtime.rpc.akka.AkkaRpcService             [] - Starting RPC endpoint for org.apache.flink.runtime.jobmaster.JobMaster at akka://flink/user/rpc/jobmanager_3 .
2024-02-02 12:16:29,146 INFO  org.apache.flink.runtime.jobmaster.JobMaster                 [] - Initializing job StreamWordCount (85c0f65ffc6ffca03c4c1f5897080a17).
2024-02-02 12:16:29,181 INFO  org.apache.flink.runtime.jobmaster.JobMaster                 [] - Using restart back off time strategy NoRestartBackoffTimeStrategy for StreamWordCount (85c0f65ffc6ffca03c4c1f5897080a17).
2024-02-02 12:16:29,244 INFO  org.apache.flink.runtime.jobmaster.JobMaster                 [] - Running initialization on master for job StreamWordCount (85c0f65ffc6ffca03c4c1f5897080a17).
2024-02-02 12:16:29,245 INFO  org.apache.flink.runtime.jobmaster.JobMaster                 [] - Successfully ran initialization on master in 0 ms.
2024-02-02 12:16:29,281 INFO  org.apache.flink.runtime.scheduler.adapter.DefaultExecutionTopology [] - Built 1 pipelined regions in 2 ms
2024-02-02 12:16:29,299 INFO  org.apache.flink.runtime.jobmaster.JobMaster                 [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@23e78d66
2024-02-02 12:16:29,301 INFO  org.apache.flink.runtime.jobmaster.JobMaster                 [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,325 INFO  org.apache.flink.runtime.checkpoint.CheckpointCoordinator    [] - No checkpoint found during restore.
2024-02-02 12:16:29,333 INFO  org.apache.flink.runtime.jobmaster.JobMaster                 [] - Using failover strategy org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionFailoverStrategy@1914c2ce for StreamWordCount (85c0f65ffc6ffca03c4c1f5897080a17).
2024-02-02 12:16:29,344 INFO  org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService [] - Received confirmation of leadership for leader akka://flink/user/rpc/jobmanager_3 , session=bdc7e972-6d2a-4d01-bbd7-0729139e2572
2024-02-02 12:16:29,347 INFO  org.apache.flink.runtime.jobmaster.JobMaster                 [] - Starting execution of job StreamWordCount (85c0f65ffc6ffca03c4c1f5897080a17) under job master id bbd70729139e2572bdc7e9726d2a4d01.
2024-02-02 12:16:29,348 INFO  org.apache.flink.runtime.jobmaster.JobMaster                 [] - Starting scheduling with scheduling strategy [org.apache.flink.runtime.scheduler.strategy.PipelinedRegionSchedulingStrategy]
2024-02-02 12:16:29,348 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Job StreamWordCount (85c0f65ffc6ffca03c4c1f5897080a17) switched from state CREATED to RUNNING.
2024-02-02 12:16:29,353 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Source: Socket Stream (1/1) (c350c727d5dc769587e0ecd8bc48af02) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,353 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (1/8) (ee431f02bf40e39dcc77e0b2d6e4d32c) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,353 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (2/8) (b3e95f7752a4a898894b44896271bc3c) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,353 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (3/8) (aa6f33f534f71e442da060df69bdc60c) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (4/8) (009a16502c49f5dcd2f9e635bd5a6782) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (5/8) (1146ec7e30bb7d899d474a6d45dece28) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (6/8) (05fd3ea02b5c38193ae21862bb801efb) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (7/8) (6871493e95a9bbee511e15e107ac7082) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (8/8) (d09e6fd867640d38af1b63b68a92d222) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Timestamps/Watermarks (1/1) (4fb7d399bb21e766e9d7fc238253f4b0) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (1/8) (d7c5126d4f5ba9d96c703379b93c4847) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (2/8) (f89d723580ebdbdad4541f025521a35c) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (3/8) (ad53fc58b87f7bce8d32061c610bc70f) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (4/8) (354b4d7f255f8da859b441ab44f054c3) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (5/8) (aa501d9858a09c9ebf332daf7ac008f0) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (6/8) (0d85c4232b5c241ef9621132258c4f37) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (7/8) (3fe03cabcc6314032a082067cc6983b6) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (8/8) (ec9b6f95cd17e4034644fd110023759d) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (1/8) (fcd7c31a2d11ea6cd0f25921961eff01) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (2/8) (2780388f5012ea0fa6aa9fa2ed1cc5f0) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (3/8) (881e99eb44f30b7c0616c7da3f3e7ac4) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (4/8) (8e867b890db6b56f04a3b6a8c8f127bc) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,354 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (5/8) (c888162ba444f889d6e1d233cb7465c8) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,355 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (6/8) (fa683d432b6c8242b2d7abc584df8aa3) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,355 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (7/8) (32eaf56e34504b1eb3bae3f4cc032427) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,355 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (8/8) (48926f3fcc34741e8810ad03559654dc) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,355 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (1/1) (bf8c6a4669370779f7698f86d704e5d1) switched from CREATED to SCHEDULED.
2024-02-02 12:16:29,376 INFO  org.apache.flink.runtime.jobmaster.JobMaster                 [] - Connecting to ResourceManager akka://flink/user/rpc/resourcemanager_1(8a94b1bce55955e3305b170b2f30446e)
2024-02-02 12:16:29,378 INFO  org.apache.flink.runtime.jobmaster.JobMaster                 [] - Resolved ResourceManager address, beginning registration
2024-02-02 12:16:29,380 INFO  org.apache.flink.runtime.resourcemanager.StandaloneResourceManager [] - Registering job manager bbd70729139e2572bdc7e9726d2a4d01@akka://flink/user/rpc/jobmanager_3 for job 85c0f65ffc6ffca03c4c1f5897080a17.
2024-02-02 12:16:29,385 INFO  org.apache.flink.runtime.resourcemanager.StandaloneResourceManager [] - Registered job manager bbd70729139e2572bdc7e9726d2a4d01@akka://flink/user/rpc/jobmanager_3 for job 85c0f65ffc6ffca03c4c1f5897080a17.
2024-02-02 12:16:29,387 INFO  org.apache.flink.runtime.jobmaster.JobMaster                 [] - JobManager successfully registered at ResourceManager, leader id: 8a94b1bce55955e3305b170b2f30446e.
2024-02-02 12:16:29,390 INFO  org.apache.flink.runtime.resourcemanager.slotmanager.DeclarativeSlotManager [] - Received resource requirements from job 85c0f65ffc6ffca03c4c1f5897080a17: [ResourceRequirement{resourceProfile=ResourceProfile{UNKNOWN}, numberOfRequiredSlots=8}]
2024-02-02 12:16:29,395 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Receive slot request 09c5867c1c35698fe4859e44f2706879 for job 85c0f65ffc6ffca03c4c1f5897080a17 from resource manager with leader id 8a94b1bce55955e3305b170b2f30446e.
2024-02-02 12:16:29,402 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Allocated slot for 09c5867c1c35698fe4859e44f2706879.
2024-02-02 12:16:29,403 INFO  org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService [] - Add job 85c0f65ffc6ffca03c4c1f5897080a17 for job leader monitoring.
2024-02-02 12:16:29,406 INFO  org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService [] - Try to register at job manager akka://flink/user/rpc/jobmanager_3 with leader id bdc7e972-6d2a-4d01-bbd7-0729139e2572.
2024-02-02 12:16:29,406 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Receive slot request f33c934076f3d826201630284dfad537 for job 85c0f65ffc6ffca03c4c1f5897080a17 from resource manager with leader id 8a94b1bce55955e3305b170b2f30446e.
2024-02-02 12:16:29,406 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Allocated slot for f33c934076f3d826201630284dfad537.
2024-02-02 12:16:29,407 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Receive slot request 99bbcc7255a3b0c88e6e58aa34a56b7a for job 85c0f65ffc6ffca03c4c1f5897080a17 from resource manager with leader id 8a94b1bce55955e3305b170b2f30446e.
2024-02-02 12:16:29,407 INFO  org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService [] - Resolved JobManager address, beginning registration
2024-02-02 12:16:29,407 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Allocated slot for 99bbcc7255a3b0c88e6e58aa34a56b7a.
2024-02-02 12:16:29,407 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Receive slot request 2b8cda9ec1b9c5ea6f53439864ce8990 for job 85c0f65ffc6ffca03c4c1f5897080a17 from resource manager with leader id 8a94b1bce55955e3305b170b2f30446e.
2024-02-02 12:16:29,407 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Allocated slot for 2b8cda9ec1b9c5ea6f53439864ce8990.
2024-02-02 12:16:29,407 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Receive slot request db9a3aec80013854f6e741b1ba81ee67 for job 85c0f65ffc6ffca03c4c1f5897080a17 from resource manager with leader id 8a94b1bce55955e3305b170b2f30446e.
2024-02-02 12:16:29,407 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Allocated slot for db9a3aec80013854f6e741b1ba81ee67.
2024-02-02 12:16:29,408 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Receive slot request ea4c085db6204115d994fd8d8e5316ac for job 85c0f65ffc6ffca03c4c1f5897080a17 from resource manager with leader id 8a94b1bce55955e3305b170b2f30446e.
2024-02-02 12:16:29,408 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Allocated slot for ea4c085db6204115d994fd8d8e5316ac.
2024-02-02 12:16:29,408 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Receive slot request 5e919556514b26b6f27e9abd55d7d714 for job 85c0f65ffc6ffca03c4c1f5897080a17 from resource manager with leader id 8a94b1bce55955e3305b170b2f30446e.
2024-02-02 12:16:29,408 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Allocated slot for 5e919556514b26b6f27e9abd55d7d714.
2024-02-02 12:16:29,408 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Receive slot request 9e2c99599214d1b2a39d232b5d81c7f8 for job 85c0f65ffc6ffca03c4c1f5897080a17 from resource manager with leader id 8a94b1bce55955e3305b170b2f30446e.
2024-02-02 12:16:29,408 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Allocated slot for 9e2c99599214d1b2a39d232b5d81c7f8.
2024-02-02 12:16:29,412 INFO  org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService [] - Successful registration at job manager akka://flink/user/rpc/jobmanager_3 for job 85c0f65ffc6ffca03c4c1f5897080a17.
2024-02-02 12:16:29,413 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Establish JobManager connection for job 85c0f65ffc6ffca03c4c1f5897080a17.
2024-02-02 12:16:29,419 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Offer reserved slots to the leader of job 85c0f65ffc6ffca03c4c1f5897080a17.
2024-02-02 12:16:29,439 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Source: Socket Stream (1/1) (c350c727d5dc769587e0ecd8bc48af02) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,439 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Source: Socket Stream (1/1) (attempt #0) with attempt id c350c727d5dc769587e0ecd8bc48af02 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 2b8cda9ec1b9c5ea6f53439864ce8990
2024-02-02 12:16:29,450 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (1/8) (ee431f02bf40e39dcc77e0b2d6e4d32c) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,450 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Map (1/8) (attempt #0) with attempt id ee431f02bf40e39dcc77e0b2d6e4d32c to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 2b8cda9ec1b9c5ea6f53439864ce8990
2024-02-02 12:16:29,451 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 2b8cda9ec1b9c5ea6f53439864ce8990.
2024-02-02 12:16:29,452 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (2/8) (b3e95f7752a4a898894b44896271bc3c) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,452 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Map (2/8) (attempt #0) with attempt id b3e95f7752a4a898894b44896271bc3c to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id ea4c085db6204115d994fd8d8e5316ac
2024-02-02 12:16:29,452 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (3/8) (aa6f33f534f71e442da060df69bdc60c) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,452 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Map (3/8) (attempt #0) with attempt id aa6f33f534f71e442da060df69bdc60c to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 5e919556514b26b6f27e9abd55d7d714
2024-02-02 12:16:29,453 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (4/8) (009a16502c49f5dcd2f9e635bd5a6782) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,453 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Map (4/8) (attempt #0) with attempt id 009a16502c49f5dcd2f9e635bd5a6782 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id f33c934076f3d826201630284dfad537
2024-02-02 12:16:29,453 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (5/8) (1146ec7e30bb7d899d474a6d45dece28) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,453 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Map (5/8) (attempt #0) with attempt id 1146ec7e30bb7d899d474a6d45dece28 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 99bbcc7255a3b0c88e6e58aa34a56b7a
2024-02-02 12:16:29,454 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (6/8) (05fd3ea02b5c38193ae21862bb801efb) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,455 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Map (6/8) (attempt #0) with attempt id 05fd3ea02b5c38193ae21862bb801efb to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 09c5867c1c35698fe4859e44f2706879
2024-02-02 12:16:29,455 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (7/8) (6871493e95a9bbee511e15e107ac7082) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,455 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Map (7/8) (attempt #0) with attempt id 6871493e95a9bbee511e15e107ac7082 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 9e2c99599214d1b2a39d232b5d81c7f8
2024-02-02 12:16:29,455 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (8/8) (d09e6fd867640d38af1b63b68a92d222) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,455 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Map (8/8) (attempt #0) with attempt id d09e6fd867640d38af1b63b68a92d222 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id db9a3aec80013854f6e741b1ba81ee67
2024-02-02 12:16:29,456 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Timestamps/Watermarks (1/1) (4fb7d399bb21e766e9d7fc238253f4b0) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,456 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Timestamps/Watermarks (1/1) (attempt #0) with attempt id 4fb7d399bb21e766e9d7fc238253f4b0 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 2b8cda9ec1b9c5ea6f53439864ce8990
2024-02-02 12:16:29,456 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (1/8) (d7c5126d4f5ba9d96c703379b93c4847) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,456 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Sink: Print to Std. Out (1/8) (attempt #0) with attempt id d7c5126d4f5ba9d96c703379b93c4847 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 2b8cda9ec1b9c5ea6f53439864ce8990
2024-02-02 12:16:29,457 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (2/8) (f89d723580ebdbdad4541f025521a35c) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,457 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Sink: Print to Std. Out (2/8) (attempt #0) with attempt id f89d723580ebdbdad4541f025521a35c to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id ea4c085db6204115d994fd8d8e5316ac
2024-02-02 12:16:29,457 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (3/8) (ad53fc58b87f7bce8d32061c610bc70f) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,457 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Sink: Print to Std. Out (3/8) (attempt #0) with attempt id ad53fc58b87f7bce8d32061c610bc70f to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 5e919556514b26b6f27e9abd55d7d714
2024-02-02 12:16:29,457 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (4/8) (354b4d7f255f8da859b441ab44f054c3) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,457 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Sink: Print to Std. Out (4/8) (attempt #0) with attempt id 354b4d7f255f8da859b441ab44f054c3 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id f33c934076f3d826201630284dfad537
2024-02-02 12:16:29,457 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (5/8) (aa501d9858a09c9ebf332daf7ac008f0) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,457 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Sink: Print to Std. Out (5/8) (attempt #0) with attempt id aa501d9858a09c9ebf332daf7ac008f0 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 99bbcc7255a3b0c88e6e58aa34a56b7a
2024-02-02 12:16:29,457 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (6/8) (0d85c4232b5c241ef9621132258c4f37) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,457 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Sink: Print to Std. Out (6/8) (attempt #0) with attempt id 0d85c4232b5c241ef9621132258c4f37 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 09c5867c1c35698fe4859e44f2706879
2024-02-02 12:16:29,457 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (7/8) (3fe03cabcc6314032a082067cc6983b6) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,457 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Sink: Print to Std. Out (7/8) (attempt #0) with attempt id 3fe03cabcc6314032a082067cc6983b6 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 9e2c99599214d1b2a39d232b5d81c7f8
2024-02-02 12:16:29,458 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (8/8) (ec9b6f95cd17e4034644fd110023759d) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,458 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Sink: Print to Std. Out (8/8) (attempt #0) with attempt id ec9b6f95cd17e4034644fd110023759d to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id db9a3aec80013854f6e741b1ba81ee67
2024-02-02 12:16:29,458 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (1/8) (fcd7c31a2d11ea6cd0f25921961eff01) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,458 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (1/8) (attempt #0) with attempt id fcd7c31a2d11ea6cd0f25921961eff01 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 2b8cda9ec1b9c5ea6f53439864ce8990
2024-02-02 12:16:29,458 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (2/8) (2780388f5012ea0fa6aa9fa2ed1cc5f0) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,459 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (2/8) (attempt #0) with attempt id 2780388f5012ea0fa6aa9fa2ed1cc5f0 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id ea4c085db6204115d994fd8d8e5316ac
2024-02-02 12:16:29,460 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (3/8) (881e99eb44f30b7c0616c7da3f3e7ac4) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,460 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (3/8) (attempt #0) with attempt id 881e99eb44f30b7c0616c7da3f3e7ac4 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 5e919556514b26b6f27e9abd55d7d714
2024-02-02 12:16:29,460 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (4/8) (8e867b890db6b56f04a3b6a8c8f127bc) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,460 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (4/8) (attempt #0) with attempt id 8e867b890db6b56f04a3b6a8c8f127bc to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id f33c934076f3d826201630284dfad537
2024-02-02 12:16:29,460 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (5/8) (c888162ba444f889d6e1d233cb7465c8) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,460 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (5/8) (attempt #0) with attempt id c888162ba444f889d6e1d233cb7465c8 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 99bbcc7255a3b0c88e6e58aa34a56b7a
2024-02-02 12:16:29,462 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (6/8) (fa683d432b6c8242b2d7abc584df8aa3) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,462 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (6/8) (attempt #0) with attempt id fa683d432b6c8242b2d7abc584df8aa3 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 09c5867c1c35698fe4859e44f2706879
2024-02-02 12:16:29,462 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (7/8) (32eaf56e34504b1eb3bae3f4cc032427) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,462 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (7/8) (attempt #0) with attempt id 32eaf56e34504b1eb3bae3f4cc032427 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 9e2c99599214d1b2a39d232b5d81c7f8
2024-02-02 12:16:29,462 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (8/8) (48926f3fcc34741e8810ad03559654dc) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,462 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (8/8) (attempt #0) with attempt id 48926f3fcc34741e8810ad03559654dc to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id db9a3aec80013854f6e741b1ba81ee67
2024-02-02 12:16:29,462 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (1/1) (bf8c6a4669370779f7698f86d704e5d1) switched from SCHEDULED to DEPLOYING.
2024-02-02 12:16:29,463 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Deploying Sink: Print to Std. Out (1/1) (attempt #0) with attempt id bf8c6a4669370779f7698f86d704e5d1 to ebc91612-46c6-4a25-b294-dbb06130bc1f @ localhost.sangfor.com.cn (dataPort=-1) with allocation id 2b8cda9ec1b9c5ea6f53439864ce8990
2024-02-02 12:16:29,543 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Source: Socket Stream (1/1)#0 (c350c727d5dc769587e0ecd8bc48af02), deploy into slot with allocation id 2b8cda9ec1b9c5ea6f53439864ce8990.
2024-02-02 12:16:29,549 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Source: Socket Stream (1/1)#0 (c350c727d5dc769587e0ecd8bc48af02) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,549 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 2b8cda9ec1b9c5ea6f53439864ce8990.
2024-02-02 12:16:29,565 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Source: Socket Stream (1/1)#0 (c350c727d5dc769587e0ecd8bc48af02) [DEPLOYING].
2024-02-02 12:16:29,613 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Map (1/8)#0 (ee431f02bf40e39dcc77e0b2d6e4d32c), deploy into slot with allocation id 2b8cda9ec1b9c5ea6f53439864ce8990.
2024-02-02 12:16:29,613 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot ea4c085db6204115d994fd8d8e5316ac.
2024-02-02 12:16:29,617 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Map (2/8)#0 (b3e95f7752a4a898894b44896271bc3c), deploy into slot with allocation id ea4c085db6204115d994fd8d8e5316ac.
2024-02-02 12:16:29,618 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 5e919556514b26b6f27e9abd55d7d714.
2024-02-02 12:16:29,623 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Map (3/8)#0 (aa6f33f534f71e442da060df69bdc60c), deploy into slot with allocation id 5e919556514b26b6f27e9abd55d7d714.
2024-02-02 12:16:29,624 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot f33c934076f3d826201630284dfad537.
2024-02-02 12:16:29,627 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Map (4/8)#0 (009a16502c49f5dcd2f9e635bd5a6782), deploy into slot with allocation id f33c934076f3d826201630284dfad537.
2024-02-02 12:16:29,628 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 99bbcc7255a3b0c88e6e58aa34a56b7a.
2024-02-02 12:16:29,634 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (1/8)#0 (ee431f02bf40e39dcc77e0b2d6e4d32c) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,634 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Map (1/8)#0 (ee431f02bf40e39dcc77e0b2d6e4d32c) [DEPLOYING].
2024-02-02 12:16:29,651 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (3/8)#0 (aa6f33f534f71e442da060df69bdc60c) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,651 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Map (3/8)#0 (aa6f33f534f71e442da060df69bdc60c) [DEPLOYING].
2024-02-02 12:16:29,639 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (4/8)#0 (009a16502c49f5dcd2f9e635bd5a6782) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,654 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Map (4/8)#0 (009a16502c49f5dcd2f9e635bd5a6782) [DEPLOYING].
2024-02-02 12:16:29,655 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (2/8)#0 (b3e95f7752a4a898894b44896271bc3c) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,655 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Map (2/8)#0 (b3e95f7752a4a898894b44896271bc3c) [DEPLOYING].
2024-02-02 12:16:29,658 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Map (5/8)#0 (1146ec7e30bb7d899d474a6d45dece28), deploy into slot with allocation id 99bbcc7255a3b0c88e6e58aa34a56b7a.
2024-02-02 12:16:29,665 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 09c5867c1c35698fe4859e44f2706879.
2024-02-02 12:16:29,679 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (5/8)#0 (1146ec7e30bb7d899d474a6d45dece28) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,679 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Map (5/8)#0 (1146ec7e30bb7d899d474a6d45dece28) [DEPLOYING].
2024-02-02 12:16:29,682 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Map (6/8)#0 (05fd3ea02b5c38193ae21862bb801efb), deploy into slot with allocation id 09c5867c1c35698fe4859e44f2706879.
2024-02-02 12:16:29,683 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 9e2c99599214d1b2a39d232b5d81c7f8.
2024-02-02 12:16:29,684 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (6/8)#0 (05fd3ea02b5c38193ae21862bb801efb) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,684 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Map (6/8)#0 (05fd3ea02b5c38193ae21862bb801efb) [DEPLOYING].
2024-02-02 12:16:29,689 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Map (7/8)#0 (6871493e95a9bbee511e15e107ac7082), deploy into slot with allocation id 9e2c99599214d1b2a39d232b5d81c7f8.
2024-02-02 12:16:29,690 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot db9a3aec80013854f6e741b1ba81ee67.
2024-02-02 12:16:29,690 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (7/8)#0 (6871493e95a9bbee511e15e107ac7082) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,691 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Map (7/8)#0 (6871493e95a9bbee511e15e107ac7082) [DEPLOYING].
2024-02-02 12:16:29,695 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@5129211c
2024-02-02 12:16:29,695 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@2954c135
2024-02-02 12:16:29,695 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@b5fb3ac
2024-02-02 12:16:29,695 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@69763d91
2024-02-02 12:16:29,695 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Map (8/8)#0 (d09e6fd867640d38af1b63b68a92d222), deploy into slot with allocation id db9a3aec80013854f6e741b1ba81ee67.
2024-02-02 12:16:29,695 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,695 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,695 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@2541043c
2024-02-02 12:16:29,695 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,695 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@6c7230ff
2024-02-02 12:16:29,695 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,695 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 2b8cda9ec1b9c5ea6f53439864ce8990.
2024-02-02 12:16:29,696 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@78dfa530
2024-02-02 12:16:29,696 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,696 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,695 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@7d24595c
2024-02-02 12:16:29,696 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,696 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,696 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (8/8)#0 (d09e6fd867640d38af1b63b68a92d222) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,696 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Map (8/8)#0 (d09e6fd867640d38af1b63b68a92d222) [DEPLOYING].
2024-02-02 12:16:29,698 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Timestamps/Watermarks (1/1)#0 (4fb7d399bb21e766e9d7fc238253f4b0), deploy into slot with allocation id 2b8cda9ec1b9c5ea6f53439864ce8990.
2024-02-02 12:16:29,699 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 2b8cda9ec1b9c5ea6f53439864ce8990.
2024-02-02 12:16:29,699 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@47d2d42f
2024-02-02 12:16:29,699 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,699 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Timestamps/Watermarks (1/1)#0 (4fb7d399bb21e766e9d7fc238253f4b0) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,699 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Timestamps/Watermarks (1/1)#0 (4fb7d399bb21e766e9d7fc238253f4b0) [DEPLOYING].
2024-02-02 12:16:29,704 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Sink: Print to Std. Out (1/8)#0 (d7c5126d4f5ba9d96c703379b93c4847), deploy into slot with allocation id 2b8cda9ec1b9c5ea6f53439864ce8990.
2024-02-02 12:16:29,704 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot ea4c085db6204115d994fd8d8e5316ac.
2024-02-02 12:16:29,705 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@10732cef
2024-02-02 12:16:29,705 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,708 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Sink: Print to Std. Out (2/8)#0 (f89d723580ebdbdad4541f025521a35c), deploy into slot with allocation id ea4c085db6204115d994fd8d8e5316ac.
2024-02-02 12:16:29,709 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 5e919556514b26b6f27e9abd55d7d714.
2024-02-02 12:16:29,712 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Sink: Print to Std. Out (3/8)#0 (ad53fc58b87f7bce8d32061c610bc70f), deploy into slot with allocation id 5e919556514b26b6f27e9abd55d7d714.
2024-02-02 12:16:29,712 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (7/8)#0 (6871493e95a9bbee511e15e107ac7082) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,712 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (6/8)#0 (05fd3ea02b5c38193ae21862bb801efb) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,712 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (5/8)#0 (1146ec7e30bb7d899d474a6d45dece28) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,712 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot f33c934076f3d826201630284dfad537.
2024-02-02 12:16:29,714 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (1/8)#0 (ee431f02bf40e39dcc77e0b2d6e4d32c) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,714 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Sink: Print to Std. Out (4/8)#0 (354b4d7f255f8da859b441ab44f054c3), deploy into slot with allocation id f33c934076f3d826201630284dfad537.
2024-02-02 12:16:29,715 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 99bbcc7255a3b0c88e6e58aa34a56b7a.
2024-02-02 12:16:29,715 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (2/8)#0 (b3e95f7752a4a898894b44896271bc3c) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,715 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (8/8)#0 (d09e6fd867640d38af1b63b68a92d222) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,715 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (3/8)#0 (aa6f33f534f71e442da060df69bdc60c) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,715 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (7/8) (6871493e95a9bbee511e15e107ac7082) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,716 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (4/8)#0 (009a16502c49f5dcd2f9e635bd5a6782) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,717 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (5/8) (1146ec7e30bb7d899d474a6d45dece28) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,717 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Sink: Print to Std. Out (5/8)#0 (aa501d9858a09c9ebf332daf7ac008f0), deploy into slot with allocation id 99bbcc7255a3b0c88e6e58aa34a56b7a.
2024-02-02 12:16:29,717 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (6/8) (05fd3ea02b5c38193ae21862bb801efb) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,717 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (1/8) (ee431f02bf40e39dcc77e0b2d6e4d32c) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,717 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (2/8) (b3e95f7752a4a898894b44896271bc3c) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,717 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (8/8) (d09e6fd867640d38af1b63b68a92d222) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,717 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (3/8) (aa6f33f534f71e442da060df69bdc60c) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,717 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (4/8) (009a16502c49f5dcd2f9e635bd5a6782) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,718 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 09c5867c1c35698fe4859e44f2706879.
2024-02-02 12:16:29,717 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Source: Socket Stream (1/1)#0 (c350c727d5dc769587e0ecd8bc48af02) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,718 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Timestamps/Watermarks (1/1)#0 (4fb7d399bb21e766e9d7fc238253f4b0) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,719 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Source: Socket Stream (1/1) (c350c727d5dc769587e0ecd8bc48af02) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,719 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Timestamps/Watermarks (1/1) (4fb7d399bb21e766e9d7fc238253f4b0) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,721 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (5/8)#0 (aa501d9858a09c9ebf332daf7ac008f0) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,721 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (2/8)#0 (f89d723580ebdbdad4541f025521a35c) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,721 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Sink: Print to Std. Out (5/8)#0 (aa501d9858a09c9ebf332daf7ac008f0) [DEPLOYING].
2024-02-02 12:16:29,721 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Sink: Print to Std. Out (2/8)#0 (f89d723580ebdbdad4541f025521a35c) [DEPLOYING].
2024-02-02 12:16:29,721 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Sink: Print to Std. Out (6/8)#0 (0d85c4232b5c241ef9621132258c4f37), deploy into slot with allocation id 09c5867c1c35698fe4859e44f2706879.
2024-02-02 12:16:29,724 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (3/8)#0 (ad53fc58b87f7bce8d32061c610bc70f) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,725 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Sink: Print to Std. Out (3/8)#0 (ad53fc58b87f7bce8d32061c610bc70f) [DEPLOYING].
2024-02-02 12:16:29,725 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (1/8)#0 (d7c5126d4f5ba9d96c703379b93c4847) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,726 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 9e2c99599214d1b2a39d232b5d81c7f8.
2024-02-02 12:16:29,726 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Sink: Print to Std. Out (1/8)#0 (d7c5126d4f5ba9d96c703379b93c4847) [DEPLOYING].
2024-02-02 12:16:29,727 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@7e427f23
2024-02-02 12:16:29,727 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,725 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (6/8)#0 (0d85c4232b5c241ef9621132258c4f37) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,724 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (4/8)#0 (354b4d7f255f8da859b441ab44f054c3) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,728 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Sink: Print to Std. Out (6/8)#0 (0d85c4232b5c241ef9621132258c4f37) [DEPLOYING].
2024-02-02 12:16:29,728 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (2/8)#0 (f89d723580ebdbdad4541f025521a35c) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,728 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Sink: Print to Std. Out (4/8)#0 (354b4d7f255f8da859b441ab44f054c3) [DEPLOYING].
2024-02-02 12:16:29,729 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@d8b239
2024-02-02 12:16:29,729 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@557cbbdf
2024-02-02 12:16:29,729 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,730 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,730 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@73ce3186
2024-02-02 12:16:29,730 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (3/8)#0 (ad53fc58b87f7bce8d32061c610bc70f) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,730 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,730 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (5/8)#0 (aa501d9858a09c9ebf332daf7ac008f0) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,730 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (6/8)#0 (0d85c4232b5c241ef9621132258c4f37) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,729 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (2/8) (f89d723580ebdbdad4541f025521a35c) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,731 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@ec1b0c0
2024-02-02 12:16:29,732 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,732 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (1/8)#0 (d7c5126d4f5ba9d96c703379b93c4847) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,732 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (3/8) (ad53fc58b87f7bce8d32061c610bc70f) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,732 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@60a4c1c
2024-02-02 12:16:29,732 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,732 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (5/8) (aa501d9858a09c9ebf332daf7ac008f0) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,732 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (4/8)#0 (354b4d7f255f8da859b441ab44f054c3) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,732 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (6/8) (0d85c4232b5c241ef9621132258c4f37) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,733 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (1/8) (d7c5126d4f5ba9d96c703379b93c4847) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,734 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Sink: Print to Std. Out (7/8)#0 (3fe03cabcc6314032a082067cc6983b6), deploy into slot with allocation id 9e2c99599214d1b2a39d232b5d81c7f8.
2024-02-02 12:16:29,734 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (4/8) (354b4d7f255f8da859b441ab44f054c3) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,735 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot db9a3aec80013854f6e741b1ba81ee67.
2024-02-02 12:16:29,739 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Sink: Print to Std. Out (8/8)#0 (ec9b6f95cd17e4034644fd110023759d), deploy into slot with allocation id db9a3aec80013854f6e741b1ba81ee67.
2024-02-02 12:16:29,741 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 2b8cda9ec1b9c5ea6f53439864ce8990.
2024-02-02 12:16:29,742 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (8/8)#0 (ec9b6f95cd17e4034644fd110023759d) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,742 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Sink: Print to Std. Out (8/8)#0 (ec9b6f95cd17e4034644fd110023759d) [DEPLOYING].
2024-02-02 12:16:29,744 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (7/8)#0 (3fe03cabcc6314032a082067cc6983b6) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,745 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Sink: Print to Std. Out (7/8)#0 (3fe03cabcc6314032a082067cc6983b6) [DEPLOYING].
2024-02-02 12:16:29,748 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (1/8)#0 (fcd7c31a2d11ea6cd0f25921961eff01), deploy into slot with allocation id 2b8cda9ec1b9c5ea6f53439864ce8990.
2024-02-02 12:16:29,750 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot ea4c085db6204115d994fd8d8e5316ac.
2024-02-02 12:16:29,751 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (1/8)#0 (fcd7c31a2d11ea6cd0f25921961eff01) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,751 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (1/8)#0 (fcd7c31a2d11ea6cd0f25921961eff01) [DEPLOYING].
2024-02-02 12:16:29,756 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (2/8)#0 (2780388f5012ea0fa6aa9fa2ed1cc5f0), deploy into slot with allocation id ea4c085db6204115d994fd8d8e5316ac.
2024-02-02 12:16:29,757 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@5789409
2024-02-02 12:16:29,757 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,757 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 5e919556514b26b6f27e9abd55d7d714.
2024-02-02 12:16:29,757 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (1/8)#0 (fcd7c31a2d11ea6cd0f25921961eff01) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,759 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (1/8) (fcd7c31a2d11ea6cd0f25921961eff01) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,760 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (3/8)#0 (881e99eb44f30b7c0616c7da3f3e7ac4), deploy into slot with allocation id 5e919556514b26b6f27e9abd55d7d714.
2024-02-02 12:16:29,761 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot f33c934076f3d826201630284dfad537.
2024-02-02 12:16:29,762 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (3/8)#0 (881e99eb44f30b7c0616c7da3f3e7ac4) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,762 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (2/8)#0 (2780388f5012ea0fa6aa9fa2ed1cc5f0) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,762 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (3/8)#0 (881e99eb44f30b7c0616c7da3f3e7ac4) [DEPLOYING].
2024-02-02 12:16:29,762 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (2/8)#0 (2780388f5012ea0fa6aa9fa2ed1cc5f0) [DEPLOYING].
2024-02-02 12:16:29,764 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@2e066300
2024-02-02 12:16:29,764 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,765 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@5e641922
2024-02-02 12:16:29,765 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@add85d
2024-02-02 12:16:29,765 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,765 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,765 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (7/8)#0 (3fe03cabcc6314032a082067cc6983b6) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,765 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (2/8)#0 (2780388f5012ea0fa6aa9fa2ed1cc5f0) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,765 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (8/8)#0 (ec9b6f95cd17e4034644fd110023759d) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,766 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (2/8) (2780388f5012ea0fa6aa9fa2ed1cc5f0) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,766 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (7/8) (3fe03cabcc6314032a082067cc6983b6) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,766 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (4/8)#0 (8e867b890db6b56f04a3b6a8c8f127bc), deploy into slot with allocation id f33c934076f3d826201630284dfad537.
2024-02-02 12:16:29,766 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (8/8) (ec9b6f95cd17e4034644fd110023759d) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,766 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@339e315
2024-02-02 12:16:29,766 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,767 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (3/8)#0 (881e99eb44f30b7c0616c7da3f3e7ac4) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,767 WARN  org.apache.flink.metrics.MetricGroup                         [] - The operator name Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) exceeded the 80 characters length limit and was truncated.
2024-02-02 12:16:29,767 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (4/8)#0 (8e867b890db6b56f04a3b6a8c8f127bc) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,768 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (4/8)#0 (8e867b890db6b56f04a3b6a8c8f127bc) [DEPLOYING].
2024-02-02 12:16:29,772 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 99bbcc7255a3b0c88e6e58aa34a56b7a.
2024-02-02 12:16:29,773 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@2c1a5c15
2024-02-02 12:16:29,773 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,773 WARN  org.apache.flink.metrics.MetricGroup                         [] - The operator name Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) exceeded the 80 characters length limit and was truncated.
2024-02-02 12:16:29,773 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (4/8)#0 (8e867b890db6b56f04a3b6a8c8f127bc) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,767 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (3/8) (881e99eb44f30b7c0616c7da3f3e7ac4) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,774 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (4/8) (8e867b890db6b56f04a3b6a8c8f127bc) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,774 WARN  org.apache.flink.metrics.MetricGroup                         [] - The operator name Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) exceeded the 80 characters length limit and was truncated.
2024-02-02 12:16:29,775 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (5/8)#0 (c888162ba444f889d6e1d233cb7465c8), deploy into slot with allocation id 99bbcc7255a3b0c88e6e58aa34a56b7a.
2024-02-02 12:16:29,775 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 09c5867c1c35698fe4859e44f2706879.
2024-02-02 12:16:29,776 WARN  org.apache.flink.metrics.MetricGroup                         [] - The operator name Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) exceeded the 80 characters length limit and was truncated.
2024-02-02 12:16:29,776 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (5/8)#0 (c888162ba444f889d6e1d233cb7465c8) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,776 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (5/8)#0 (c888162ba444f889d6e1d233cb7465c8) [DEPLOYING].
2024-02-02 12:16:29,777 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (6/8)#0 (fa683d432b6c8242b2d7abc584df8aa3), deploy into slot with allocation id 09c5867c1c35698fe4859e44f2706879.
2024-02-02 12:16:29,777 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 9e2c99599214d1b2a39d232b5d81c7f8.
2024-02-02 12:16:29,779 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (7/8)#0 (32eaf56e34504b1eb3bae3f4cc032427), deploy into slot with allocation id 9e2c99599214d1b2a39d232b5d81c7f8.
2024-02-02 12:16:29,780 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (6/8)#0 (fa683d432b6c8242b2d7abc584df8aa3) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,780 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (7/8)#0 (32eaf56e34504b1eb3bae3f4cc032427) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,780 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (6/8)#0 (fa683d432b6c8242b2d7abc584df8aa3) [DEPLOYING].
2024-02-02 12:16:29,782 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (7/8)#0 (32eaf56e34504b1eb3bae3f4cc032427) [DEPLOYING].
2024-02-02 12:16:29,781 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@726d51bc
2024-02-02 12:16:29,782 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,782 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (5/8)#0 (c888162ba444f889d6e1d233cb7465c8) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,782 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@5a02ba15
2024-02-02 12:16:29,782 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,782 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (5/8) (c888162ba444f889d6e1d233cb7465c8) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,783 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (6/8)#0 (fa683d432b6c8242b2d7abc584df8aa3) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,783 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot db9a3aec80013854f6e741b1ba81ee67.
2024-02-02 12:16:29,783 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (6/8) (fa683d432b6c8242b2d7abc584df8aa3) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,783 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@d30c553
2024-02-02 12:16:29,783 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,783 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (7/8)#0 (32eaf56e34504b1eb3bae3f4cc032427) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,783 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (7/8) (32eaf56e34504b1eb3bae3f4cc032427) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,784 WARN  org.apache.flink.metrics.MetricGroup                         [] - The operator name Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) exceeded the 80 characters length limit and was truncated.
2024-02-02 12:16:29,786 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (8/8)#0 (48926f3fcc34741e8810ad03559654dc), deploy into slot with allocation id db9a3aec80013854f6e741b1ba81ee67.
2024-02-02 12:16:29,788 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 2b8cda9ec1b9c5ea6f53439864ce8990.
2024-02-02 12:16:29,790 INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor           [] - Received task Sink: Print to Std. Out (1/1)#0 (bf8c6a4669370779f7698f86d704e5d1), deploy into slot with allocation id 2b8cda9ec1b9c5ea6f53439864ce8990.
2024-02-02 12:16:29,790 WARN  org.apache.flink.metrics.MetricGroup                         [] - The operator name Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) exceeded the 80 characters length limit and was truncated.
2024-02-02 12:16:29,791 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (1/1)#0 (bf8c6a4669370779f7698f86d704e5d1) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,791 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Sink: Print to Std. Out (1/1)#0 (bf8c6a4669370779f7698f86d704e5d1) [DEPLOYING].
2024-02-02 12:16:29,792 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot ea4c085db6204115d994fd8d8e5316ac.
2024-02-02 12:16:29,792 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot db9a3aec80013854f6e741b1ba81ee67.
2024-02-02 12:16:29,792 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 2b8cda9ec1b9c5ea6f53439864ce8990.
2024-02-02 12:16:29,792 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 99bbcc7255a3b0c88e6e58aa34a56b7a.
2024-02-02 12:16:29,792 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot f33c934076f3d826201630284dfad537.
2024-02-02 12:16:29,792 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 5e919556514b26b6f27e9abd55d7d714.
2024-02-02 12:16:29,792 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 09c5867c1c35698fe4859e44f2706879.
2024-02-02 12:16:29,792 INFO  org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl [] - Activate slot 9e2c99599214d1b2a39d232b5d81c7f8.
2024-02-02 12:16:29,792 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (8/8)#0 (48926f3fcc34741e8810ad03559654dc) switched from CREATED to DEPLOYING.
2024-02-02 12:16:29,792 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Loading JAR files for task Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (8/8)#0 (48926f3fcc34741e8810ad03559654dc) [DEPLOYING].
2024-02-02 12:16:29,794 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@3d40435d
2024-02-02 12:16:29,794 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,794 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (8/8)#0 (48926f3fcc34741e8810ad03559654dc) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,796 WARN  org.apache.flink.metrics.MetricGroup                         [] - The operator name Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) exceeded the 80 characters length limit and was truncated.
2024-02-02 12:16:29,797 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (8/8) (48926f3fcc34741e8810ad03559654dc) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,798 WARN  org.apache.flink.metrics.MetricGroup                         [] - The operator name Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) exceeded the 80 characters length limit and was truncated.
2024-02-02 12:16:29,796 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@3568bd5e
2024-02-02 12:16:29,798 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Checkpoint storage is set to 'jobmanager'
2024-02-02 12:16:29,798 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (1/1)#0 (bf8c6a4669370779f7698f86d704e5d1) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,799 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (1/1) (bf8c6a4669370779f7698f86d704e5d1) switched from DEPLOYING to INITIALIZING.
2024-02-02 12:16:29,888 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder [] - Finished to build heap keyed state-backend.
2024-02-02 12:16:29,888 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder [] - Finished to build heap keyed state-backend.
2024-02-02 12:16:29,888 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder [] - Finished to build heap keyed state-backend.
2024-02-02 12:16:29,888 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder [] - Finished to build heap keyed state-backend.
2024-02-02 12:16:29,888 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder [] - Finished to build heap keyed state-backend.
2024-02-02 12:16:29,888 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder [] - Finished to build heap keyed state-backend.
2024-02-02 12:16:29,888 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder [] - Finished to build heap keyed state-backend.
2024-02-02 12:16:29,888 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder [] - Finished to build heap keyed state-backend.
2024-02-02 12:16:29,888 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder [] - Finished to build heap keyed state-backend.
2024-02-02 12:16:29,888 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder [] - Finished to build heap keyed state-backend.
2024-02-02 12:16:29,888 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder [] - Finished to build heap keyed state-backend.
2024-02-02 12:16:29,889 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder [] - Finished to build heap keyed state-backend.
2024-02-02 12:16:29,889 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder [] - Finished to build heap keyed state-backend.
2024-02-02 12:16:29,889 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder [] - Finished to build heap keyed state-backend.
2024-02-02 12:16:29,889 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder [] - Finished to build heap keyed state-backend.
2024-02-02 12:16:29,892 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder [] - Finished to build heap keyed state-backend.
2024-02-02 12:16:29,896 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Source: Socket Stream (1/1)#0 (c350c727d5dc769587e0ecd8bc48af02) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,897 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Source: Socket Stream (1/1) (c350c727d5dc769587e0ecd8bc48af02) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,912 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackend    [] - Initializing heap keyed state backend with stream factory.
2024-02-02 12:16:29,912 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackend    [] - Initializing heap keyed state backend with stream factory.
2024-02-02 12:16:29,912 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackend    [] - Initializing heap keyed state backend with stream factory.
2024-02-02 12:16:29,913 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackend    [] - Initializing heap keyed state backend with stream factory.
2024-02-02 12:16:29,913 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackend    [] - Initializing heap keyed state backend with stream factory.
2024-02-02 12:16:29,913 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackend    [] - Initializing heap keyed state backend with stream factory.
2024-02-02 12:16:29,913 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackend    [] - Initializing heap keyed state backend with stream factory.
2024-02-02 12:16:29,913 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackend    [] - Initializing heap keyed state backend with stream factory.
2024-02-02 12:16:29,913 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackend    [] - Initializing heap keyed state backend with stream factory.
2024-02-02 12:16:29,914 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackend    [] - Initializing heap keyed state backend with stream factory.
2024-02-02 12:16:29,914 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackend    [] - Initializing heap keyed state backend with stream factory.
2024-02-02 12:16:29,914 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackend    [] - Initializing heap keyed state backend with stream factory.
2024-02-02 12:16:29,914 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackend    [] - Initializing heap keyed state backend with stream factory.
2024-02-02 12:16:29,914 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackend    [] - Initializing heap keyed state backend with stream factory.
2024-02-02 12:16:29,914 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackend    [] - Initializing heap keyed state backend with stream factory.
2024-02-02 12:16:29,914 INFO  org.apache.flink.runtime.state.heap.HeapKeyedStateBackend    [] - Initializing heap keyed state backend with stream factory.
2024-02-02 12:16:29,924 INFO  org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction [] - Connecting to server socket localhost:8888
2024-02-02 12:16:29,936 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (7/8)#0 (6871493e95a9bbee511e15e107ac7082) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,937 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (8/8)#0 (d09e6fd867640d38af1b63b68a92d222) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,937 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (6/8)#0 (05fd3ea02b5c38193ae21862bb801efb) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,937 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (7/8) (6871493e95a9bbee511e15e107ac7082) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,938 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (5/8)#0 (1146ec7e30bb7d899d474a6d45dece28) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,938 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (4/8)#0 (009a16502c49f5dcd2f9e635bd5a6782) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,939 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (3/8)#0 (aa6f33f534f71e442da060df69bdc60c) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,940 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (1/1)#0 (bf8c6a4669370779f7698f86d704e5d1) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,938 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (8/8) (d09e6fd867640d38af1b63b68a92d222) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,941 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (6/8) (05fd3ea02b5c38193ae21862bb801efb) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,941 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (5/8) (1146ec7e30bb7d899d474a6d45dece28) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,942 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (4/8) (009a16502c49f5dcd2f9e635bd5a6782) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,942 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (3/8) (aa6f33f534f71e442da060df69bdc60c) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,942 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (1/1) (bf8c6a4669370779f7698f86d704e5d1) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,942 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (1/8)#0 (d7c5126d4f5ba9d96c703379b93c4847) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,943 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (1/8) (d7c5126d4f5ba9d96c703379b93c4847) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,945 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (1/8)#0 (ee431f02bf40e39dcc77e0b2d6e4d32c) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,946 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (1/8) (ee431f02bf40e39dcc77e0b2d6e4d32c) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,946 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Timestamps/Watermarks (1/1)#0 (4fb7d399bb21e766e9d7fc238253f4b0) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,946 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (3/8)#0 (ad53fc58b87f7bce8d32061c610bc70f) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,947 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Map (2/8)#0 (b3e95f7752a4a898894b44896271bc3c) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,947 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Timestamps/Watermarks (1/1) (4fb7d399bb21e766e9d7fc238253f4b0) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,947 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (3/8) (ad53fc58b87f7bce8d32061c610bc70f) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,947 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Map (2/8) (b3e95f7752a4a898894b44896271bc3c) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,956 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (6/8)#0 (0d85c4232b5c241ef9621132258c4f37) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,958 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (6/8) (0d85c4232b5c241ef9621132258c4f37) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,961 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (2/8)#0 (f89d723580ebdbdad4541f025521a35c) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,962 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (2/8) (f89d723580ebdbdad4541f025521a35c) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,963 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (8/8)#0 (ec9b6f95cd17e4034644fd110023759d) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,963 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (8/8) (ec9b6f95cd17e4034644fd110023759d) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,964 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (4/8)#0 (354b4d7f255f8da859b441ab44f054c3) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,966 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (4/8) (354b4d7f255f8da859b441ab44f054c3) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,969 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (7/8)#0 (3fe03cabcc6314032a082067cc6983b6) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,969 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Sink: Print to Std. Out (5/8)#0 (aa501d9858a09c9ebf332daf7ac008f0) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,971 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (7/8) (3fe03cabcc6314032a082067cc6983b6) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,971 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Sink: Print to Std. Out (5/8) (aa501d9858a09c9ebf332daf7ac008f0) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,989 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (7/8)#0 (32eaf56e34504b1eb3bae3f4cc032427) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,994 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (8/8)#0 (48926f3fcc34741e8810ad03559654dc) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,995 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (4/8)#0 (8e867b890db6b56f04a3b6a8c8f127bc) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,995 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (2/8)#0 (2780388f5012ea0fa6aa9fa2ed1cc5f0) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,995 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (6/8)#0 (fa683d432b6c8242b2d7abc584df8aa3) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,995 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (1/8)#0 (fcd7c31a2d11ea6cd0f25921961eff01) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,996 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (3/8)#0 (881e99eb44f30b7c0616c7da3f3e7ac4) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,996 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (7/8) (32eaf56e34504b1eb3bae3f4cc032427) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,997 INFO  org.apache.flink.runtime.taskmanager.Task                    [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (5/8)#0 (c888162ba444f889d6e1d233cb7465c8) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,997 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (8/8) (48926f3fcc34741e8810ad03559654dc) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,997 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (4/8) (8e867b890db6b56f04a3b6a8c8f127bc) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,997 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (2/8) (2780388f5012ea0fa6aa9fa2ed1cc5f0) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,998 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (6/8) (fa683d432b6c8242b2d7abc584df8aa3) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,998 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (1/8) (fcd7c31a2d11ea6cd0f25921961eff01) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,998 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (3/8) (881e99eb44f30b7c0616c7da3f3e7ac4) switched from INITIALIZING to RUNNING.
2024-02-02 12:16:29,998 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph       [] - Window(EventTimeSessionWindows(5000), EventTimeTrigger, SumAggregator, PassThroughWindowFunction) (5/8) (c888162ba444f889d6e1d233cb7465c8) switched from INITIALIZING to RUNNING.

作业启动后

  • 作业启动后:
  • netcat : 显示有外部程序(FlinkJob)监听/订阅到本端口

  • cmd : netstat -ano | findstr "18081" | jps

  • netcat 窗口中输入如下数据后:
Sensor1 1000
Sensor1 7000
Sensor1 10000
Sensor1 15000
Sensor1 17000
Sensor1 24000

Sensor2 1000
Sensor2 7000
Sensor2 10000
Sensor2 15000
Sensor2 17000
Sensor2 24000


Sensor3 18000
Sensor3 24000
Sensor3 29000
Sensor3 36000

Sensor3 45000

Sensor2 24000
Sensor2 25000
Sensor2 31000
Sensor2 35000
Sensor2 36000
Sensor2 36100

Sensor2 44000
Sensor2 45000
Sensor2 46000
Sensor2 50000
Sensor2 51000

Sensor1 55000
Sensor1 56000
Sensor1 57000

netcat

FlinkJob

...

textKey: :2> (Sensor1,10000,1)
textKey: :2> (Sensor1,7000,1)
textKey: :2> (Sensor1,15000,1)
textKey: :2> (Sensor1,1000,1)
sessionWindow: > (Sensor1,1000,1) 
textKey: :2> (Sensor1,17000,1)
textKey: :2> (Sensor1,24000,1)
sessionWindow: > (Sensor1,10000,4) 

textKey: :1> (Sensor2,1000,1)
textKey: :1> (Sensor2,10000,1)
textKey: :1> (Sensor2,7000,1)
textKey: :1> (Sensor2,17000,1)
textKey: :1> (Sensor2,15000,1)
textKey: :1> (Sensor2,24000,1)

textKey: :8> (Sensor3,18000,1)
textKey: :8> (Sensor3,24000,1)
textKey: :8> (Sensor3,29000,1)
textKey: :8> (Sensor3,36000,1)

sessionWindow: > (Sensor1,24000,1) 
sessionWindow: > (Sensor2,24000,1) 
sessionWindow: > (Sensor3,24000,2) 

textKey: :8> (Sensor3,45000,1)
sessionWindow: > (Sensor3,36000,1) 

textKey: :1> (Sensor2,24000,1)
textKey: :1> (Sensor2,25000,1)
textKey: :1> (Sensor2,31000,1)
textKey: :1> (Sensor2,35000,1)
textKey: :1> (Sensor2,36000,1)
textKey: :1> (Sensor2,36100,1)

textKey: :1> (Sensor2,44000,1)
textKey: :1> (Sensor2,45000,1)
textKey: :1> (Sensor2,46000,1)

textKey: :1> (Sensor2,51000,1) 
sessionWindow: > (Sensor3,45000,1) 

textKey: :2> (Sensor1,56000,1)
textKey: :2> (Sensor1,55000,1)
sessionWindow: > (Sensor2,44000,5)
textKey: :2> (Sensor1,57000,1)
  • 输入第1个参数表示传感器id, 空格后第2个参数表示时间,进行前一次输入与当前输入时间对比是否超过时间间隔。
  • 第1个会话窗口 7000-1000=6 秒 超过活动时间间隔5秒+延迟的watermark1秒,触发计算
  • 第2个会话窗口 24000-17000=7 秒 超过活动时间间隔5秒+延迟的watermark1秒,触发计算
Sensor1 : 
    [1000(第4个收到,收到后触发了第1个会话窗口的计算) , ]  
    【GAP】 
    [7000(第2个收到) , 10000(第1个收到) , 15000(第3个收到), 17000(第5个收到) , ] 
    【GAP】 
    [24000(第6个收到,收到后触发了第2个会话窗口的计算) , ]

Step4 访问 WEB UI

Overview

  • Overview

Jobs > Runnning Jobs / Completed Jobs

  • Overview > Running Job List [StreamWordCount]


  • Source: Socket Stream算子为例,查看算子的运行详情

http://localhost:18081/#/job/85c0f65ffc6ffca03c4c1f5897080a17/overview/bc764cd8ddf7a0cff126f51c16239658/detail

  • Task - Detail
  • Task - SubTasks
  • Task - TaskManagers
  • Task - Watermarks
  • Task - Accumulators
  • Task - BackPressure
  • Task - Metrics
  • Task - FlameGraph
  • Jobs > Running Jobs

http://localhost:18081/#/job/running

  • Jobs > Completed Jobs

http://localhost:18081/#/job/completed
无任何作业

Job Manager

  • Job Manager
  • Job Manager > Metrics

http://localhost:18081/#/job-manager/metrics

  • Job Manager > Configuration

http://localhost:18081/#/job-manager/config

Task Managers

  • Task Managers

http://localhost:18081/#/task-manager


Submit New Job

  • Submit New Job

http://localhost:18081/#/submit

X 参考文献

netstat / findstr / ...

posted @ 2024-02-02 13:07  千千寰宇  阅读(780)  评论(0编辑  收藏  举报