You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@flink.apache.org by Dawid Wysakowicz <dw...@apache.org> on 2020/07/03 07:56:46 UTC

Re: NullPointer Exception while trying to access or read ReadOnly ctx in processElement method in KeyedBroadCastProcessFunction in Apache Flink

Hi Rahul.

Could you verify that the provided code is the one that fails? Something
does not seem right for me in the stacktrace. The stacktrace shows that
you call processElement recursively, but I can not see that in the code:

com.westpac.itm.eq.pattern.TestProcess.processElement(TestProcess.java:35)
    at
com.westpac.itm.eq.pattern.TestProcess.processElement(TestProcess.java:15)
    at

Where do you exactly get the exception? When accessing the local
variable Map<String,String> incomingRule? Is it only a typo or are you
really using

Hashmap instead of java.util.HashMap? Not sure what is the Hashmap class...

If you still find some problem there, could you provide is with an
example with which we could reproduce the problem?

Best,

Dawid

On 15/06/2020 16:21, bujjirahul45 . wrote:
> I have some interesting scenario i am working on pattern matching in flink
> evaluating the incoming data against a set of patterns using
> keyedbroadcastprocessfunction, when i am running the program in IDE i am
> getting null pointer exception in processElements method when trying to
> access ReadOnlyContext but the same program is running fine in flink
> terminal, below is my keyedbroadcastprocessfunction
>
> public class TestProcess extends KeyedBroadcastProcessFunction<String,
> Tuple2<String, sampleSignal>,
>         Tuple2<String, Map<String, String>>, Tuple2<String, sampleSignal>> {
>
>     public static final MapStateDescriptor <String,Map<String,String>>
> ruleDescriptor =
>             new MapStateDescriptor <>("RuleDiscriptor",
>                     ,BasicTypeInfo.STRING_TYPE_INFO
>                     ,new MapTypeInfo<>(String.class,String.class));
>
>     @Override
>     public void processElement(Tuple2<String, sampleSignal> value,
> ReadOnlyContext ctx, Collector<Tuple2<String,
>             sampleSignal>> out) throws Exception {
>
>         System.out.println("sampleSignal: " +value.f1.toString());
>
>         String Context = ctx.getBroadcastState(ruleDescriptor).toString();
>
>         Map<String,String> incomingRule = new Hashmap<>();
>
>         incomingPattern = ctx.getBroadcastState(ruleDescriptor).get(Key);
>
>         /*It's hitting nullpointer exception when printing the size of
> hashmpa*/
>         System.out.println("Map Size: " +incomingRule.size());
>
>         System.out.println("Context: " +Context);
>
>         System.out.println("Before Rule Iterator");
>
>         /*I tried below way to print the values in broadcaststream just to
> print the values
>           in broadcast state it don't print anything*/
>         for(Map.Entry<String, Map<String, String>> rules:
>                 ctx.getBroadcastState(ruleDescriptor).immutableEntries()){
>             System.out.println("Key: " +rules.getKey());
>             System.out.println("Value: "+rules.getValue());
>         }
>
>
>         for(Map.Entry<String,String> rules: incomingRule.entrySet()){
>
>             System.out.println("Key: " +rules.getKey());
>             System.out.println("Value: "+rules.getValue());
>         }
>
>         out.collect(new Tuple2<>(value.f0,value.f1));
>
>     }
>
>     @Override
>     public void processBroadcastElement(Tuple2<String, Map<String, String>>
> value, Context ctx,
>                                         Collector<Tuple2<String,
> sampleSignal>> out) throws Exception {
>
>         System.out.println("BroadCastState Key: " +value.f0);
>         System.out.println("BroadCastState Value: " +value.f1);
>         ctx.getBroadcastState(ruleDescriptor).put(value.f0,value.f1);
>
>     }
> }
> Below is the IDE Terminal output with error exception
>
> /*Its prints below data in BroadCastState in processBroadcastElement*/
> BroadCastState Key: Key
> BroadCastState Value: {"RuleKey":"RuleValue"}
>
>
> /*Its printing below data in processElement*/
>
> sampleSignal: {SignalData}
>
> When it hits the Map in which i am storing the Rule Name and Rule Condition
> its throwing nullpointer exception and below is the stack trace of error
>
> Exception in thread "main"
> org.apache.flink.runtime.client.JobExecutionException: Job execution failed.
>     at
> org.apache.flink.runtime.jobmaster.JobResult.toJobExecutionResult(JobResult.java:146)
>     at
> org.apache.flink.runtime.minicluster.MiniCluster.executeJobBlocking(MiniCluster.java:638)
>     at
> org.apache.flink.streaming.api.environment.LocalStreamEnvironment.execute(LocalStreamEnvironment.java:123)
>     at com.westpac.itm.eq.pattern.App.main(App.java:34)
> Caused by: java.lang.NullPointerException
>     at
> com.westpac.itm.eq.pattern.TestProcess.processElement(TestProcess.java:35)
>     at
> com.westpac.itm.eq.pattern.TestProcess.processElement(TestProcess.java:15)
>     at
> org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator.processElement1(CoBroadcastWithKeyedOperator.java:113)
>     at
> org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.processInput(StreamTwoInputProcessor.java:238)
> Caused by: java.lang.NullPointerException
>
>     at
> org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask.run(TwoInputStreamTask.java:117)
>     at
> org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:300)
>     at org.apache.flink.runtime.taskmanager.Task.run(Task.java:711)
>     at java.lang.Thread.run(Thread.java:748)
>
>
> Please help me in solving the issue
>
> Thanks,
> Rahul.
>


Re: NullPointer Exception while trying to access or read ReadOnly ctx in processElement method in KeyedBroadCastProcessFunction in Apache Flink

Posted by Dawid Wysakowicz <dw...@apache.org>.
Could you please share with us the actual code that you are running.
Possibly without any debug statements. As I said in my first reply, I
can not rely relate the stack trace with the code you sent us. Moreover
in the code you sent us I can not see a way it could throw an Exception
at the line you annotated with: /*It's hitting nullpointer exception
when printing the size of hashmpa*/. You are accessing a local variable
in the function. It must not throw nullpointer exception (unless there
is something weird about Hashmap. Again I don't necessarily know what is
that class. It might be a typo and you meant HashMap or it is some class
that I don't know.)

Without an actual code that fails I am afraid we will not be able to
help you much. From the information I got so far I can only be guessing
you might be making wrong assumption on the order in which the
processElement and processBroadcast are called. As Kostas mentioned in
his response. There is no guarantee about the order of the two sides.

Best.,

Dawid



Re: NullPointer Exception while trying to access or read ReadOnly ctx in processElement method in KeyedBroadCastProcessFunction in Apache Flink

Posted by "bujjirahul45 ." <ra...@gmail.com>.
Hi,

Thanks for the reply incomingRule is nothing but incomingPattern it's a
typo and yes i am using in my program, here is my scenario i have streaming
of json events which need to be validated against a set of rules i have
multiple streams from which i am consuming data let say if i have Source A
and Source B my Map State has Key the sourcename and value is a map with
patternrule name as key and value is patterncondition  let say A is source
which is Key for Map State and Value is PatternName and PatternCondition
(A,(PatternName,PatternCondition)). In my use case when i have stream of
data my broadcast state have all the patterns for all the sources of data
but to make it more efficient i am trying to apply patterns of a particular
source to the stream, that's why i am trying to get patterns of a
particular source using key as source name
ctx.getBroadcastState(ruleDescriptor).get(Key); but when ever i am running
this in my local i am getting Null pointer exception when trying to access
the rules in broadcast state using key and this not consistent error
sometimes it runs and sometimes it throws null pointer exception when i ran
program in debug mode what i observed  is for successful run i see the
control is first going to processBroadcast method in
KeyedBroadcastProcessFunction and for unsuccessful run its first going to
processElement method and throwing null pointer exception above code how i
am trying to read broadcast state in processElement method i am attaching
the complete error log to the mail please help me in solving the issue i am
trying since long but nothing working for me i have even open method in
KeyedBroadcastProcessFunction where i am initiating the map state

if need any clarity please let me know below are my system details

OS: Windows 10
Java Version: 1.8
Flink Version: 1.10.0
IDE : IntelliJ

Below is stack trace of error

> Task :SignalPatternMatchingApp.main()
12:15:13,413 |-INFO in ch.qos.logback.classic.LoggerContext[default] -
Could NOT find resource [logback-test.xml]
12:15:13,414 |-INFO in ch.qos.logback.classic.LoggerContext[default] -
Could NOT find resource [logback.groovy]
12:15:13,414 |-INFO in ch.qos.logback.classic.LoggerContext[default] -
Found resource [logback.xml] at
[file:/C:/Users/Rahul/IdeaProjectsNew/PatternMatchingbuild/resources/main/logback.xml]
12:15:13,416 |-WARN in ch.qos.logback.classic.LoggerContext[default] -
Resource [logback.xml] occurs multiple times on the classpath.
12:15:13,416 |-WARN in ch.qos.logback.classic.LoggerContext[default] -
Resource [logback.xml] occurs at
[file:/C:/Users/Rahul/IdeaProjectsNew/PatternMatchingbuild/resources/main/logback.xml]
12:15:13,416 |-WARN in ch.qos.logback.classic.LoggerContext[default] -
Resource [logback.xml] occurs at
[jar:file:/C:/Users/Rahul/IdeaProjectsNew/PatternMatchinglibs/state-management1.10_2.12-1.0.0-SNAPSHOT.jar!/logback.xml]
12:15:13,481 |-INFO in ch.qos.logback.core.joran.action.ImplicitModelAction
- Assuming default class name
[ch.qos.logback.classic.encoder.PatternLayoutEncoder] for tag [encoder]
12:15:13,545 |-INFO in
ch.qos.logback.classic.model.processor.LoggerModelHandler@46d56d67 -
Setting level of logger [akka] to WARN
12:15:13,545 |-INFO in
ch.qos.logback.classic.model.processor.LoggerModelHandler@d8355a8 - Setting
level of logger [akka.actor.ActorSystemImpl] to WARN
12:15:13,545 |-INFO in
ch.qos.logback.classic.model.processor.LoggerModelHandler@59fa1d9b -
Setting level of logger [org.apache.kafka] to WARN
12:15:13,546 |-INFO in
ch.qos.logback.classic.model.processor.LoggerModelHandler@28d25987 -
Setting level of logger [org.apache.kafka.clients.producer.ProducerConfig]
to WARN
12:15:13,546 |-INFO in
ch.qos.logback.classic.model.processor.LoggerModelHandler@4501b7af -
Setting level of logger [org.apache.kafka.clients.consumer.ConsumerConfig]
to WARN
12:15:13,546 |-INFO in
ch.qos.logback.classic.model.processor.LoggerModelHandler@523884b2 -
Setting level of logger [org.apache.kafka.common.utils.AppInfoParser] to
ERROR
12:15:13,546 |-INFO in
ch.qos.logback.classic.model.processor.LoggerModelHandler@5b275dab -
Setting level of logger [org.apache.kafka.clients.NetworkClient] to ERROR
12:15:13,546 |-INFO in
ch.qos.logback.classic.model.processor.LoggerModelHandler@61832929 -
Setting level of logger [org.apache.flink.runtime.jobgraph.JobGraph] to
ERROR
12:15:13,546 |-INFO in
ch.qos.logback.classic.model.processor.LoggerModelHandler@29774679 -
Setting level of logger [com.eventdetection.eventfilter] to INFO
12:15:13,546 |-INFO in
ch.qos.logback.classic.model.processor.RootLoggerModelHandler@3ffc5af1 -
Setting level of ROOT logger to INFO
12:15:13,615 |-INFO in
ch.qos.logback.core.model.processor.DefaultProcessor@5e5792a0 - End of
configuration.
12:15:13,616 |-INFO in
ch.qos.logback.classic.joran.JoranConfigurator@26653222 - Registering
current configuration as safe fallback point

2020-07-07 12:15:13,660 INFO  [TypeExtractor] - class org.json.JSONObject
does not contain a getter for field map
2020-07-07 12:15:13,661 INFO  [TypeExtractor] - class org.json.JSONObject
does not contain a setter for field map
2020-07-07 12:15:13,661 INFO  [TypeExtractor] - Class class
org.json.JSONObject cannot be used as a POJO type because not all fields
are valid POJO fields, and must be processed as GenericType. Please read
the Flink documentation on "Data Types & Serialization" for details of the
effect on performance.
2020-07-07 12:15:13,736 INFO  [TypeExtractor] - class org.json.JSONObject
does not contain a getter for field map
2020-07-07 12:15:13,737 INFO  [TypeExtractor] - class org.json.JSONObject
does not contain a setter for field map
2020-07-07 12:15:13,737 INFO  [TypeExtractor] - Class class
org.json.JSONObject cannot be used as a POJO type because not all fields
are valid POJO fields, and must be processed as GenericType. Please read
the Flink documentation on "Data Types & Serialization" for details of the
effect on performance.
2020-07-07 12:15:15,188 INFO  [TypeExtractor] - class java.util.HashMap
does not contain a getter for field threshold
2020-07-07 12:15:15,188 INFO  [TypeExtractor] - class java.util.HashMap
does not contain a setter for field threshold
2020-07-07 12:15:15,188 INFO  [TypeExtractor] - Class class
java.util.HashMap cannot be used as a POJO type because not all fields are
valid POJO fields, and must be processed as GenericType. Please read the
Flink documentation on "Data Types & Serialization" for details of the
effect on performance.
2020-07-07 12:15:15,207 INFO  [TypeExtractor] - class org.json.JSONObject
does not contain a getter for field map
2020-07-07 12:15:15,208 INFO  [TypeExtractor] - class org.json.JSONObject
does not contain a setter for field map
2020-07-07 12:15:15,208 INFO  [TypeExtractor] - Class class
org.json.JSONObject cannot be used as a POJO type because not all fields
are valid POJO fields, and must be processed as GenericType. Please read
the Flink documentation on "Data Types & Serialization" for details of the
effect on performance.
2020-07-07 12:15:15,391 INFO  [TypeExtractor] - class org.json.JSONObject
does not contain a getter for field map
2020-07-07 12:15:15,391 INFO  [TypeExtractor] - class org.json.JSONObject
does not contain a setter for field map
2020-07-07 12:15:15,391 INFO  [TypeExtractor] - Class class
org.json.JSONObject cannot be used as a POJO type because not all fields
are valid POJO fields, and must be processed as GenericType. Please read
the Flink documentation on "Data Types & Serialization" for details of the
effect on performance.
2020-07-07 12:15:15,575 INFO  [TaskExecutorResourceUtils] - The
configuration option Key: 'taskmanager.cpu.cores' , default: null (fallback
keys: []) required for local execution is not set, setting it to its
default value 1.7976931348623157E308
2020-07-07 12:15:15,576 INFO  [TaskExecutorResourceUtils] - The
configuration option Key: 'taskmanager.memory.task.heap.size' , default:
null (fallback keys: []) required for local execution is not set, setting
it to its default value 9223372036854775807 bytes
2020-07-07 12:15:15,579 INFO  [TaskExecutorResourceUtils] - The
configuration option Key: 'taskmanager.memory.task.off-heap.size' ,
default: 0 bytes (fallback keys: []) required for local execution is not
set, setting it to its default value 9223372036854775807 bytes
2020-07-07 12:15:15,579 INFO  [TaskExecutorResourceUtils] - The
configuration option Key: 'taskmanager.memory.network.min' , default: 64 mb
(fallback keys: [{key=taskmanager.network.memory.min, isDeprecated=true}])
required for local execution is not set, setting it to its default value 64
mb
2020-07-07 12:15:15,580 INFO  [TaskExecutorResourceUtils] - The
configuration option Key: 'taskmanager.memory.network.max' , default: 1 gb
(fallback keys: [{key=taskmanager.network.memory.max, isDeprecated=true}])
required for local execution is not set, setting it to its default value 64
mb
2020-07-07 12:15:15,580 INFO  [TaskExecutorResourceUtils] - The
configuration option Key: 'taskmanager.memory.managed.size' , default: null
(fallback keys: [{key=taskmanager.memory.size, isDeprecated=true}])
required for local execution is not set, setting it to its default value
128 mb
2020-07-07 12:15:15,597 INFO  [MiniCluster] - Starting Flink Mini Cluster
2020-07-07 12:15:15,599 INFO  [MiniCluster] - Starting Metrics Registry
2020-07-07 12:15:15,661 INFO  [MetricRegistryImpl] - No metrics reporter
configured, no metrics will be exposed/reported.
2020-07-07 12:15:15,662 INFO  [MiniCluster] - Starting RPC Service(s)
2020-07-07 12:15:16,281 INFO  [AkkaRpcServiceUtils] - Trying to start actor
system at :0
2020-07-07 12:15:17,125 INFO  [AkkaRpcServiceUtils] - Actor system started
at akka.tcp://flink-metrics@192.168.0.103:50103
2020-07-07 12:15:17,132 INFO  [AkkaRpcService] - Starting RPC endpoint for
org.apache.flink.runtime.metrics.dump.MetricQueryService at
akka://flink-metrics/user/MetricQueryService .
2020-07-07 12:15:17,191 INFO  [MiniCluster] - Starting high-availability
services
2020-07-07 12:15:17,206 INFO  [BlobServer] - Created BLOB server storage
directory
C:\Users\RAHUL~1.KUM\AppData\Local\Temp\blobStore-7150eb6f-062e-4f52-bcb1-138261688dbc
2020-07-07 12:15:17,211 INFO  [BlobServer] - Started BLOB server at
0.0.0.0:50104 - max concurrent requests: 50 - max backlog: 1000
2020-07-07 12:15:17,215 INFO  [PermanentBlobCache] - Created BLOB cache
storage directory
C:\Users\RAHUL~1.KUM\AppData\Local\Temp\blobStore-66e432c4-20be-47d6-97fb-cd3ae9782656
2020-07-07 12:15:17,218 INFO  [TransientBlobCache] - Created BLOB cache
storage directory
C:\Users\RAHUL~1.KUM\AppData\Local\Temp\blobStore-66ee2259-5606-41f7-b7f1-7eb2621ce240
2020-07-07 12:15:17,218 INFO  [MiniCluster] - Starting 1 TaskManger(s)
2020-07-07 12:15:17,223 INFO  [TaskManagerRunner] - Starting TaskManager
with ResourceID: 82810ea2-3be7-4d71-b2d8-4769b3a19c1b
2020-07-07 12:15:17,250 INFO  [TaskManagerServices] - Temporary file
directory 'C:\Users\RAHUL~1.KUM\AppData\Local\Temp': total 475 GB, usable
248 GB (52.21% usable)
2020-07-07 12:15:17,256 INFO  [FileChannelManagerImpl] - FileChannelManager
uses directory
C:\Users\RAHUL~1.KUM\AppData\Local\Temp\flink-io-c3083c09-e755-46a5-a9ea-ff95ffce4972
for spill files.
2020-07-07 12:15:17,268 INFO  [FileChannelManagerImpl] - FileChannelManager
uses directory
C:\Users\RAHUL~1.KUM\AppData\Local\Temp\flink-netty-shuffle-108bc4f3-b0b7-4012-9c6d-e1080749a094
for spill files.
2020-07-07 12:15:17,305 INFO  [NetworkBufferPool] - Allocated 64 MB for
network buffer pool (number of memory segments: 2048, bytes per segment:
32768).
2020-07-07 12:15:17,313 INFO  [NettyShuffleEnvironment] - Starting the
network environment and its components.
2020-07-07 12:15:17,315 INFO  [KvStateService] - Starting the kvState
service and its components.
2020-07-07 12:15:17,325 INFO  [TaskManagerConfiguration] - Messages have a
max timeout of 10000 ms
2020-07-07 12:15:17,368 INFO  [AkkaRpcService] - Starting RPC endpoint for
org.apache.flink.runtime.taskexecutor.TaskExecutor at
akka://flink/user/taskmanager_0 .
2020-07-07 12:15:17,381 INFO  [JobLeaderService] - Start job leader service.
2020-07-07 12:15:17,383 INFO  [FileCache] - User file cache uses directory
C:\Users\RAHUL~1.KUM\AppData\Local\Temp\flink-dist-cache-ee90e750-8e6f-41c9-bab0-53fb3d189c71
2020-07-07 12:15:17,436 INFO  [DispatcherRestEndpoint] - Starting rest
endpoint.
2020-07-07 12:15:17,685 WARN  [WebMonitorUtils] - Log file environment
variable 'log.file' is not set.
2020-07-07 12:15:17,685 WARN  [WebMonitorUtils] - JobManager log files are
unavailable in the web dashboard. Log file location not found in
environment variable 'log.file' or configuration key 'Key: 'web.log.path' ,
default: null (fallback keys: [{key=jobmanager.web.log.path,
isDeprecated=true}])'.
2020-07-07 12:15:17,696 INFO  [DispatcherRestEndpoint] - Failed to load web
based job submission extension. Probable reason: flink-runtime-web is not
in the classpath.
2020-07-07 12:15:18,555 INFO  [DispatcherRestEndpoint] - Rest endpoint
listening at localhost:50140
2020-07-07 12:15:18,556 INFO  [EmbeddedLeaderService] - Proposing
leadership to contender http://localhost:50140
2020-07-07 12:15:18,558 INFO  [DispatcherRestEndpoint] -
http://localhost:50140 was granted leadership with
leaderSessionID=24e25c72-3ffe-4a9c-a698-6d3f9bd5714d
2020-07-07 12:15:18,558 INFO  [EmbeddedLeaderService] - Received
confirmation of leadership for leader http://localhost:50140 ,
session=24e25c72-3ffe-4a9c-a698-6d3f9bd5714d
2020-07-07 12:15:18,569 INFO  [AkkaRpcService] - Starting RPC endpoint for
org.apache.flink.runtime.resourcemanager.StandaloneResourceManager at
akka://flink/user/resourcemanager .
2020-07-07 12:15:18,584 INFO  [EmbeddedLeaderService] - Proposing
leadership to contender LeaderContender: DefaultDispatcherRunner
2020-07-07 12:15:18,585 INFO  [EmbeddedLeaderService] - Proposing
leadership to contender LeaderContender: StandaloneResourceManager
2020-07-07 12:15:18,588 INFO  [StandaloneResourceManager] - ResourceManager
akka://flink/user/resourcemanager was granted leadership with fencing token
87c358dcca39c61494f36a8da3f244ee
2020-07-07 12:15:18,591 INFO  [MiniCluster] - Flink Mini Cluster started
successfully
2020-07-07 12:15:18,595 INFO  [SessionDispatcherLeaderProcess] - Start
SessionDispatcherLeaderProcess.
2020-07-07 12:15:18,595 INFO  [SlotManagerImpl] - Starting the SlotManager.
2020-07-07 12:15:18,597 INFO  [SessionDispatcherLeaderProcess] - Recover
all persisted job graphs.
2020-07-07 12:15:18,597 INFO  [SessionDispatcherLeaderProcess] -
Successfully recovered 0 persisted job graphs.
2020-07-07 12:15:18,598 INFO  [EmbeddedLeaderService] - Received
confirmation of leadership for leader akka://flink/user/resourcemanager ,
session=94f36a8d-a3f2-44ee-87c3-58dcca39c614
2020-07-07 12:15:18,601 INFO  [TaskExecutor] - Connecting to
ResourceManager
akka://flink/user/resourcemanager(87c358dcca39c61494f36a8da3f244ee).
2020-07-07 12:15:18,610 INFO  [AkkaRpcService] - Starting RPC endpoint for
org.apache.flink.runtime.dispatcher.StandaloneDispatcher at
akka://flink/user/dispatcher .
2020-07-07 12:15:18,619 INFO  [TaskExecutor] - Resolved ResourceManager
address, beginning registration
2020-07-07 12:15:18,619 INFO  [TaskExecutor] - Registration at
ResourceManager attempt 1 (timeout=100ms)
2020-07-07 12:15:18,628 INFO  [StandaloneResourceManager] - Registering
TaskManager with ResourceID 82810ea2-3be7-4d71-b2d8-4769b3a19c1b
(akka://flink/user/taskmanager_0) at ResourceManager
2020-07-07 12:15:18,628 INFO  [EmbeddedLeaderService] - Received
confirmation of leadership for leader akka://flink/user/dispatcher ,
session=c4ecf861-20c7-4e54-9d56-1e51b77181e5
2020-07-07 12:15:18,635 INFO  [TaskExecutor] - Successful registration at
resource manager akka://flink/user/resourcemanager under registration id
1f8df00edb6126f33486bd5f4350bed9.
2020-07-07 12:15:18,639 INFO  [StandaloneDispatcher] - Received JobGraph
submission 1a828d53bc6a886fe0fc7c454e6e66b7 (Pattern-Matching).
2020-07-07 12:15:18,639 INFO  [StandaloneDispatcher] - Submitting job
1a828d53bc6a886fe0fc7c454e6e66b7 (Pattern-Matching).
2020-07-07 12:15:18,658 INFO  [AkkaRpcService] - Starting RPC endpoint for
org.apache.flink.runtime.jobmaster.JobMaster at
akka://flink/user/jobmanager_1 .
2020-07-07 12:15:18,666 INFO  [JobMaster] - Initializing job
Pattern-Matching (1a828d53bc6a886fe0fc7c454e6e66b7).
2020-07-07 12:15:18,681 INFO  [JobMaster] - Using restart back off time
strategy NoRestartBackoffTimeStrategy for Pattern-Matching
(1a828d53bc6a886fe0fc7c454e6e66b7).
2020-07-07 12:15:18,723 INFO  [JobMaster] - Running initialization on
master for job Pattern-Matching (1a828d53bc6a886fe0fc7c454e6e66b7).
2020-07-07 12:15:18,723 INFO  [JobMaster] - Successfully ran initialization
on master in 0 ms.
2020-07-07 12:15:18,762 INFO  [JobMaster] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:18,775 INFO  [RestartPipelinedRegionStrategy] - Start
building failover regions.
2020-07-07 12:15:18,776 INFO  [RestartPipelinedRegionStrategy] - Created 1
failover regions.
2020-07-07 12:15:18,776 INFO  [JobMaster] - Using failover strategy
org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy@6e46b132
for Pattern-Matching (1a828d53bc6a886fe0fc7c454e6e66b7).
2020-07-07 12:15:18,779 INFO  [EmbeddedLeaderService] - Proposing
leadership to contender akka://flink/user/jobmanager_1
2020-07-07 12:15:18,780 INFO  [JobManagerRunnerImpl] - JobManager runner
for job Pattern-Matching (1a828d53bc6a886fe0fc7c454e6e66b7) was granted
leadership with session id 6419056d-cac4-4058-a75e-313cb87effdf at
akka://flink/user/jobmanager_1.
2020-07-07 12:15:18,784 INFO  [JobMaster] - Starting execution of job
Pattern-Matching (1a828d53bc6a886fe0fc7c454e6e66b7) under job master id
a75e313cb87effdf6419056dcac44058.
2020-07-07 12:15:18,787 INFO  [JobMaster] - Starting scheduling with
scheduling strategy
[org.apache.flink.runtime.scheduler.strategy.EagerSchedulingStrategy]
2020-07-07 12:15:18,788 INFO  [ExecutionGraph] - Job Pattern-Matching
(1a828d53bc6a886fe0fc7c454e6e66b7) switched from state CREATED to RUNNING.
2020-07-07 12:15:18,795 INFO  [ExecutionGraph] - Source: Collection Source
(1/1) (406f5c97dd906161b3483e7a91cb9eee) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,795 INFO  [ExecutionGraph] - Source: Collection Source
(1/1) (23f6a4d19c5744a62c46ac48d4dfbb24) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,795 INFO  [ExecutionGraph] - Map (1/8)
(7dd6a325fe2265187b0b30bf3b4b8f63) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,795 INFO  [ExecutionGraph] - Map (2/8)
(90787449e2373696163da5670b0e543a) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,795 INFO  [ExecutionGraph] - Map (3/8)
(d94aea75380e0e32c4747eef2f51a88d) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,795 INFO  [ExecutionGraph] - Map (4/8)
(354a39e7781194b294978daa29688813) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,795 INFO  [ExecutionGraph] - Map (5/8)
(4920b55f28ea09128aaa4e0d9d4691d8) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,795 INFO  [ExecutionGraph] - Map (6/8)
(00f29aa2e8fe5300b05fc93432299ebd) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,795 INFO  [ExecutionGraph] - Map (7/8)
(ac26eefbff14e55f031a055c1d6fa7f3) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,796 INFO  [ExecutionGraph] - Map (8/8)
(b1bf6bb7283e70c58b370665b2d2fd84) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,796 INFO  [ExecutionGraph] - Flat Map (1/8)
(1a117aa5347465fcc2cd5e58c286ccca) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,796 INFO  [ExecutionGraph] - Flat Map (2/8)
(32f2429b06954884543a4de062edf6f6) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,796 INFO  [ExecutionGraph] - Flat Map (3/8)
(63a7c3f2b7a8d110232374c700e6378a) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,796 INFO  [ExecutionGraph] - Flat Map (4/8)
(de310509f095e00584ce128336e19adf) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,796 INFO  [ExecutionGraph] - Flat Map (5/8)
(3bb74ec008b43ffe86edd6a7f84844a0) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,796 INFO  [ExecutionGraph] - Flat Map (6/8)
(3a3a78fb1ae4384a264d417013dc864d) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,796 INFO  [ExecutionGraph] - Flat Map (7/8)
(c1ca47240e15ef6c60f1943aed1b45ba) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,796 INFO  [ExecutionGraph] - Flat Map (8/8)
(0fded4a7816a9d9a219c520891d2b38d) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,796 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (1/8)
(8fa9c71df79d439827a1d290d9ad9abd) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,796 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (2/8)
(67a21177a7598f3f1ccc5001fe6951c3) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,796 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (3/8)
(8d860a734d5b6a50194a5caad135a844) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,796 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (4/8)
(ee3c4e895e82f77ad9a055ee788f4a2b) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,796 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (5/8)
(33a27b2d97c96658fd43db24177236bc) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,796 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (6/8)
(6a75da55421a929d4b3d4ebd655414e9) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,796 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (7/8)
(351cc238fecce28d1dfdc5ac357ef8e4) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,796 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (8/8)
(773fad58ff1418ae919a0900e4da6ef5) switched from CREATED to SCHEDULED.
2020-07-07 12:15:18,812 INFO  [SlotPoolImpl] - Cannot serve slot request,
no ResourceManager connected. Adding as pending request
[SlotRequestId{58f52694f67b7fe9b2d2876ecb24a09a}]
2020-07-07 12:15:18,824 INFO  [EmbeddedLeaderService] - Received
confirmation of leadership for leader akka://flink/user/jobmanager_1 ,
session=6419056d-cac4-4058-a75e-313cb87effdf
2020-07-07 12:15:18,824 INFO  [JobMaster] - Connecting to ResourceManager
akka://flink/user/resourcemanager(87c358dcca39c61494f36a8da3f244ee)
2020-07-07 12:15:18,826 INFO  [JobMaster] - Resolved ResourceManager
address, beginning registration
2020-07-07 12:15:18,827 INFO  [JobMaster] - Registration at ResourceManager
attempt 1 (timeout=100ms)
2020-07-07 12:15:18,828 INFO  [StandaloneResourceManager] - Registering job
manager a75e313cb87effdf6419056dcac44058@akka://flink/user/jobmanager_1 for
job 1a828d53bc6a886fe0fc7c454e6e66b7.
2020-07-07 12:15:18,832 INFO  [StandaloneResourceManager] - Registered job
manager a75e313cb87effdf6419056dcac44058@akka://flink/user/jobmanager_1 for
job 1a828d53bc6a886fe0fc7c454e6e66b7.
2020-07-07 12:15:18,833 INFO  [JobMaster] - JobManager successfully
registered at ResourceManager, leader id: 87c358dcca39c61494f36a8da3f244ee.
2020-07-07 12:15:18,834 INFO  [SlotPoolImpl] - Requesting new slot
[SlotRequestId{58f52694f67b7fe9b2d2876ecb24a09a}] and profile
ResourceProfile{UNKNOWN} from resource manager.
2020-07-07 12:15:18,835 INFO  [StandaloneResourceManager] - Request slot
with profile ResourceProfile{UNKNOWN} for job
1a828d53bc6a886fe0fc7c454e6e66b7 with allocation id
7ed77eaff3404148674a6d8ace6711b1.
2020-07-07 12:15:18,841 INFO  [TaskExecutor] - Receive slot request
7ed77eaff3404148674a6d8ace6711b1 for job 1a828d53bc6a886fe0fc7c454e6e66b7
from resource manager with leader id 87c358dcca39c61494f36a8da3f244ee.
2020-07-07 12:15:18,848 INFO  [TaskExecutor] - Allocated slot for
7ed77eaff3404148674a6d8ace6711b1.
2020-07-07 12:15:18,848 INFO  [JobLeaderService] - Add job
1a828d53bc6a886fe0fc7c454e6e66b7 for job leader monitoring.
2020-07-07 12:15:18,851 INFO  [JobLeaderService] - Try to register at job
manager akka://flink/user/jobmanager_1 with leader id
6419056d-cac4-4058-a75e-313cb87effdf.
2020-07-07 12:15:18,852 INFO  [JobLeaderService] - Resolved JobManager
address, beginning registration
2020-07-07 12:15:18,852 INFO  [JobLeaderService] - Registration at
JobManager attempt 1 (timeout=100ms)
2020-07-07 12:15:18,855 INFO  [JobLeaderService] - Successful registration
at job manager akka://flink/user/jobmanager_1 for job
1a828d53bc6a886fe0fc7c454e6e66b7.
2020-07-07 12:15:18,855 INFO  [TaskExecutor] - Establish JobManager
connection for job 1a828d53bc6a886fe0fc7c454e6e66b7.
2020-07-07 12:15:18,858 INFO  [TaskExecutor] - Offer reserved slots to the
leader of job 1a828d53bc6a886fe0fc7c454e6e66b7.
2020-07-07 12:15:18,867 INFO  [SlotPoolImpl] - Requesting new slot
[SlotRequestId{e17f6e7a8cb2b707927f4bf0b63ac7fc}] and profile
ResourceProfile{UNKNOWN} from resource manager.
2020-07-07 12:15:18,867 INFO  [StandaloneResourceManager] - Request slot
with profile ResourceProfile{UNKNOWN} for job
1a828d53bc6a886fe0fc7c454e6e66b7 with allocation id
ea338a9c24fd1fbc154b82895ffd6120.
2020-07-07 12:15:18,867 INFO  [SlotPoolImpl] - Requesting new slot
[SlotRequestId{130f8e106ae025b4dce44f60fef42037}] and profile
ResourceProfile{UNKNOWN} from resource manager.
2020-07-07 12:15:18,868 INFO  [TaskExecutor] - Receive slot request
ea338a9c24fd1fbc154b82895ffd6120 for job 1a828d53bc6a886fe0fc7c454e6e66b7
from resource manager with leader id 87c358dcca39c61494f36a8da3f244ee.
2020-07-07 12:15:18,868 INFO  [StandaloneResourceManager] - Request slot
with profile ResourceProfile{UNKNOWN} for job
1a828d53bc6a886fe0fc7c454e6e66b7 with allocation id
da9c2d5e020a3726c2322ec3a2751385.
2020-07-07 12:15:18,868 INFO  [SlotPoolImpl] - Requesting new slot
[SlotRequestId{287620b4d0fdfe70e0b2034d70bd7c14}] and profile
ResourceProfile{UNKNOWN} from resource manager.
2020-07-07 12:15:18,868 INFO  [TaskExecutor] - Allocated slot for
ea338a9c24fd1fbc154b82895ffd6120.
2020-07-07 12:15:18,868 INFO  [TaskExecutor] - Offer reserved slots to the
leader of job 1a828d53bc6a886fe0fc7c454e6e66b7.
2020-07-07 12:15:18,868 INFO  [StandaloneResourceManager] - Request slot
with profile ResourceProfile{UNKNOWN} for job
1a828d53bc6a886fe0fc7c454e6e66b7 with allocation id
78475a44354404e70780c097ecb9fc1f.
2020-07-07 12:15:18,868 INFO  [SlotPoolImpl] - Requesting new slot
[SlotRequestId{e74981de67c0e79dd58ef17a24ad7d38}] and profile
ResourceProfile{UNKNOWN} from resource manager.
2020-07-07 12:15:18,871 INFO  [SlotPoolImpl] - Requesting new slot
[SlotRequestId{789b027cf9d0af06f9bf2e1fffd7f722}] and profile
ResourceProfile{UNKNOWN} from resource manager.
2020-07-07 12:15:18,872 INFO  [StandaloneResourceManager] - Request slot
with profile ResourceProfile{UNKNOWN} for job
1a828d53bc6a886fe0fc7c454e6e66b7 with allocation id
35b8f6d367b0b1d9664011f8c9b9c0f5.
2020-07-07 12:15:18,871 INFO  [TaskExecutor] - Receive slot request
da9c2d5e020a3726c2322ec3a2751385 for job 1a828d53bc6a886fe0fc7c454e6e66b7
from resource manager with leader id 87c358dcca39c61494f36a8da3f244ee.
2020-07-07 12:15:18,873 INFO  [SlotPoolImpl] - Requesting new slot
[SlotRequestId{d8a7e44795f9913af80c621e18cdcbe8}] and profile
ResourceProfile{UNKNOWN} from resource manager.
2020-07-07 12:15:18,874 INFO  [SlotPoolImpl] - Requesting new slot
[SlotRequestId{9c87334ce0b5a225cb137d5c718eec2d}] and profile
ResourceProfile{UNKNOWN} from resource manager.
2020-07-07 12:15:18,874 INFO  [TaskExecutor] - Allocated slot for
da9c2d5e020a3726c2322ec3a2751385.
2020-07-07 12:15:18,874 INFO  [StandaloneResourceManager] - Request slot
with profile ResourceProfile{UNKNOWN} for job
1a828d53bc6a886fe0fc7c454e6e66b7 with allocation id
5d7bf9557ad3dbdf879e87d57521a3ce.
2020-07-07 12:15:18,874 INFO  [TaskExecutor] - Offer reserved slots to the
leader of job 1a828d53bc6a886fe0fc7c454e6e66b7.
2020-07-07 12:15:18,875 INFO  [TaskExecutor] - Receive slot request
78475a44354404e70780c097ecb9fc1f for job 1a828d53bc6a886fe0fc7c454e6e66b7
from resource manager with leader id 87c358dcca39c61494f36a8da3f244ee.
2020-07-07 12:15:18,876 INFO  [TaskExecutor] - Allocated slot for
78475a44354404e70780c097ecb9fc1f.
2020-07-07 12:15:18,876 INFO  [StandaloneResourceManager] - Request slot
with profile ResourceProfile{UNKNOWN} for job
1a828d53bc6a886fe0fc7c454e6e66b7 with allocation id
ea0301a300a6eccd4a86b5c7061eba6b.
2020-07-07 12:15:18,876 INFO  [TaskExecutor] - Offer reserved slots to the
leader of job 1a828d53bc6a886fe0fc7c454e6e66b7.
2020-07-07 12:15:18,876 INFO  [TaskExecutor] - Receive slot request
35b8f6d367b0b1d9664011f8c9b9c0f5 for job 1a828d53bc6a886fe0fc7c454e6e66b7
from resource manager with leader id 87c358dcca39c61494f36a8da3f244ee.
2020-07-07 12:15:18,876 INFO  [StandaloneResourceManager] - Request slot
with profile ResourceProfile{UNKNOWN} for job
1a828d53bc6a886fe0fc7c454e6e66b7 with allocation id
606b583518d47a7b301071fe38f9720c.
2020-07-07 12:15:18,876 INFO  [TaskExecutor] - Allocated slot for
35b8f6d367b0b1d9664011f8c9b9c0f5.
2020-07-07 12:15:18,877 INFO  [TaskExecutor] - Offer reserved slots to the
leader of job 1a828d53bc6a886fe0fc7c454e6e66b7.
2020-07-07 12:15:18,877 INFO  [SlotPoolImpl] - Received repeated offer for
slot [7ed77eaff3404148674a6d8ace6711b1]. Ignoring.
2020-07-07 12:15:18,877 INFO  [TaskExecutor] - Receive slot request
5d7bf9557ad3dbdf879e87d57521a3ce for job 1a828d53bc6a886fe0fc7c454e6e66b7
from resource manager with leader id 87c358dcca39c61494f36a8da3f244ee.
2020-07-07 12:15:18,877 INFO  [SlotPoolImpl] - Received repeated offer for
slot [ea338a9c24fd1fbc154b82895ffd6120]. Ignoring.
2020-07-07 12:15:18,877 INFO  [SlotPoolImpl] - Received repeated offer for
slot [7ed77eaff3404148674a6d8ace6711b1]. Ignoring.
2020-07-07 12:15:18,877 INFO  [TaskExecutor] - Allocated slot for
5d7bf9557ad3dbdf879e87d57521a3ce.
2020-07-07 12:15:18,877 INFO  [TaskExecutor] - Offer reserved slots to the
leader of job 1a828d53bc6a886fe0fc7c454e6e66b7.
2020-07-07 12:15:18,878 INFO  [SlotPoolImpl] - Received repeated offer for
slot [ea338a9c24fd1fbc154b82895ffd6120]. Ignoring.
2020-07-07 12:15:18,878 INFO  [TaskExecutor] - Receive slot request
ea0301a300a6eccd4a86b5c7061eba6b for job 1a828d53bc6a886fe0fc7c454e6e66b7
from resource manager with leader id 87c358dcca39c61494f36a8da3f244ee.
2020-07-07 12:15:18,878 INFO  [TaskExecutor] - Allocated slot for
ea0301a300a6eccd4a86b5c7061eba6b.
2020-07-07 12:15:18,878 INFO  [TaskExecutor] - Offer reserved slots to the
leader of job 1a828d53bc6a886fe0fc7c454e6e66b7.
2020-07-07 12:15:18,878 INFO  [SlotPoolImpl] - Received repeated offer for
slot [7ed77eaff3404148674a6d8ace6711b1]. Ignoring.
2020-07-07 12:15:18,878 INFO  [SlotPoolImpl] - Received repeated offer for
slot [da9c2d5e020a3726c2322ec3a2751385]. Ignoring.
2020-07-07 12:15:18,878 INFO  [SlotPoolImpl] - Received repeated offer for
slot [ea338a9c24fd1fbc154b82895ffd6120]. Ignoring.
2020-07-07 12:15:18,879 INFO  [SlotPoolImpl] - Received repeated offer for
slot [78475a44354404e70780c097ecb9fc1f]. Ignoring.
2020-07-07 12:15:18,879 INFO  [SlotPoolImpl] - Received repeated offer for
slot [7ed77eaff3404148674a6d8ace6711b1]. Ignoring.
2020-07-07 12:15:18,879 INFO  [TaskExecutor] - Receive slot request
606b583518d47a7b301071fe38f9720c for job 1a828d53bc6a886fe0fc7c454e6e66b7
from resource manager with leader id 87c358dcca39c61494f36a8da3f244ee.
2020-07-07 12:15:18,879 INFO  [SlotPoolImpl] - Received repeated offer for
slot [da9c2d5e020a3726c2322ec3a2751385]. Ignoring.
2020-07-07 12:15:18,879 INFO  [SlotPoolImpl] - Received repeated offer for
slot [ea338a9c24fd1fbc154b82895ffd6120]. Ignoring.
2020-07-07 12:15:18,879 INFO  [SlotPoolImpl] - Received repeated offer for
slot [78475a44354404e70780c097ecb9fc1f]. Ignoring.
2020-07-07 12:15:18,879 INFO  [TaskExecutor] - Allocated slot for
606b583518d47a7b301071fe38f9720c.
2020-07-07 12:15:18,879 INFO  [SlotPoolImpl] - Received repeated offer for
slot [7ed77eaff3404148674a6d8ace6711b1]. Ignoring.
2020-07-07 12:15:18,879 INFO  [TaskExecutor] - Offer reserved slots to the
leader of job 1a828d53bc6a886fe0fc7c454e6e66b7.
2020-07-07 12:15:18,879 INFO  [SlotPoolImpl] - Received repeated offer for
slot [35b8f6d367b0b1d9664011f8c9b9c0f5]. Ignoring.
2020-07-07 12:15:18,879 INFO  [SlotPoolImpl] - Received repeated offer for
slot [da9c2d5e020a3726c2322ec3a2751385]. Ignoring.
2020-07-07 12:15:18,880 INFO  [SlotPoolImpl] - Received repeated offer for
slot [ea338a9c24fd1fbc154b82895ffd6120]. Ignoring.
2020-07-07 12:15:18,880 INFO  [SlotPoolImpl] - Received repeated offer for
slot [78475a44354404e70780c097ecb9fc1f]. Ignoring.
2020-07-07 12:15:18,880 INFO  [SlotPoolImpl] - Received repeated offer for
slot [7ed77eaff3404148674a6d8ace6711b1]. Ignoring.
2020-07-07 12:15:18,880 INFO  [TaskSlotTableImpl] - Activate slot
7ed77eaff3404148674a6d8ace6711b1.
2020-07-07 12:15:18,880 INFO  [SlotPoolImpl] - Received repeated offer for
slot [35b8f6d367b0b1d9664011f8c9b9c0f5]. Ignoring.
2020-07-07 12:15:18,880 INFO  [SlotPoolImpl] - Received repeated offer for
slot [5d7bf9557ad3dbdf879e87d57521a3ce]. Ignoring.
2020-07-07 12:15:18,880 INFO  [SlotPoolImpl] - Received repeated offer for
slot [da9c2d5e020a3726c2322ec3a2751385]. Ignoring.
2020-07-07 12:15:18,880 INFO  [TaskSlotTableImpl] - Activate slot
ea338a9c24fd1fbc154b82895ffd6120.
2020-07-07 12:15:18,880 INFO  [TaskSlotTableImpl] - Activate slot
7ed77eaff3404148674a6d8ace6711b1.
2020-07-07 12:15:18,880 INFO  [TaskSlotTableImpl] - Activate slot
ea338a9c24fd1fbc154b82895ffd6120.
2020-07-07 12:15:18,880 INFO  [TaskSlotTableImpl] - Activate slot
7ed77eaff3404148674a6d8ace6711b1.
2020-07-07 12:15:18,880 INFO  [TaskSlotTableImpl] - Activate slot
da9c2d5e020a3726c2322ec3a2751385.
2020-07-07 12:15:18,880 INFO  [TaskSlotTableImpl] - Activate slot
ea338a9c24fd1fbc154b82895ffd6120.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
78475a44354404e70780c097ecb9fc1f.
2020-07-07 12:15:18,881 INFO  [SlotPoolImpl] - Received repeated offer for
slot [ea338a9c24fd1fbc154b82895ffd6120]. Ignoring.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
7ed77eaff3404148674a6d8ace6711b1.
2020-07-07 12:15:18,881 INFO  [SlotPoolImpl] - Received repeated offer for
slot [78475a44354404e70780c097ecb9fc1f]. Ignoring.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
da9c2d5e020a3726c2322ec3a2751385.
2020-07-07 12:15:18,881 INFO  [SlotPoolImpl] - Received repeated offer for
slot [7ed77eaff3404148674a6d8ace6711b1]. Ignoring.
2020-07-07 12:15:18,881 INFO  [SlotPoolImpl] - Received repeated offer for
slot [35b8f6d367b0b1d9664011f8c9b9c0f5]. Ignoring.
2020-07-07 12:15:18,881 INFO  [SlotPoolImpl] - Received repeated offer for
slot [5d7bf9557ad3dbdf879e87d57521a3ce]. Ignoring.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
ea338a9c24fd1fbc154b82895ffd6120.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
78475a44354404e70780c097ecb9fc1f.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
7ed77eaff3404148674a6d8ace6711b1.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
35b8f6d367b0b1d9664011f8c9b9c0f5.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
da9c2d5e020a3726c2322ec3a2751385.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
ea338a9c24fd1fbc154b82895ffd6120.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
78475a44354404e70780c097ecb9fc1f.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
7ed77eaff3404148674a6d8ace6711b1.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
35b8f6d367b0b1d9664011f8c9b9c0f5.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
5d7bf9557ad3dbdf879e87d57521a3ce.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
da9c2d5e020a3726c2322ec3a2751385.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
ea338a9c24fd1fbc154b82895ffd6120.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
78475a44354404e70780c097ecb9fc1f.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
7ed77eaff3404148674a6d8ace6711b1.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
35b8f6d367b0b1d9664011f8c9b9c0f5.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
5d7bf9557ad3dbdf879e87d57521a3ce.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
da9c2d5e020a3726c2322ec3a2751385.
2020-07-07 12:15:18,881 INFO  [TaskSlotTableImpl] - Activate slot
ea0301a300a6eccd4a86b5c7061eba6b.
2020-07-07 12:15:18,883 INFO  [ExecutionGraph] - Source: Collection Source
(1/1) (406f5c97dd906161b3483e7a91cb9eee) switched from SCHEDULED to
DEPLOYING.
2020-07-07 12:15:18,884 INFO  [ExecutionGraph] - Deploying Source:
Collection Source (1/1) (attempt #0) to
82810ea2-3be7-4d71-b2d8-4769b3a19c1b @ kubernetes.docker.internal
(dataPort=-1)
2020-07-07 12:15:18,890 INFO  [ExecutionGraph] - Source: Collection Source
(1/1) (23f6a4d19c5744a62c46ac48d4dfbb24) switched from SCHEDULED to
DEPLOYING.
2020-07-07 12:15:18,890 INFO  [ExecutionGraph] - Deploying Source:
Collection Source (1/1) (attempt #0) to
82810ea2-3be7-4d71-b2d8-4769b3a19c1b @ kubernetes.docker.internal
(dataPort=-1)
2020-07-07 12:15:18,890 INFO  [ExecutionGraph] - Map (1/8)
(7dd6a325fe2265187b0b30bf3b4b8f63) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,891 INFO  [ExecutionGraph] - Deploying Map (1/8)
(attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,892 INFO  [ExecutionGraph] - Map (2/8)
(90787449e2373696163da5670b0e543a) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,892 INFO  [ExecutionGraph] - Deploying Map (2/8)
(attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,892 INFO  [ExecutionGraph] - Map (3/8)
(d94aea75380e0e32c4747eef2f51a88d) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,893 INFO  [ExecutionGraph] - Deploying Map (3/8)
(attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,893 INFO  [ExecutionGraph] - Map (4/8)
(354a39e7781194b294978daa29688813) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,893 INFO  [ExecutionGraph] - Deploying Map (4/8)
(attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,893 INFO  [ExecutionGraph] - Map (5/8)
(4920b55f28ea09128aaa4e0d9d4691d8) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,893 INFO  [ExecutionGraph] - Deploying Map (5/8)
(attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,893 INFO  [ExecutionGraph] - Map (6/8)
(00f29aa2e8fe5300b05fc93432299ebd) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,893 INFO  [ExecutionGraph] - Deploying Map (6/8)
(attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,893 INFO  [ExecutionGraph] - Map (7/8)
(ac26eefbff14e55f031a055c1d6fa7f3) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,894 INFO  [ExecutionGraph] - Deploying Map (7/8)
(attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,894 INFO  [ExecutionGraph] - Map (8/8)
(b1bf6bb7283e70c58b370665b2d2fd84) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,894 INFO  [ExecutionGraph] - Deploying Map (8/8)
(attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,894 INFO  [ExecutionGraph] - Flat Map (1/8)
(1a117aa5347465fcc2cd5e58c286ccca) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,894 INFO  [ExecutionGraph] - Deploying Flat Map (1/8)
(attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,894 INFO  [ExecutionGraph] - Flat Map (2/8)
(32f2429b06954884543a4de062edf6f6) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,894 INFO  [ExecutionGraph] - Deploying Flat Map (2/8)
(attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,894 INFO  [ExecutionGraph] - Flat Map (3/8)
(63a7c3f2b7a8d110232374c700e6378a) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,895 INFO  [ExecutionGraph] - Deploying Flat Map (3/8)
(attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,895 INFO  [ExecutionGraph] - Flat Map (4/8)
(de310509f095e00584ce128336e19adf) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,895 INFO  [ExecutionGraph] - Deploying Flat Map (4/8)
(attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,895 INFO  [ExecutionGraph] - Flat Map (5/8)
(3bb74ec008b43ffe86edd6a7f84844a0) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,895 INFO  [ExecutionGraph] - Deploying Flat Map (5/8)
(attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,895 INFO  [ExecutionGraph] - Flat Map (6/8)
(3a3a78fb1ae4384a264d417013dc864d) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,895 INFO  [ExecutionGraph] - Deploying Flat Map (6/8)
(attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,895 INFO  [ExecutionGraph] - Flat Map (7/8)
(c1ca47240e15ef6c60f1943aed1b45ba) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,895 INFO  [ExecutionGraph] - Deploying Flat Map (7/8)
(attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,895 INFO  [ExecutionGraph] - Flat Map (8/8)
(0fded4a7816a9d9a219c520891d2b38d) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,896 INFO  [ExecutionGraph] - Deploying Flat Map (8/8)
(attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,896 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (1/8)
(8fa9c71df79d439827a1d290d9ad9abd) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,896 INFO  [ExecutionGraph] - Deploying
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (1/8) (attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,896 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (2/8)
(67a21177a7598f3f1ccc5001fe6951c3) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,896 INFO  [ExecutionGraph] - Deploying
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (2/8) (attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,897 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (3/8)
(8d860a734d5b6a50194a5caad135a844) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,897 INFO  [ExecutionGraph] - Deploying
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (3/8) (attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,897 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (4/8)
(ee3c4e895e82f77ad9a055ee788f4a2b) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,897 INFO  [ExecutionGraph] - Deploying
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (4/8) (attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,897 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (5/8)
(33a27b2d97c96658fd43db24177236bc) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,897 INFO  [ExecutionGraph] - Deploying
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (5/8) (attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,897 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (6/8)
(6a75da55421a929d4b3d4ebd655414e9) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,897 INFO  [ExecutionGraph] - Deploying
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (6/8) (attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,897 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (7/8)
(351cc238fecce28d1dfdc5ac357ef8e4) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,897 INFO  [ExecutionGraph] - Deploying
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (7/8) (attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,898 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (8/8)
(773fad58ff1418ae919a0900e4da6ef5) switched from SCHEDULED to DEPLOYING.
2020-07-07 12:15:18,898 INFO  [ExecutionGraph] - Deploying
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (8/8) (attempt #0) to 82810ea2-3be7-4d71-b2d8-4769b3a19c1b @
kubernetes.docker.internal (dataPort=-1)
2020-07-07 12:15:18,898 INFO  [SlotPoolImpl] - Received repeated offer for
slot [da9c2d5e020a3726c2322ec3a2751385]. Ignoring.
2020-07-07 12:15:18,898 INFO  [SlotPoolImpl] - Received repeated offer for
slot [ea0301a300a6eccd4a86b5c7061eba6b]. Ignoring.
2020-07-07 12:15:18,916 INFO  [TaskExecutor] - Received task Source:
Collection Source (1/1).
2020-07-07 12:15:18,917 INFO  [Task] - Source: Collection Source (1/1)
(406f5c97dd906161b3483e7a91cb9eee) switched from CREATED to DEPLOYING.
2020-07-07 12:15:18,917 INFO  [Task] - Creating FileSystem stream leak
safety net for task Source: Collection Source (1/1)
(406f5c97dd906161b3483e7a91cb9eee) [DEPLOYING]
2020-07-07 12:15:18,921 INFO  [TaskExecutor] - Received task Source:
Collection Source (1/1).
2020-07-07 12:15:18,921 INFO  [Task] - Loading JAR files for task Source:
Collection Source (1/1) (406f5c97dd906161b3483e7a91cb9eee) [DEPLOYING].
2020-07-07 12:15:18,922 INFO  [Task] - Source: Collection Source (1/1)
(23f6a4d19c5744a62c46ac48d4dfbb24) switched from CREATED to DEPLOYING.
2020-07-07 12:15:18,922 INFO  [Task] - Creating FileSystem stream leak
safety net for task Source: Collection Source (1/1)
(23f6a4d19c5744a62c46ac48d4dfbb24) [DEPLOYING]
2020-07-07 12:15:18,922 INFO  [Task] - Loading JAR files for task Source:
Collection Source (1/1) (23f6a4d19c5744a62c46ac48d4dfbb24) [DEPLOYING].
2020-07-07 12:15:18,924 INFO  [Task] - Registering task at network: Source:
Collection Source (1/1) (406f5c97dd906161b3483e7a91cb9eee) [DEPLOYING].
2020-07-07 12:15:18,924 INFO  [Task] - Registering task at network: Source:
Collection Source (1/1) (23f6a4d19c5744a62c46ac48d4dfbb24) [DEPLOYING].
2020-07-07 12:15:18,933 INFO  [TaskExecutor] - Received task Map (1/8).
2020-07-07 12:15:18,935 INFO  [Task] - Map (1/8)
(7dd6a325fe2265187b0b30bf3b4b8f63) switched from CREATED to DEPLOYING.
2020-07-07 12:15:18,935 INFO  [Task] - Creating FileSystem stream leak
safety net for task Map (1/8) (7dd6a325fe2265187b0b30bf3b4b8f63) [DEPLOYING]
2020-07-07 12:15:18,935 INFO  [Task] - Loading JAR files for task Map (1/8)
(7dd6a325fe2265187b0b30bf3b4b8f63) [DEPLOYING].
2020-07-07 12:15:18,936 INFO  [Task] - Registering task at network: Map
(1/8) (7dd6a325fe2265187b0b30bf3b4b8f63) [DEPLOYING].
2020-07-07 12:15:18,938 INFO  [TaskExecutor] - Received task Map (2/8).
2020-07-07 12:15:18,939 INFO  [Task] - Map (2/8)
(90787449e2373696163da5670b0e543a) switched from CREATED to DEPLOYING.
2020-07-07 12:15:18,939 INFO  [Task] - Creating FileSystem stream leak
safety net for task Map (2/8) (90787449e2373696163da5670b0e543a) [DEPLOYING]
2020-07-07 12:15:18,939 INFO  [Task] - Loading JAR files for task Map (2/8)
(90787449e2373696163da5670b0e543a) [DEPLOYING].
2020-07-07 12:15:18,940 INFO  [Task] - Registering task at network: Map
(2/8) (90787449e2373696163da5670b0e543a) [DEPLOYING].
2020-07-07 12:15:18,943 INFO  [TaskExecutor] - Received task Map (3/8).
2020-07-07 12:15:18,944 INFO  [Task] - Map (3/8)
(d94aea75380e0e32c4747eef2f51a88d) switched from CREATED to DEPLOYING.
2020-07-07 12:15:18,944 INFO  [Task] - Creating FileSystem stream leak
safety net for task Map (3/8) (d94aea75380e0e32c4747eef2f51a88d) [DEPLOYING]
2020-07-07 12:15:18,945 INFO  [Task] - Loading JAR files for task Map (3/8)
(d94aea75380e0e32c4747eef2f51a88d) [DEPLOYING].
2020-07-07 12:15:18,946 INFO  [Task] - Registering task at network: Map
(3/8) (d94aea75380e0e32c4747eef2f51a88d) [DEPLOYING].
2020-07-07 12:15:18,948 INFO  [TaskExecutor] - Received task Map (4/8).
2020-07-07 12:15:18,948 INFO  [Task] - Map (4/8)
(354a39e7781194b294978daa29688813) switched from CREATED to DEPLOYING.
2020-07-07 12:15:18,948 INFO  [Task] - Creating FileSystem stream leak
safety net for task Map (4/8) (354a39e7781194b294978daa29688813) [DEPLOYING]
2020-07-07 12:15:18,949 INFO  [Task] - Loading JAR files for task Map (4/8)
(354a39e7781194b294978daa29688813) [DEPLOYING].
2020-07-07 12:15:18,951 INFO  [Task] - Registering task at network: Map
(4/8) (354a39e7781194b294978daa29688813) [DEPLOYING].
2020-07-07 12:15:18,953 INFO  [TaskExecutor] - Received task Map (5/8).
2020-07-07 12:15:18,954 INFO  [Task] - Map (5/8)
(4920b55f28ea09128aaa4e0d9d4691d8) switched from CREATED to DEPLOYING.
2020-07-07 12:15:18,955 INFO  [Task] - Creating FileSystem stream leak
safety net for task Map (5/8) (4920b55f28ea09128aaa4e0d9d4691d8) [DEPLOYING]
2020-07-07 12:15:18,955 INFO  [Task] - Loading JAR files for task Map (5/8)
(4920b55f28ea09128aaa4e0d9d4691d8) [DEPLOYING].
2020-07-07 12:15:18,956 INFO  [Task] - Registering task at network: Map
(5/8) (4920b55f28ea09128aaa4e0d9d4691d8) [DEPLOYING].
2020-07-07 12:15:18,960 INFO  [TaskExecutor] - Received task Map (6/8).
2020-07-07 12:15:18,961 INFO  [Task] - Map (6/8)
(00f29aa2e8fe5300b05fc93432299ebd) switched from CREATED to DEPLOYING.
2020-07-07 12:15:18,961 INFO  [Task] - Creating FileSystem stream leak
safety net for task Map (6/8) (00f29aa2e8fe5300b05fc93432299ebd) [DEPLOYING]
2020-07-07 12:15:18,962 INFO  [Task] - Loading JAR files for task Map (6/8)
(00f29aa2e8fe5300b05fc93432299ebd) [DEPLOYING].
2020-07-07 12:15:18,962 INFO  [Task] - Registering task at network: Map
(6/8) (00f29aa2e8fe5300b05fc93432299ebd) [DEPLOYING].
2020-07-07 12:15:18,964 INFO  [TaskExecutor] - Received task Map (7/8).
2020-07-07 12:15:18,965 INFO  [Task] - Map (7/8)
(ac26eefbff14e55f031a055c1d6fa7f3) switched from CREATED to DEPLOYING.
2020-07-07 12:15:18,965 INFO  [Task] - Creating FileSystem stream leak
safety net for task Map (7/8) (ac26eefbff14e55f031a055c1d6fa7f3) [DEPLOYING]
2020-07-07 12:15:18,965 INFO  [Task] - Loading JAR files for task Map (7/8)
(ac26eefbff14e55f031a055c1d6fa7f3) [DEPLOYING].
2020-07-07 12:15:18,967 INFO  [Task] - Registering task at network: Map
(7/8) (ac26eefbff14e55f031a055c1d6fa7f3) [DEPLOYING].
2020-07-07 12:15:18,969 INFO  [TaskExecutor] - Received task Map (8/8).
2020-07-07 12:15:18,972 INFO  [TaskExecutor] - Received task Flat Map (1/8).
2020-07-07 12:15:18,976 INFO  [TaskExecutor] - Received task Flat Map (2/8).
2020-07-07 12:15:18,978 INFO  [Task] - Flat Map (1/8)
(1a117aa5347465fcc2cd5e58c286ccca) switched from CREATED to DEPLOYING.
2020-07-07 12:15:18,977 INFO  [Task] - Map (8/8)
(b1bf6bb7283e70c58b370665b2d2fd84) switched from CREATED to DEPLOYING.
2020-07-07 12:15:18,978 INFO  [Task] - Creating FileSystem stream leak
safety net for task Map (8/8) (b1bf6bb7283e70c58b370665b2d2fd84) [DEPLOYING]
2020-07-07 12:15:18,978 INFO  [Task] - Loading JAR files for task Map (8/8)
(b1bf6bb7283e70c58b370665b2d2fd84) [DEPLOYING].
2020-07-07 12:15:18,978 INFO  [Task] - Creating FileSystem stream leak
safety net for task Flat Map (1/8) (1a117aa5347465fcc2cd5e58c286ccca)
[DEPLOYING]
2020-07-07 12:15:18,979 INFO  [Task] - Loading JAR files for task Flat Map
(1/8) (1a117aa5347465fcc2cd5e58c286ccca) [DEPLOYING].
2020-07-07 12:15:18,979 INFO  [Task] - Registering task at network: Map
(8/8) (b1bf6bb7283e70c58b370665b2d2fd84) [DEPLOYING].
2020-07-07 12:15:18,980 INFO  [Task] - Registering task at network: Flat
Map (1/8) (1a117aa5347465fcc2cd5e58c286ccca) [DEPLOYING].
2020-07-07 12:15:18,981 INFO  [Task] - Flat Map (2/8)
(32f2429b06954884543a4de062edf6f6) switched from CREATED to DEPLOYING.
2020-07-07 12:15:18,982 INFO  [Task] - Creating FileSystem stream leak
safety net for task Flat Map (2/8) (32f2429b06954884543a4de062edf6f6)
[DEPLOYING]
2020-07-07 12:15:18,982 INFO  [Task] - Loading JAR files for task Flat Map
(2/8) (32f2429b06954884543a4de062edf6f6) [DEPLOYING].
2020-07-07 12:15:18,984 INFO  [Task] - Map (2/8)
(90787449e2373696163da5670b0e543a) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,985 INFO  [TaskExecutor] - Received task Flat Map (3/8).
2020-07-07 12:15:18,986 INFO  [Task] - Map (8/8)
(b1bf6bb7283e70c58b370665b2d2fd84) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,986 INFO  [Task] - Source: Collection Source (1/1)
(23f6a4d19c5744a62c46ac48d4dfbb24) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,986 INFO  [Task] - Source: Collection Source (1/1)
(406f5c97dd906161b3483e7a91cb9eee) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,987 INFO  [ExecutionGraph] - Map (2/8)
(90787449e2373696163da5670b0e543a) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,988 INFO  [Task] - Map (7/8)
(ac26eefbff14e55f031a055c1d6fa7f3) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,988 INFO  [Task] - Map (1/8)
(7dd6a325fe2265187b0b30bf3b4b8f63) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,988 INFO  [ExecutionGraph] - Map (8/8)
(b1bf6bb7283e70c58b370665b2d2fd84) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,988 INFO  [Task] - Map (5/8)
(4920b55f28ea09128aaa4e0d9d4691d8) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,989 INFO  [Task] - Registering task at network: Flat
Map (2/8) (32f2429b06954884543a4de062edf6f6) [DEPLOYING].
2020-07-07 12:15:18,989 INFO  [ExecutionGraph] - Source: Collection Source
(1/1) (23f6a4d19c5744a62c46ac48d4dfbb24) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,989 INFO  [Task] - Flat Map (1/8)
(1a117aa5347465fcc2cd5e58c286ccca) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,989 INFO  [ExecutionGraph] - Source: Collection Source
(1/1) (406f5c97dd906161b3483e7a91cb9eee) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,989 INFO  [Task] - Map (6/8)
(00f29aa2e8fe5300b05fc93432299ebd) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,989 INFO  [ExecutionGraph] - Map (7/8)
(ac26eefbff14e55f031a055c1d6fa7f3) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,989 INFO  [ExecutionGraph] - Map (1/8)
(7dd6a325fe2265187b0b30bf3b4b8f63) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,989 INFO  [TaskExecutor] - Received task Flat Map (4/8).
2020-07-07 12:15:18,991 INFO  [ExecutionGraph] - Map (5/8)
(4920b55f28ea09128aaa4e0d9d4691d8) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,991 INFO  [Task] - Map (3/8)
(d94aea75380e0e32c4747eef2f51a88d) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,991 INFO  [Task] - Flat Map (3/8)
(63a7c3f2b7a8d110232374c700e6378a) switched from CREATED to DEPLOYING.
2020-07-07 12:15:18,991 INFO  [Task] - Map (4/8)
(354a39e7781194b294978daa29688813) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,991 INFO  [Task] - Creating FileSystem stream leak
safety net for task Flat Map (3/8) (63a7c3f2b7a8d110232374c700e6378a)
[DEPLOYING]
2020-07-07 12:15:18,991 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:18,991 INFO  [Task] - Loading JAR files for task Flat Map
(3/8) (63a7c3f2b7a8d110232374c700e6378a) [DEPLOYING].
2020-07-07 12:15:18,991 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:18,991 INFO  [ExecutionGraph] - Flat Map (1/8)
(1a117aa5347465fcc2cd5e58c286ccca) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,991 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:18,992 INFO  [ExecutionGraph] - Map (6/8)
(00f29aa2e8fe5300b05fc93432299ebd) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,992 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:18,992 INFO  [ExecutionGraph] - Map (4/8)
(354a39e7781194b294978daa29688813) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,992 INFO  [ExecutionGraph] - Map (3/8)
(d94aea75380e0e32c4747eef2f51a88d) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,992 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:18,992 INFO  [Task] - Registering task at network: Flat
Map (3/8) (63a7c3f2b7a8d110232374c700e6378a) [DEPLOYING].
2020-07-07 12:15:18,993 INFO  [Task] - Flat Map (4/8)
(de310509f095e00584ce128336e19adf) switched from CREATED to DEPLOYING.
2020-07-07 12:15:18,993 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:18,993 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:18,994 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:18,994 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:18,993 INFO  [Task] - Creating FileSystem stream leak
safety net for task Flat Map (4/8) (de310509f095e00584ce128336e19adf)
[DEPLOYING]
2020-07-07 12:15:18,995 INFO  [Task] - Flat Map (2/8)
(32f2429b06954884543a4de062edf6f6) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,995 INFO  [Task] - Loading JAR files for task Flat Map
(4/8) (de310509f095e00584ce128336e19adf) [DEPLOYING].
2020-07-07 12:15:18,994 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:18,995 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:18,995 INFO  [ExecutionGraph] - Flat Map (2/8)
(32f2429b06954884543a4de062edf6f6) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,994 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:18,995 INFO  [TaskExecutor] - Received task Flat Map (5/8).
2020-07-07 12:15:18,996 INFO  [Task] - Registering task at network: Flat
Map (4/8) (de310509f095e00584ce128336e19adf) [DEPLOYING].
2020-07-07 12:15:18,997 INFO  [Task] - Flat Map (3/8)
(63a7c3f2b7a8d110232374c700e6378a) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,998 INFO  [Task] - Flat Map (5/8)
(3bb74ec008b43ffe86edd6a7f84844a0) switched from CREATED to DEPLOYING.
2020-07-07 12:15:18,998 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:18,998 INFO  [Task] - Creating FileSystem stream leak
safety net for task Flat Map (5/8) (3bb74ec008b43ffe86edd6a7f84844a0)
[DEPLOYING]
2020-07-07 12:15:18,998 INFO  [Task] - Loading JAR files for task Flat Map
(5/8) (3bb74ec008b43ffe86edd6a7f84844a0) [DEPLOYING].
2020-07-07 12:15:18,999 INFO  [Task] - Flat Map (4/8)
(de310509f095e00584ce128336e19adf) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:18,999 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:19,000 INFO  [ExecutionGraph] - Flat Map (3/8)
(63a7c3f2b7a8d110232374c700e6378a) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,001 INFO  [ExecutionGraph] - Flat Map (4/8)
(de310509f095e00584ce128336e19adf) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,001 INFO  [Task] - Registering task at network: Flat
Map (5/8) (3bb74ec008b43ffe86edd6a7f84844a0) [DEPLOYING].
2020-07-07 12:15:19,003 INFO  [Task] - Flat Map (5/8)
(3bb74ec008b43ffe86edd6a7f84844a0) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,004 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:19,004 INFO  [ExecutionGraph] - Flat Map (5/8)
(3bb74ec008b43ffe86edd6a7f84844a0) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,005 INFO  [TaskExecutor] - Received task Flat Map (6/8).
2020-07-07 12:15:19,008 INFO  [TaskExecutor] - Received task Flat Map (7/8).
2020-07-07 12:15:19,011 INFO  [TaskExecutor] - Received task Flat Map (8/8).
2020-07-07 12:15:19,013 INFO  [Task] - Flat Map (6/8)
(3a3a78fb1ae4384a264d417013dc864d) switched from CREATED to DEPLOYING.
2020-07-07 12:15:19,013 INFO  [Task] - Flat Map (7/8)
(c1ca47240e15ef6c60f1943aed1b45ba) switched from CREATED to DEPLOYING.
2020-07-07 12:15:19,013 INFO  [Task] - Creating FileSystem stream leak
safety net for task Flat Map (6/8) (3a3a78fb1ae4384a264d417013dc864d)
[DEPLOYING]
2020-07-07 12:15:19,013 INFO  [Task] - Creating FileSystem stream leak
safety net for task Flat Map (7/8) (c1ca47240e15ef6c60f1943aed1b45ba)
[DEPLOYING]
2020-07-07 12:15:19,013 INFO  [Task] - Loading JAR files for task Flat Map
(6/8) (3a3a78fb1ae4384a264d417013dc864d) [DEPLOYING].
2020-07-07 12:15:19,013 INFO  [Task] - Loading JAR files for task Flat Map
(7/8) (c1ca47240e15ef6c60f1943aed1b45ba) [DEPLOYING].
2020-07-07 12:15:19,013 INFO  [Task] - Flat Map (8/8)
(0fded4a7816a9d9a219c520891d2b38d) switched from CREATED to DEPLOYING.
2020-07-07 12:15:19,014 INFO  [Task] - Creating FileSystem stream leak
safety net for task Flat Map (8/8) (0fded4a7816a9d9a219c520891d2b38d)
[DEPLOYING]
2020-07-07 12:15:19,015 INFO  [Task] - Loading JAR files for task Flat Map
(8/8) (0fded4a7816a9d9a219c520891d2b38d) [DEPLOYING].
2020-07-07 12:15:19,015 INFO  [Task] - Registering task at network: Flat
Map (6/8) (3a3a78fb1ae4384a264d417013dc864d) [DEPLOYING].
2020-07-07 12:15:19,015 INFO  [TaskExecutor] - Received task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (1/8).
2020-07-07 12:15:19,015 INFO  [Task] - Registering task at network: Flat
Map (7/8) (c1ca47240e15ef6c60f1943aed1b45ba) [DEPLOYING].
2020-07-07 12:15:19,015 INFO  [Task] - Registering task at network: Flat
Map (8/8) (0fded4a7816a9d9a219c520891d2b38d) [DEPLOYING].
2020-07-07 12:15:19,017 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (1/8)
(8fa9c71df79d439827a1d290d9ad9abd) switched from CREATED to DEPLOYING.
2020-07-07 12:15:19,018 INFO  [TaskExecutor] - Received task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (2/8).
2020-07-07 12:15:19,019 INFO  [Task] - Flat Map (8/8)
(0fded4a7816a9d9a219c520891d2b38d) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,019 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:19,020 INFO  [ExecutionGraph] - Flat Map (8/8)
(0fded4a7816a9d9a219c520891d2b38d) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,018 INFO  [Task] - Creating FileSystem stream leak
safety net for task Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out,
Sink: Print to Std. Out) (1/8) (8fa9c71df79d439827a1d290d9ad9abd)
[DEPLOYING]
2020-07-07 12:15:19,022 INFO  [Task] - Loading JAR files for task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (1/8) (8fa9c71df79d439827a1d290d9ad9abd) [DEPLOYING].
2020-07-07 12:15:19,022 INFO  [TaskExecutor] - Received task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (3/8).
2020-07-07 12:15:19,022 INFO  [Task] - Registering task at network:
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (1/8) (8fa9c71df79d439827a1d290d9ad9abd) [DEPLOYING].
2020-07-07 12:15:19,024 INFO  [TaskExecutor] - Received task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (4/8).
2020-07-07 12:15:19,025 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (4/8)
(ee3c4e895e82f77ad9a055ee788f4a2b) switched from CREATED to DEPLOYING.
2020-07-07 12:15:19,025 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (2/8)
(67a21177a7598f3f1ccc5001fe6951c3) switched from CREATED to DEPLOYING.
2020-07-07 12:15:19,025 INFO  [Task] - Creating FileSystem stream leak
safety net for task Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out,
Sink: Print to Std. Out) (4/8) (ee3c4e895e82f77ad9a055ee788f4a2b)
[DEPLOYING]
2020-07-07 12:15:19,025 INFO  [Task] - Creating FileSystem stream leak
safety net for task Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out,
Sink: Print to Std. Out) (2/8) (67a21177a7598f3f1ccc5001fe6951c3)
[DEPLOYING]
2020-07-07 12:15:19,025 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (3/8)
(8d860a734d5b6a50194a5caad135a844) switched from CREATED to DEPLOYING.
2020-07-07 12:15:19,026 INFO  [Task] - Loading JAR files for task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (2/8) (67a21177a7598f3f1ccc5001fe6951c3) [DEPLOYING].
2020-07-07 12:15:19,026 INFO  [Task] - Loading JAR files for task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (4/8) (ee3c4e895e82f77ad9a055ee788f4a2b) [DEPLOYING].
2020-07-07 12:15:19,031 INFO  [Task] - Registering task at network:
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (2/8) (67a21177a7598f3f1ccc5001fe6951c3) [DEPLOYING].
2020-07-07 12:15:19,026 INFO  [Task] - Creating FileSystem stream leak
safety net for task Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out,
Sink: Print to Std. Out) (3/8) (8d860a734d5b6a50194a5caad135a844)
[DEPLOYING]
2020-07-07 12:15:19,032 INFO  [Task] - Loading JAR files for task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (3/8) (8d860a734d5b6a50194a5caad135a844) [DEPLOYING].
2020-07-07 12:15:19,033 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (2/8)
(67a21177a7598f3f1ccc5001fe6951c3) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,033 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:19,034 INFO  [Task] - Registering task at network:
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (4/8) (ee3c4e895e82f77ad9a055ee788f4a2b) [DEPLOYING].
2020-07-07 12:15:19,031 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (1/8)
(8fa9c71df79d439827a1d290d9ad9abd) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,034 INFO  [Task] - Registering task at network:
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (3/8) (8d860a734d5b6a50194a5caad135a844) [DEPLOYING].
2020-07-07 12:15:19,035 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:19,031 INFO  [Task] - Flat Map (6/8)
(3a3a78fb1ae4384a264d417013dc864d) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,038 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:19,029 INFO  [Task] - Flat Map (7/8)
(c1ca47240e15ef6c60f1943aed1b45ba) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,039 INFO  [TaskExecutor] - Received task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (5/8).
2020-07-07 12:15:19,038 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (4/8)
(ee3c4e895e82f77ad9a055ee788f4a2b) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,034 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (2/8)
(67a21177a7598f3f1ccc5001fe6951c3) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,047 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:19,043 INFO  [TaskExecutor] - Received task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (6/8).
2020-07-07 12:15:19,047 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (1/8)
(8fa9c71df79d439827a1d290d9ad9abd) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,047 INFO  [ExecutionGraph] - Flat Map (6/8)
(3a3a78fb1ae4384a264d417013dc864d) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,042 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (3/8)
(8d860a734d5b6a50194a5caad135a844) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,047 INFO  [ExecutionGraph] - Flat Map (7/8)
(c1ca47240e15ef6c60f1943aed1b45ba) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,048 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (4/8)
(ee3c4e895e82f77ad9a055ee788f4a2b) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,048 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:19,048 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (3/8)
(8d860a734d5b6a50194a5caad135a844) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,041 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (5/8)
(33a27b2d97c96658fd43db24177236bc) switched from CREATED to DEPLOYING.
2020-07-07 12:15:19,048 INFO  [Task] - Creating FileSystem stream leak
safety net for task Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out,
Sink: Print to Std. Out) (5/8) (33a27b2d97c96658fd43db24177236bc)
[DEPLOYING]
2020-07-07 12:15:19,049 INFO  [Task] - Loading JAR files for task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (5/8) (33a27b2d97c96658fd43db24177236bc) [DEPLOYING].
2020-07-07 12:15:19,049 INFO  [TaskExecutor] - Received task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (7/8).
2020-07-07 12:15:19,052 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (7/8)
(351cc238fecce28d1dfdc5ac357ef8e4) switched from CREATED to DEPLOYING.
2020-07-07 12:15:19,052 INFO  [Task] - Creating FileSystem stream leak
safety net for task Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out,
Sink: Print to Std. Out) (7/8) (351cc238fecce28d1dfdc5ac357ef8e4)
[DEPLOYING]
2020-07-07 12:15:19,053 INFO  [Task] - Loading JAR files for task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (7/8) (351cc238fecce28d1dfdc5ac357ef8e4) [DEPLOYING].
2020-07-07 12:15:19,049 INFO  [Task] - Registering task at network:
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (5/8) (33a27b2d97c96658fd43db24177236bc) [DEPLOYING].
2020-07-07 12:15:19,041 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:19,053 INFO  [Task] - Registering task at network:
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (7/8) (351cc238fecce28d1dfdc5ac357ef8e4) [DEPLOYING].
2020-07-07 12:15:19,053 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (6/8)
(6a75da55421a929d4b3d4ebd655414e9) switched from CREATED to DEPLOYING.
2020-07-07 12:15:19,054 INFO  [Task] - Creating FileSystem stream leak
safety net for task Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out,
Sink: Print to Std. Out) (6/8) (6a75da55421a929d4b3d4ebd655414e9)
[DEPLOYING]
2020-07-07 12:15:19,054 INFO  [Task] - Loading JAR files for task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (6/8) (6a75da55421a929d4b3d4ebd655414e9) [DEPLOYING].
2020-07-07 12:15:19,060 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (5/8)
(33a27b2d97c96658fd43db24177236bc) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,060 INFO  [Task] - Registering task at network:
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (6/8) (6a75da55421a929d4b3d4ebd655414e9) [DEPLOYING].
2020-07-07 12:15:19,060 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (7/8)
(351cc238fecce28d1dfdc5ac357ef8e4) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,061 INFO  [TaskExecutor] - Received task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (8/8).
2020-07-07 12:15:19,061 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (5/8)
(33a27b2d97c96658fd43db24177236bc) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,061 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:19,061 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:19,061 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (7/8)
(351cc238fecce28d1dfdc5ac357ef8e4) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,061 INFO  [TaskSlotTableImpl] - Activate slot
ea338a9c24fd1fbc154b82895ffd6120.
2020-07-07 12:15:19,061 INFO  [TaskSlotTableImpl] - Activate slot
78475a44354404e70780c097ecb9fc1f.
2020-07-07 12:15:19,061 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (6/8)
(6a75da55421a929d4b3d4ebd655414e9) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,061 INFO  [TaskSlotTableImpl] - Activate slot
7ed77eaff3404148674a6d8ace6711b1.
2020-07-07 12:15:19,061 INFO  [TaskSlotTableImpl] - Activate slot
35b8f6d367b0b1d9664011f8c9b9c0f5.
2020-07-07 12:15:19,061 INFO  [TaskSlotTableImpl] - Activate slot
5d7bf9557ad3dbdf879e87d57521a3ce.
2020-07-07 12:15:19,061 INFO  [TaskSlotTableImpl] - Activate slot
606b583518d47a7b301071fe38f9720c.
2020-07-07 12:15:19,061 INFO  [TaskSlotTableImpl] - Activate slot
da9c2d5e020a3726c2322ec3a2751385.
2020-07-07 12:15:19,062 INFO  [TaskSlotTableImpl] - Activate slot
ea0301a300a6eccd4a86b5c7061eba6b.
2020-07-07 12:15:19,062 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:19,062 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (6/8)
(6a75da55421a929d4b3d4ebd655414e9) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,065 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (8/8)
(773fad58ff1418ae919a0900e4da6ef5) switched from CREATED to DEPLOYING.
2020-07-07 12:15:19,066 INFO  [Task] - Creating FileSystem stream leak
safety net for task Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out,
Sink: Print to Std. Out) (8/8) (773fad58ff1418ae919a0900e4da6ef5)
[DEPLOYING]
2020-07-07 12:15:19,067 INFO  [Task] - Loading JAR files for task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (8/8) (773fad58ff1418ae919a0900e4da6ef5) [DEPLOYING].
2020-07-07 12:15:19,067 INFO  [Task] - Registering task at network:
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (8/8) (773fad58ff1418ae919a0900e4da6ef5) [DEPLOYING].
2020-07-07 12:15:19,069 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (8/8)
(773fad58ff1418ae919a0900e4da6ef5) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,078 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (8/8)
(773fad58ff1418ae919a0900e4da6ef5) switched from DEPLOYING to RUNNING.
2020-07-07 12:15:19,079 INFO  [StreamTask] - No state backend has been
configured, using default (Memory / JobManager) MemoryStateBackend (data in
heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints:
'null', asynchronous: TRUE, maxStateSize: 5242880)
2020-07-07 12:15:19,209 INFO  [HeapKeyedStateBackend] - Initializing heap
keyed state backend with stream factory.
2020-07-07 12:15:19,209 INFO  [HeapKeyedStateBackend] - Initializing heap
keyed state backend with stream factory.
2020-07-07 12:15:19,209 INFO  [HeapKeyedStateBackend] - Initializing heap
keyed state backend with stream factory.
2020-07-07 12:15:19,210 INFO  [HeapKeyedStateBackend] - Initializing heap
keyed state backend with stream factory.
2020-07-07 12:15:19,209 INFO  [HeapKeyedStateBackend] - Initializing heap
keyed state backend with stream factory.
2020-07-07 12:15:19,209 INFO  [HeapKeyedStateBackend] - Initializing heap
keyed state backend with stream factory.
2020-07-07 12:15:19,209 INFO  [HeapKeyedStateBackend] - Initializing heap
keyed state backend with stream factory.
2020-07-07 12:15:19,210 INFO  [HeapKeyedStateBackend] - Initializing heap
keyed state backend with stream factory.
2020-07-07 12:15:19,275 INFO  [Task] - Source: Collection Source (1/1)
(406f5c97dd906161b3483e7a91cb9eee) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,275 INFO  [Task] - Freeing task resources for Source:
Collection Source (1/1) (406f5c97dd906161b3483e7a91cb9eee).
2020-07-07 12:15:19,279 INFO  [Task] - Map (8/8)
(b1bf6bb7283e70c58b370665b2d2fd84) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,279 INFO  [Task] - Freeing task resources for Map (8/8)
(b1bf6bb7283e70c58b370665b2d2fd84).
2020-07-07 12:15:19,279 INFO  [Task] - Map (4/8)
(354a39e7781194b294978daa29688813) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,280 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Map (8/8) (b1bf6bb7283e70c58b370665b2d2fd84) [FINISHED]
2020-07-07 12:15:19,280 INFO  [Task] - Freeing task resources for Map (4/8)
(354a39e7781194b294978daa29688813).
2020-07-07 12:15:19,280 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Map (4/8) (354a39e7781194b294978daa29688813) [FINISHED]
2020-07-07 12:15:19,279 INFO  [Task] - Source: Collection Source (1/1)
(23f6a4d19c5744a62c46ac48d4dfbb24) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,284 INFO  [Task] - Map (6/8)
(00f29aa2e8fe5300b05fc93432299ebd) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,291 INFO  [Task] - Freeing task resources for Map (6/8)
(00f29aa2e8fe5300b05fc93432299ebd).
2020-07-07 12:15:19,292 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Map (6/8) (00f29aa2e8fe5300b05fc93432299ebd) [FINISHED]
2020-07-07 12:15:19,291 INFO  [Task] - Map (1/8)
(7dd6a325fe2265187b0b30bf3b4b8f63) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,294 INFO  [Task] - Freeing task resources for Map (1/8)
(7dd6a325fe2265187b0b30bf3b4b8f63).
2020-07-07 12:15:19,294 INFO  [Task] - Flat Map (6/8)
(3a3a78fb1ae4384a264d417013dc864d) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,294 INFO  [Task] - Freeing task resources for Flat Map
(6/8) (3a3a78fb1ae4384a264d417013dc864d).
2020-07-07 12:15:19,294 INFO  [Task] - Flat Map (4/8)
(de310509f095e00584ce128336e19adf) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,295 INFO  [Task] - Freeing task resources for Flat Map
(4/8) (de310509f095e00584ce128336e19adf).
2020-07-07 12:15:19,295 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Flat Map (6/8) (3a3a78fb1ae4384a264d417013dc864d) [FINISHED]
2020-07-07 12:15:19,276 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Source: Collection Source (1/1)
(406f5c97dd906161b3483e7a91cb9eee) [FINISHED]
2020-07-07 12:15:19,295 INFO  [Task] - Flat Map (3/8)
(63a7c3f2b7a8d110232374c700e6378a) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,296 INFO  [Task] - Freeing task resources for Flat Map
(3/8) (63a7c3f2b7a8d110232374c700e6378a).
2020-07-07 12:15:19,296 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Flat Map (3/8) (63a7c3f2b7a8d110232374c700e6378a) [FINISHED]
2020-07-07 12:15:19,296 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Flat Map (4/8) (de310509f095e00584ce128336e19adf) [FINISHED]
2020-07-07 12:15:19,289 INFO  [Task] - Map (7/8)
(ac26eefbff14e55f031a055c1d6fa7f3) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,297 INFO  [Task] - Freeing task resources for Map (7/8)
(ac26eefbff14e55f031a055c1d6fa7f3).
2020-07-07 12:15:19,297 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Map (7/8) (ac26eefbff14e55f031a055c1d6fa7f3) [FINISHED]
2020-07-07 12:15:19,289 INFO  [Task] - Map (3/8)
(d94aea75380e0e32c4747eef2f51a88d) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,302 INFO  [Task] - Freeing task resources for Map (3/8)
(d94aea75380e0e32c4747eef2f51a88d).
2020-07-07 12:15:19,289 INFO  [Task] - Flat Map (5/8)
(3bb74ec008b43ffe86edd6a7f84844a0) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,288 INFO  [Task] - Flat Map (2/8)
(32f2429b06954884543a4de062edf6f6) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,308 INFO  [Task] - Freeing task resources for Flat Map
(5/8) (3bb74ec008b43ffe86edd6a7f84844a0).
2020-07-07 12:15:19,309 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Flat Map (5/8) (3bb74ec008b43ffe86edd6a7f84844a0) [FINISHED]
2020-07-07 12:15:19,288 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Map (8/8)
b1bf6bb7283e70c58b370665b2d2fd84.
2020-07-07 12:15:19,285 INFO  [Task] - Freeing task resources for Source:
Collection Source (1/1) (23f6a4d19c5744a62c46ac48d4dfbb24).
2020-07-07 12:15:19,288 INFO  [Task] - Map (2/8)
(90787449e2373696163da5670b0e543a) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,317 INFO  [Task] - Freeing task resources for Map (2/8)
(90787449e2373696163da5670b0e543a).
2020-07-07 12:15:19,317 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Map (2/8) (90787449e2373696163da5670b0e543a) [FINISHED]
2020-07-07 12:15:19,320 INFO  [ExecutionGraph] - Map (8/8)
(b1bf6bb7283e70c58b370665b2d2fd84) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,326 INFO  [JsonKeyContentFilter] - BroadCastState
SourceName: A
2020-07-07 12:15:19,326 INFO  [JsonKeyContentFilter] - BroadCastState
PatternCondition: PatternRule
2020-07-07 12:15:19,287 INFO  [Task] - Flat Map (7/8)
(c1ca47240e15ef6c60f1943aed1b45ba) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,330 INFO  [Task] - Freeing task resources for Flat Map
(7/8) (c1ca47240e15ef6c60f1943aed1b45ba).
2020-07-07 12:15:19,330 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Flat Map (7/8) (c1ca47240e15ef6c60f1943aed1b45ba) [FINISHED]
2020-07-07 12:15:19,330 INFO  [JsonKeyContentFilter] - BroadCastState
SourceName: A
2020-07-07 12:15:19,331 INFO  [JsonKeyContentFilter] - BroadCastState
PatternCondition: PatternRule
2020-07-07 12:15:19,316 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Map (4/8)
354a39e7781194b294978daa29688813.
2020-07-07 12:15:19,316 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Source: Collection Source (1/1)
(23f6a4d19c5744a62c46ac48d4dfbb24) [FINISHED]
2020-07-07 12:15:19,335 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Map (6/8)
00f29aa2e8fe5300b05fc93432299ebd.
2020-07-07 12:15:19,335 INFO  [ExecutionGraph] - Map (4/8)
(354a39e7781194b294978daa29688813) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,335 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Flat Map
(6/8) 3a3a78fb1ae4384a264d417013dc864d.
2020-07-07 12:15:19,336 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Source:
Collection Source (1/1) 406f5c97dd906161b3483e7a91cb9eee.
2020-07-07 12:15:19,336 INFO  [ExecutionGraph] - Map (6/8)
(00f29aa2e8fe5300b05fc93432299ebd) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,336 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Flat Map
(3/8) 63a7c3f2b7a8d110232374c700e6378a.
2020-07-07 12:15:19,337 INFO  [ExecutionGraph] - Flat Map (6/8)
(3a3a78fb1ae4384a264d417013dc864d) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,337 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Flat Map
(4/8) de310509f095e00584ce128336e19adf.
2020-07-07 12:15:19,337 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Map (7/8)
ac26eefbff14e55f031a055c1d6fa7f3.
2020-07-07 12:15:19,338 INFO  [ExecutionGraph] - Source: Collection Source
(1/1) (406f5c97dd906161b3483e7a91cb9eee) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,338 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Flat Map
(5/8) 3bb74ec008b43ffe86edd6a7f84844a0.
2020-07-07 12:15:19,339 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Map (2/8)
90787449e2373696163da5670b0e543a.
2020-07-07 12:15:19,340 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Flat Map
(7/8) c1ca47240e15ef6c60f1943aed1b45ba.
2020-07-07 12:15:19,309 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Map (3/8) (d94aea75380e0e32c4747eef2f51a88d) [FINISHED]
2020-07-07 12:15:19,308 INFO  [Task] - Freeing task resources for Flat Map
(2/8) (32f2429b06954884543a4de062edf6f6).
2020-07-07 12:15:19,342 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Flat Map (2/8) (32f2429b06954884543a4de062edf6f6) [FINISHED]
2020-07-07 12:15:19,294 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Map (1/8) (7dd6a325fe2265187b0b30bf3b4b8f63) [FINISHED]
2020-07-07 12:15:19,344 INFO  [Task] - Map (5/8)
(4920b55f28ea09128aaa4e0d9d4691d8) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,344 INFO  [Task] - Freeing task resources for Map (5/8)
(4920b55f28ea09128aaa4e0d9d4691d8).
2020-07-07 12:15:19,345 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Map (5/8) (4920b55f28ea09128aaa4e0d9d4691d8) [FINISHED]
2020-07-07 12:15:19,294 INFO  [Task] - Flat Map (8/8)
(0fded4a7816a9d9a219c520891d2b38d) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,349 INFO  [Task] - Freeing task resources for Flat Map
(8/8) (0fded4a7816a9d9a219c520891d2b38d).
2020-07-07 12:15:19,349 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Flat Map (8/8) (0fded4a7816a9d9a219c520891d2b38d) [FINISHED]
2020-07-07 12:15:19,349 INFO  [Task] - Flat Map (1/8)
(1a117aa5347465fcc2cd5e58c286ccca) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,349 INFO  [Task] - Freeing task resources for Flat Map
(1/8) (1a117aa5347465fcc2cd5e58c286ccca).
2020-07-07 12:15:19,349 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Flat Map (1/8) (1a117aa5347465fcc2cd5e58c286ccca) [FINISHED]
2020-07-07 12:15:19,348 INFO  [JsonKeyContentFilter] - BroadCastState
SourceName: A
2020-07-07 12:15:19,350 INFO  [JsonKeyContentFilter] - BroadCastState
PatternCondition: PatternRule
2020-07-07 12:15:19,341 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Source:
Collection Source (1/1) 23f6a4d19c5744a62c46ac48d4dfbb24.
2020-07-07 12:15:19,351 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (8/8)
(773fad58ff1418ae919a0900e4da6ef5) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,351 INFO  [Task] - Freeing task resources for
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (8/8) (773fad58ff1418ae919a0900e4da6ef5).
2020-07-07 12:15:19,351 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (2/8)
(67a21177a7598f3f1ccc5001fe6951c3) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,351 INFO  [Task] - Freeing task resources for
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (2/8) (67a21177a7598f3f1ccc5001fe6951c3).
2020-07-07 12:15:19,351 INFO  [JsonKeyContentFilter] - BroadCastState
SourceName: A
2020-07-07 12:15:19,351 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out,
Sink: Print to Std. Out) (2/8) (67a21177a7598f3f1ccc5001fe6951c3) [FINISHED]
2020-07-07 12:15:19,351 INFO  [JsonKeyContentFilter] - BroadCastState
PatternCondition: PatternRule
2020-07-07 12:15:19,351 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out,
Sink: Print to Std. Out) (8/8) (773fad58ff1418ae919a0900e4da6ef5) [FINISHED]
2020-07-07 12:15:19,352 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (3/8)
(8d860a734d5b6a50194a5caad135a844) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,352 INFO  [Task] - Freeing task resources for
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (3/8) (8d860a734d5b6a50194a5caad135a844).
2020-07-07 12:15:19,352 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out,
Sink: Print to Std. Out) (3/8) (8d860a734d5b6a50194a5caad135a844) [FINISHED]
2020-07-07 12:15:19,352 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (1/8)
(8fa9c71df79d439827a1d290d9ad9abd) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,352 INFO  [Task] - Freeing task resources for
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (1/8) (8fa9c71df79d439827a1d290d9ad9abd).
2020-07-07 12:15:19,352 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out,
Sink: Print to Std. Out) (1/8) (8fa9c71df79d439827a1d290d9ad9abd) [FINISHED]
2020-07-07 12:15:19,357 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (4/8)
(ee3c4e895e82f77ad9a055ee788f4a2b) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,357 INFO  [Task] - Freeing task resources for
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (4/8) (ee3c4e895e82f77ad9a055ee788f4a2b).
2020-07-07 12:15:19,357 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out,
Sink: Print to Std. Out) (4/8) (ee3c4e895e82f77ad9a055ee788f4a2b) [FINISHED]
2020-07-07 12:15:19,358 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (6/8)
(6a75da55421a929d4b3d4ebd655414e9) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,358 INFO  [Task] - Freeing task resources for
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (6/8) (6a75da55421a929d4b3d4ebd655414e9).
2020-07-07 12:15:19,339 INFO  [ExecutionGraph] - Flat Map (3/8)
(63a7c3f2b7a8d110232374c700e6378a) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,352 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (7/8)
(351cc238fecce28d1dfdc5ac357ef8e4) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,352 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Map (3/8)
d94aea75380e0e32c4747eef2f51a88d.
2020-07-07 12:15:19,358 INFO  [Task] - Freeing task resources for
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (7/8) (351cc238fecce28d1dfdc5ac357ef8e4).
2020-07-07 12:15:19,359 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out,
Sink: Print to Std. Out) (7/8) (351cc238fecce28d1dfdc5ac357ef8e4) [FINISHED]
2020-07-07 12:15:19,360 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Flat Map
(2/8) 32f2429b06954884543a4de062edf6f6.
2020-07-07 12:15:19,358 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out,
Sink: Print to Std. Out) (6/8) (6a75da55421a929d4b3d4ebd655414e9) [FINISHED]
2020-07-07 12:15:19,360 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Map (1/8)
7dd6a325fe2265187b0b30bf3b4b8f63.
2020-07-07 12:15:19,358 INFO  [ExecutionGraph] - Flat Map (4/8)
(de310509f095e00584ce128336e19adf) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,361 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Map (5/8)
4920b55f28ea09128aaa4e0d9d4691d8.
2020-07-07 12:15:19,362 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Flat Map
(8/8) 0fded4a7816a9d9a219c520891d2b38d.
2020-07-07 12:15:19,362 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task Flat Map
(1/8) 1a117aa5347465fcc2cd5e58c286ccca.
2020-07-07 12:15:19,363 INFO  [ExecutionGraph] - Map (7/8)
(ac26eefbff14e55f031a055c1d6fa7f3) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,364 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (2/8) 67a21177a7598f3f1ccc5001fe6951c3.
2020-07-07 12:15:19,367 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (8/8) 773fad58ff1418ae919a0900e4da6ef5.
2020-07-07 12:15:19,367 INFO  [ExecutionGraph] - Flat Map (5/8)
(3bb74ec008b43ffe86edd6a7f84844a0) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,368 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (3/8) 8d860a734d5b6a50194a5caad135a844.
2020-07-07 12:15:19,368 INFO  [ExecutionGraph] - Map (2/8)
(90787449e2373696163da5670b0e543a) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,369 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (1/8) 8fa9c71df79d439827a1d290d9ad9abd.
2020-07-07 12:15:19,370 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (4/8) ee3c4e895e82f77ad9a055ee788f4a2b.
2020-07-07 12:15:19,373 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (7/8) 351cc238fecce28d1dfdc5ac357ef8e4.
2020-07-07 12:15:19,374 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FINISHED to JobManager for task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (6/8) 6a75da55421a929d4b3d4ebd655414e9.
2020-07-07 12:15:19,369 INFO  [ExecutionGraph] - Flat Map (7/8)
(c1ca47240e15ef6c60f1943aed1b45ba) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,379 INFO  [ExecutionGraph] - Source: Collection Source
(1/1) (23f6a4d19c5744a62c46ac48d4dfbb24) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,381 INFO  [ExecutionGraph] - Map (3/8)
(d94aea75380e0e32c4747eef2f51a88d) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,382 INFO  [ExecutionGraph] - Flat Map (2/8)
(32f2429b06954884543a4de062edf6f6) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,384 INFO  [ExecutionGraph] - Map (1/8)
(7dd6a325fe2265187b0b30bf3b4b8f63) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,385 INFO  [ExecutionGraph] - Map (5/8)
(4920b55f28ea09128aaa4e0d9d4691d8) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,386 INFO  [TypeExtractor] - class org.json.JSONObject
does not contain a getter for field map
2020-07-07 12:15:19,386 INFO  [TypeExtractor] - class org.json.JSONObject
does not contain a setter for field map
2020-07-07 12:15:19,386 INFO  [ExecutionGraph] - Flat Map (8/8)
(0fded4a7816a9d9a219c520891d2b38d) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,386 INFO  [TypeExtractor] - Class class
org.json.JSONObject cannot be used as a POJO type because not all fields
are valid POJO fields, and must be processed as GenericType. Please read
the Flink documentation on "Data Types & Serialization" for details of the
effect on performance.
2020-07-07 12:15:19,388 INFO  [ExecutionGraph] - Flat Map (1/8)
(1a117aa5347465fcc2cd5e58c286ccca) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,390 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (2/8)
(67a21177a7598f3f1ccc5001fe6951c3) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,390 INFO  [Task] - Co-Process-Broadcast-Keyed -> (Sink:
Print to Std. Out, Sink: Print to Std. Out) (5/8)
(33a27b2d97c96658fd43db24177236bc) switched from RUNNING to FAILED.
java.lang.NullPointerException: null
at
com.eventdetection.eventfilter.pattern.operator.json.filter.JsonKeyContentFilter.processElement(JsonKeyContentFilter.java:103)
at
com.eventdetection.eventfilter.pattern.operator.json.filter.JsonKeyContentFilter.processElement(JsonKeyContentFilter.java:40)
at
org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator.processElement1(CoBroadcastWithKeyedOperator.java:113)
at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.processRecord1(StreamTwoInputProcessor.java:135)
at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.lambda$new$0(StreamTwoInputProcessor.java:100)
at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor$StreamTaskNetworkOutput.emitRecord(StreamTwoInputProcessor.java:362)
at
org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput.processElement(StreamTaskNetworkInput.java:151)
at
org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput.emitNext(StreamTaskNetworkInput.java:128)
at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.processInput(StreamTwoInputProcessor.java:182)
at
org.apache.flink.streaming.runtime.tasks.StreamTask.processInput(StreamTask.java:311)
at
org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMailboxLoop(MailboxProcessor.java:187)
at
org.apache.flink.streaming.runtime.tasks.StreamTask.runMailboxLoop(StreamTask.java:487)
at
org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:470)
at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:707)
at org.apache.flink.runtime.taskmanager.Task.run(Task.java:532)
at java.lang.Thread.run(Thread.java:748)
2020-07-07 12:15:19,394 INFO  [Task] - Freeing task resources for
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (5/8) (33a27b2d97c96658fd43db24177236bc).
2020-07-07 12:15:19,394 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (8/8)
(773fad58ff1418ae919a0900e4da6ef5) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,394 INFO  [Task] - Ensuring all FileSystem streams are
closed for task Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out,
Sink: Print to Std. Out) (5/8) (33a27b2d97c96658fd43db24177236bc) [FAILED]
2020-07-07 12:15:19,395 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (3/8)
(8d860a734d5b6a50194a5caad135a844) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,396 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (1/8)
(8fa9c71df79d439827a1d290d9ad9abd) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,397 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (4/8)
(ee3c4e895e82f77ad9a055ee788f4a2b) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,398 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (7/8)
(351cc238fecce28d1dfdc5ac357ef8e4) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,399 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (6/8)
(6a75da55421a929d4b3d4ebd655414e9) switched from RUNNING to FINISHED.
2020-07-07 12:15:19,402 INFO  [TaskExecutor] - Un-registering task and
sending final execution state FAILED to JobManager for task
Co-Process-Broadcast-Keyed -> (Sink: Print to Std. Out, Sink: Print to Std.
Out) (5/8) 33a27b2d97c96658fd43db24177236bc.
2020-07-07 12:15:19,404 INFO  [ExecutionGraph] - Co-Process-Broadcast-Keyed
-> (Sink: Print to Std. Out, Sink: Print to Std. Out) (5/8)
(33a27b2d97c96658fd43db24177236bc) switched from RUNNING to FAILED.
java.lang.NullPointerException: null
at
com.eventdetection.eventfilter.pattern.operator.json.filter.PatternFilter.processElement(PatternFilter.java:103)
at
com.eventdetection.eventfilter.pattern.operator.json.filter.PatternFilter.processElement(PatternFilter.java:40)
at
org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator.processElement1(CoBroadcastWithKeyedOperator.java:113)
at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.processRecord1(StreamTwoInputProcessor.java:135)
at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.lambda$new$0(StreamTwoInputProcessor.java:100)
at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor$StreamTaskNetworkOutput.emitRecord(StreamTwoInputProcessor.java:362)
at
org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput.processElement(StreamTaskNetworkInput.java:151)
at
org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput.emitNext(StreamTaskNetworkInput.java:128)
at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.processInput(StreamTwoInputProcessor.java:182)
at
org.apache.flink.streaming.runtime.tasks.StreamTask.processInput(StreamTask.java:311)
at
org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMailboxLoop(MailboxProcessor.java:187)
at
org.apache.flink.streaming.runtime.tasks.StreamTask.runMailboxLoop(StreamTask.java:487)
at
org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:470)
at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:707)
at org.apache.flink.runtime.taskmanager.Task.run(Task.java:532)
at java.lang.Thread.run(Thread.java:748)
2020-07-07 12:15:19,406 INFO  [RestartPipelinedRegionStrategy] -
Calculating tasks to restart to recover the failed task
d8804397962a5c1c0b4daacb1802fb97_4.
2020-07-07 12:15:19,408 INFO  [RestartPipelinedRegionStrategy] - 26 tasks
should be restarted to recover the failed task
d8804397962a5c1c0b4daacb1802fb97_4.
2020-07-07 12:15:19,410 INFO  [ExecutionGraph] - Job Pattern-Matching
(1a828d53bc6a886fe0fc7c454e6e66b7) switched from state RUNNING to FAILING.
org.apache.flink.runtime.JobException: Recovery is suppressed by
NoRestartBackoffTimeStrategy
at
org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.handleFailure(ExecutionFailureHandler.java:110)
at
org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.getFailureHandlingResult(ExecutionFailureHandler.java:76)
at
org.apache.flink.runtime.scheduler.DefaultScheduler.handleTaskFailure(DefaultScheduler.java:192)
at
org.apache.flink.runtime.scheduler.DefaultScheduler.maybeHandleTaskFailure(DefaultScheduler.java:186)
at
org.apache.flink.runtime.scheduler.DefaultScheduler.updateTaskExecutionStateInternal(DefaultScheduler.java:180)
at
org.apache.flink.runtime.scheduler.SchedulerBase.updateTaskExecutionState(SchedulerBase.java:484)
at
org.apache.flink.runtime.jobmaster.JobMaster.updateTaskExecutionState(JobMaster.java:380)
at sun.reflect.GeneratedMethodAccessor17.invoke(Unknown Source)
at
sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
at java.lang.reflect.Method.invoke(Method.java:498)
at
org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcInvocation(AkkaRpcActor.java:279)
at
org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcMessage(AkkaRpcActor.java:194)
at
org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor.handleRpcMessage(FencedAkkaRpcActor.java:74)
at
org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleMessage(AkkaRpcActor.java:152)
at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:26)
at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:21)
at scala.PartialFunction.applyOrElse(PartialFunction.scala:123)
at scala.PartialFunction.applyOrElse$(PartialFunction.scala:122)
at akka.japi.pf.UnitCaseStatement.applyOrElse(CaseStatements.scala:21)
at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:171)
at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:172)
at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:172)
at akka.actor.Actor.aroundReceive(Actor.scala:517)
at akka.actor.Actor.aroundReceive$(Actor.scala:515)
at akka.actor.AbstractActor.aroundReceive(AbstractActor.scala:225)
at akka.actor.ActorCell.receiveMessage(ActorCell.scala:592)
at akka.actor.ActorCell.invoke(ActorCell.scala:561)
at akka.dispatch.Mailbox.processMailbox(Mailbox.scala:258)
at akka.dispatch.Mailbox.run(Mailbox.scala:225)
at akka.dispatch.Mailbox.exec(Mailbox.scala:235)
at akka.dispatch.forkjoin.ForkJoinTask.doExec(ForkJoinTask.java:260)
at
akka.dispatch.forkjoin.ForkJoinPool$WorkQueue.runTask(ForkJoinPool.java:1339)
at akka.dispatch.forkjoin.ForkJoinPool.runWorker(ForkJoinPool.java:1979)
at
akka.dispatch.forkjoin.ForkJoinWorkerThread.run(ForkJoinWorkerThread.java:107)
Caused by: java.lang.NullPointerException: null
at
com.eventdetection.eventfilter.pattern.operator.json.filter.PatternFilter.processElement(PatternFilter.java:103)
at
com.eventdetection.eventfilter.pattern.operator.json.filter.PatternFilter.processElement(PatternFilter.java:40)
at
org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator.processElement1(CoBroadcastWithKeyedOperator.java:113)
at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.processRecord1(StreamTwoInputProcessor.java:135)
Caused by: java.lang.NullPointerException: null

at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.lambda$new$0(StreamTwoInputProcessor.java:100)
at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor$StreamTaskNetworkOutput.emitRecord(StreamTwoInputProcessor.java:362)
at
org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput.processElement(StreamTaskNetworkInput.java:151)
at
org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput.emitNext(StreamTaskNetworkInput.java:128)
at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.processInput(StreamTwoInputProcessor.java:182)
at
org.apache.flink.streaming.runtime.tasks.StreamTask.processInput(StreamTask.java:311)
at
org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMailboxLoop(MailboxProcessor.java:187)
at
org.apache.flink.streaming.runtime.tasks.StreamTask.runMailboxLoop(StreamTask.java:487)
at
org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:470)
at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:707)
at org.apache.flink.runtime.taskmanager.Task.run(Task.java:532)
at java.lang.Thread.run(Thread.java:748)
2020-07-07 12:15:19,415 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 406f5c97dd906161b3483e7a91cb9eee.
2020-07-07 12:15:19,418 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 23f6a4d19c5744a62c46ac48d4dfbb24.
2020-07-07 12:15:19,419 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 7dd6a325fe2265187b0b30bf3b4b8f63.
2020-07-07 12:15:19,419 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 90787449e2373696163da5670b0e543a.
2020-07-07 12:15:19,419 INFO  [ExecutionGraph] - Discarding the results
produced by task execution d94aea75380e0e32c4747eef2f51a88d.
2020-07-07 12:15:19,419 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 354a39e7781194b294978daa29688813.
2020-07-07 12:15:19,419 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 4920b55f28ea09128aaa4e0d9d4691d8.
2020-07-07 12:15:19,419 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 00f29aa2e8fe5300b05fc93432299ebd.
2020-07-07 12:15:19,419 INFO  [ExecutionGraph] - Discarding the results
produced by task execution ac26eefbff14e55f031a055c1d6fa7f3.
2020-07-07 12:15:19,419 INFO  [ExecutionGraph] - Discarding the results
produced by task execution b1bf6bb7283e70c58b370665b2d2fd84.
2020-07-07 12:15:19,419 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 1a117aa5347465fcc2cd5e58c286ccca.
2020-07-07 12:15:19,419 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 32f2429b06954884543a4de062edf6f6.
2020-07-07 12:15:19,419 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 63a7c3f2b7a8d110232374c700e6378a.
2020-07-07 12:15:19,420 INFO  [ExecutionGraph] - Discarding the results
produced by task execution de310509f095e00584ce128336e19adf.
2020-07-07 12:15:19,420 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 3bb74ec008b43ffe86edd6a7f84844a0.
2020-07-07 12:15:19,420 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 3a3a78fb1ae4384a264d417013dc864d.
2020-07-07 12:15:19,420 INFO  [ExecutionGraph] - Discarding the results
produced by task execution c1ca47240e15ef6c60f1943aed1b45ba.
2020-07-07 12:15:19,420 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 0fded4a7816a9d9a219c520891d2b38d.
2020-07-07 12:15:19,421 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 8fa9c71df79d439827a1d290d9ad9abd.
2020-07-07 12:15:19,421 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 67a21177a7598f3f1ccc5001fe6951c3.
2020-07-07 12:15:19,421 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 8d860a734d5b6a50194a5caad135a844.
2020-07-07 12:15:19,421 INFO  [ExecutionGraph] - Discarding the results
produced by task execution ee3c4e895e82f77ad9a055ee788f4a2b.
2020-07-07 12:15:19,421 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 6a75da55421a929d4b3d4ebd655414e9.
2020-07-07 12:15:19,421 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 351cc238fecce28d1dfdc5ac357ef8e4.
2020-07-07 12:15:19,421 INFO  [ExecutionGraph] - Discarding the results
produced by task execution 773fad58ff1418ae919a0900e4da6ef5.
2020-07-07 12:15:19,422 INFO  [ExecutionGraph] - Job Pattern-Matching
(1a828d53bc6a886fe0fc7c454e6e66b7) switched from state FAILING to FAILED.
org.apache.flink.runtime.JobException: Recovery is suppressed by
NoRestartBackoffTimeStrategy
at
org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.handleFailure(ExecutionFailureHandler.java:110)
at
org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.getFailureHandlingResult(ExecutionFailureHandler.java:76)
at
org.apache.flink.runtime.scheduler.DefaultScheduler.handleTaskFailure(DefaultScheduler.java:192)
at
org.apache.flink.runtime.scheduler.DefaultScheduler.maybeHandleTaskFailure(DefaultScheduler.java:186)
at
org.apache.flink.runtime.scheduler.DefaultScheduler.updateTaskExecutionStateInternal(DefaultScheduler.java:180)
at
org.apache.flink.runtime.scheduler.SchedulerBase.updateTaskExecutionState(SchedulerBase.java:484)
at
org.apache.flink.runtime.jobmaster.JobMaster.updateTaskExecutionState(JobMaster.java:380)
at sun.reflect.GeneratedMethodAccessor17.invoke(Unknown Source)
at
sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
at java.lang.reflect.Method.invoke(Method.java:498)
at
org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcInvocation(AkkaRpcActor.java:279)
at
org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcMessage(AkkaRpcActor.java:194)
at
org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor.handleRpcMessage(FencedAkkaRpcActor.java:74)
at
org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleMessage(AkkaRpcActor.java:152)
at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:26)
at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:21)
at scala.PartialFunction.applyOrElse(PartialFunction.scala:123)
at scala.PartialFunction.applyOrElse$(PartialFunction.scala:122)
at akka.japi.pf.UnitCaseStatement.applyOrElse(CaseStatements.scala:21)
at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:171)
at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:172)
at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:172)
at akka.actor.Actor.aroundReceive(Actor.scala:517)
at akka.actor.Actor.aroundReceive$(Actor.scala:515)
at akka.actor.AbstractActor.aroundReceive(AbstractActor.scala:225)
at akka.actor.ActorCell.receiveMessage(ActorCell.scala:592)
at akka.actor.ActorCell.invoke(ActorCell.scala:561)
at akka.dispatch.Mailbox.processMailbox(Mailbox.scala:258)
at akka.dispatch.Mailbox.run(Mailbox.scala:225)
at akka.dispatch.Mailbox.exec(Mailbox.scala:235)
at akka.dispatch.forkjoin.ForkJoinTask.doExec(ForkJoinTask.java:260)
at
akka.dispatch.forkjoin.ForkJoinPool$WorkQueue.runTask(ForkJoinPool.java:1339)
at akka.dispatch.forkjoin.ForkJoinPool.runWorker(ForkJoinPool.java:1979)
at
akka.dispatch.forkjoin.ForkJoinWorkerThread.run(ForkJoinWorkerThread.java:107)
Caused by: java.lang.NullPointerException: null
at
com.eventdetection.eventfilter.pattern.operator.json.filter.PatternFilter.processElement(PatternFilter.java:103)
at
com.eventdetection.eventfilter.pattern.operator.json.filter.PatternFilter.processElement(PatternFilter.java:40)
at
org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator.processElement1(CoBroadcastWithKeyedOperator.java:113)
at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.processRecord1(StreamTwoInputProcessor.java:135)
at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.lambda$new$0(StreamTwoInputProcessor.java:100)
at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor$StreamTaskNetworkOutput.emitRecord(StreamTwoInputProcessor.java:362)
at
org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput.processElement(StreamTaskNetworkInput.java:151)
at
org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput.emitNext(StreamTaskNetworkInput.java:128)
at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.processInput(StreamTwoInputProcessor.java:182)
at
org.apache.flink.streaming.runtime.tasks.StreamTask.processInput(StreamTask.java:311)
at
org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMailboxLoop(MailboxProcessor.java:187)
at
org.apache.flink.streaming.runtime.tasks.StreamTask.runMailboxLoop(StreamTask.java:487)
at
org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:470)
at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:707)
at org.apache.flink.runtime.taskmanager.Task.run(Task.java:532)
at java.lang.Thread.run(Thread.java:748)
2020-07-07 12:15:19,423 INFO  [CheckpointCoordinator] - Stopping checkpoint
coordinator for job 1a828d53bc6a886fe0fc7c454e6e66b7.
2020-07-07 12:15:19,423 INFO  [StandaloneCompletedCheckpointStore] -
Shutting down
2020-07-07 12:15:19,435 INFO  [MiniCluster] - Shutting down Flink Mini
Cluster
2020-07-07 12:15:19,435 INFO  [DispatcherRestEndpoint] - Shutting down rest
endpoint.
2020-07-07 12:15:19,436 INFO  [TaskExecutor] - Stopping TaskExecutor
akka://flink/user/taskmanager_0.
2020-07-07 12:15:19,436 INFO  [TaskExecutor] - Close ResourceManager
connection b9946c32383de9e6655bb562e3421502.
2020-07-07 12:15:19,436 INFO  [StandaloneDispatcher] - Job
1a828d53bc6a886fe0fc7c454e6e66b7 reached globally terminal state FAILED.
2020-07-07 12:15:19,437 INFO  [JobMaster] - Stopping the JobMaster for job
Pattern-Matching(1a828d53bc6a886fe0fc7c454e6e66b7).
2020-07-07 12:15:19,440 INFO  [StandaloneResourceManager] - Closing
TaskExecutor connection 82810ea2-3be7-4d71-b2d8-4769b3a19c1b because: The
TaskExecutor is shutting down.
2020-07-07 12:15:19,441 INFO  [SlotPoolImpl] - Suspending SlotPool.
2020-07-07 12:15:19,441 INFO  [JobMaster] - Close ResourceManager
connection b9946c32383de9e6655bb562e3421502: JobManager is shutting down..
2020-07-07 12:15:19,441 INFO  [SlotPoolImpl] - Stopping SlotPool.
Exception in thread "main" java.util.concurrent.ExecutionException:
org.apache.flink.client.program.ProgramInvocationException: Job failed
(JobID: 1a828d53bc6a886fe0fc7c454e6e66b7)
at
java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
at java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1908)
at
org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.execute(StreamExecutionEnvironment.java:1640)
at
org.apache.flink.streaming.api.environment.LocalStreamEnvironment.execute(LocalStreamEnvironment.java:74)
at
org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.execute(StreamExecutionEnvironment.java:1620)
at
com.eventdetection.eventfilter.pattern.SignalPatternMatchingApp.main(SignalPatternMatchingApp.java:118)
Caused by: org.apache.flink.client.program.ProgramInvocationException: Job
failed (JobID: 1a828d53bc6a886fe0fc7c454e6e66b7)
at
org.apache.flink.client.deployment.ClusterClientJobClientAdapter.lambda$null$6(ClusterClientJobClientAdapter.java:112)
at
java.util.concurrent.CompletableFuture.uniApply(CompletableFuture.java:616)
at
java.util.concurrent.CompletableFuture$UniApply.tryFire(CompletableFuture.java:591)
at
java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
at
java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:1975)
at
org.apache.flink.runtime.concurrent.FutureUtils$1.onComplete(FutureUtils.java:874)
at akka.dispatch.OnComplete.internal(Future.scala:264)
at akka.dispatch.OnComplete.internal(Future.scala:261)
at akka.dispatch.japi$CallbackBridge.apply(Future.scala:191)
at akka.dispatch.japi$CallbackBridge.apply(Future.scala:188)
at scala.concurrent.impl.CallbackRunnable.run(Promise.scala:60)
at
org.apache.flink.runtime.concurrent.Executors$DirectExecutionContext.execute(Executors.java:74)
at scala.concurrent.impl.CallbackRunnable.executeWithValue(Promise.scala:68)
at
scala.concurrent.impl.Promise$DefaultPromise.$anonfun$tryComplete$1(Promise.scala:284)
at
scala.concurrent.impl.Promise$DefaultPromise.$anonfun$tryComplete$1$adapted(Promise.scala:284)
at
scala.concurrent.impl.Promise$DefaultPromise.tryComplete(Promise.scala:284)
at akka.pattern.PromiseActorRef.$bang(AskSupport.scala:573)
at
akka.pattern.PipeToSupport$PipeableFuture$$anonfun$pipeTo$1.applyOrElse(PipeToSupport.scala:22)
at
akka.pattern.PipeToSupport$PipeableFuture$$anonfun$pipeTo$1.applyOrElse(PipeToSupport.scala:21)
at scala.concurrent.Future.$anonfun$andThen$1(Future.scala:532)
at scala.concurrent.impl.Promise.liftedTree1$1(Promise.scala:29)
at scala.concurrent.impl.Promise.$anonfun$transform$1(Promise.scala:29)
at scala.concurrent.impl.CallbackRunnable.run(Promise.scala:60)
at
akka.dispatch.BatchingExecutor$AbstractBatch.processBatch(BatchingExecutor.scala:55)
at
akka.dispatch.BatchingExecutor$BlockableBatch.$anonfun$run$1(BatchingExecutor.scala:91)
at scala.runtime.java8.JFunction0$mcV$sp.apply(JFunction0$mcV$sp.java:12)
at scala.concurrent.BlockContext$.withBlockContext(BlockContext.scala:81)
2020-07-07 12:15:19,438 INFO  [TaskSlotTableImpl] - Free slot
TaskSlot(index:1, state:ACTIVE, resource profile:
ResourceProfile{managedMemory=16.000mb (16777216 bytes),
networkMemory=8.000mb (8388608 bytes)}, allocationId:
ea338a9c24fd1fbc154b82895ffd6120, jobId: 1a828d53bc6a886fe0fc7c454e6e66b7).
at
akka.dispatch.BatchingExecutor$BlockableBatch.run(BatchingExecutor.scala:91)
at akka.dispatch.TaskInvocation.run(AbstractDispatcher.scala:40)
at
akka.dispatch.ForkJoinExecutorConfigurator$AkkaForkJoinTask.exec(ForkJoinExecutorConfigurator.scala:44)
at akka.dispatch.forkjoin.ForkJoinTask.doExec(ForkJoinTask.java:260)
at
akka.dispatch.forkjoin.ForkJoinPool$WorkQueue.runTask(ForkJoinPool.java:1339)
at akka.dispatch.forkjoin.ForkJoinPool.runWorker(ForkJoinPool.java:1979)
at
akka.dispatch.forkjoin.ForkJoinWorkerThread.run(ForkJoinWorkerThread.java:107)
2020-07-07 12:15:19,442 INFO  [StandaloneResourceManager] - Disconnect job
manager a75e313cb87effdf6419056dcac44058@akka://flink/user/jobmanager_1 for
job 1a828d53bc6a886fe0fc7c454e6e66b7 from the resource manager.
Caused by: org.apache.flink.runtime.client.JobExecutionException: Job
execution failed.
at
org.apache.flink.runtime.jobmaster.JobResult.toJobExecutionResult(JobResult.java:147)
at
org.apache.flink.client.deployment.ClusterClientJobClientAdapter.lambda$null$6(ClusterClientJobClientAdapter.java:110)
... 33 more
Caused by: org.apache.flink.runtime.JobException: Recovery is suppressed by
NoRestartBackoffTimeStrategy
at
org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.handleFailure(ExecutionFailureHandler.java:110)
at
org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.getFailureHandlingResult(ExecutionFailureHandler.java:76)
at
org.apache.flink.runtime.scheduler.DefaultScheduler.handleTaskFailure(DefaultScheduler.java:192)
at
org.apache.flink.runtime.scheduler.DefaultScheduler.maybeHandleTaskFailure(DefaultScheduler.java:186)
at
org.apache.flink.runtime.scheduler.DefaultScheduler.updateTaskExecutionStateInternal(DefaultScheduler.java:180)
at
org.apache.flink.runtime.scheduler.SchedulerBase.updateTaskExecutionState(SchedulerBase.java:484)
at
org.apache.flink.runtime.jobmaster.JobMaster.updateTaskExecutionState(JobMaster.java:380)
at sun.reflect.GeneratedMethodAccessor17.invoke(Unknown Source)
at
sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
at java.lang.reflect.Method.invoke(Method.java:498)
at
org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcInvocation(AkkaRpcActor.java:279)
at
org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcMessage(AkkaRpcActor.java:194)
at
org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor.handleRpcMessage(FencedAkkaRpcActor.java:74)
at
org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleMessage(AkkaRpcActor.java:152)
at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:26)
at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:21)
at scala.PartialFunction.applyOrElse(PartialFunction.scala:123)
at scala.PartialFunction.applyOrElse$(PartialFunction.scala:122)
at akka.japi.pf.UnitCaseStatement.applyOrElse(CaseStatements.scala:21)
Caused by: org.apache.flink.client.program.ProgramInvocationException: Job
failed (JobID: 1a828d53bc6a886fe0fc7c454e6e66b7)

at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:171)
at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:172)
at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:172)
at akka.actor.Actor.aroundReceive(Actor.scala:517)
at akka.actor.Actor.aroundReceive$(Actor.scala:515)
at akka.actor.AbstractActor.aroundReceive(AbstractActor.scala:225)
at akka.actor.ActorCell.receiveMessage(ActorCell.scala:592)
at akka.actor.ActorCell.invoke(ActorCell.scala:561)
at akka.dispatch.Mailbox.processMailbox(Mailbox.scala:258)
at akka.dispatch.Mailbox.run(Mailbox.scala:225)
at akka.dispatch.Mailbox.exec(Mailbox.scala:235)
... 4 more
Caused by: java.lang.NullPointerException
at
com.eventdetection.eventfilter.pattern.operator.json.filter.PatternFilter.processElement(PatternFilter.java:103)
at
com.eventdetection.eventfilter.pattern.operator.json.filter.PatternFilter.processElement(PatternFilter.java:40)
at
org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator.processElement1(CoBroadcastWithKeyedOperator.java:113)
at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.processRecord1(StreamTwoInputProcessor.java:135)2020-07-07
12:15:19,450 INFO  [TaskSlotTableImpl] - Free slot TaskSlot(index:3,
state:ACTIVE, resource profile: ResourceProfile{managedMemory=16.000mb
(16777216 bytes), networkMemory=8.000mb (8388608 bytes)}, allocationId:
78475a44354404e70780c097ecb9fc1f, jobId: 1a828d53bc6a886fe0fc7c454e6e66b7).

Caused by: org.apache.flink.runtime.client.JobExecutionException: Job
execution failed.

at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.lambda$new$0(StreamTwoInputProcessor.java:100)
Caused by: org.apache.flink.runtime.JobException: Recovery is suppressed by
NoRestartBackoffTimeStrategy

at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor$StreamTaskNetworkOutput.emitRecord(StreamTwoInputProcessor.java:362)
2020-07-07 12:15:19,451 INFO  [TaskSlotTableImpl] - Free slot
TaskSlot(index:0, state:ACTIVE, resource profile:
ResourceProfile{managedMemory=16.000mb (16777216 bytes),
networkMemory=8.000mb (8388608 bytes)}, allocationId:
7ed77eaff3404148674a6d8ace6711b1, jobId: 1a828d53bc6a886fe0fc7c454e6e66b7).
at
org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput.processElement(StreamTaskNetworkInput.java:151)
at
org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput.emitNext(StreamTaskNetworkInput.java:128)2020-07-07
12:15:19,451 INFO  [TaskSlotTableImpl] - Free slot TaskSlot(index:4,
state:ACTIVE, resource profile: ResourceProfile{managedMemory=16.000mb
(16777216 bytes), networkMemory=8.000mb (8388608 bytes)}, allocationId:
35b8f6d367b0b1d9664011f8c9b9c0f5, jobId: 1a828d53bc6a886fe0fc7c454e6e66b7).
Caused by: java.lang.NullPointerException


2020-07-07 12:15:19,451 INFO  [TaskSlotTableImpl] - Free slot
TaskSlot(index:5, state:ACTIVE, resource profile:
ResourceProfile{managedMemory=16.000mb (16777216 bytes),
networkMemory=8.000mb (8388608 bytes)}, allocationId:
5d7bf9557ad3dbdf879e87d57521a3ce, jobId: 1a828d53bc6a886fe0fc7c454e6e66b7).
at
org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.processInput(StreamTwoInputProcessor.java:182)
at
org.apache.flink.streaming.runtime.tasks.StreamTask.processInput(StreamTask.java:311)
at
org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMailboxLoop(MailboxProcessor.java:187)2020-07-07
12:15:19,452 INFO  [TaskSlotTableImpl] - Free slot TaskSlot(index:7,
state:ACTIVE, resource profile: ResourceProfile{managedMemory=16.000mb
(16777216 bytes), networkMemory=8.000mb (8388608 bytes)}, allocationId:
606b583518d47a7b301071fe38f9720c, jobId: 1a828d53bc6a886fe0fc7c454e6e66b7).

at
org.apache.flink.streaming.runtime.tasks.StreamTask.runMailboxLoop(StreamTask.java:487)
2020-07-07 12:15:19,452 INFO  [TaskExecutor] - JobManager for job
1a828d53bc6a886fe0fc7c454e6e66b7 with leader id
a75e313cb87effdf6419056dcac44058 lost leadership.
at
org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:470)
at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:707)
at org.apache.flink.runtime.taskmanager.Task.run(Task.java:532)
at java.lang.Thread.run(Thread.java:748)
2020-07-07 12:15:19,453 INFO  [TaskSlotTableImpl] - Free slot
TaskSlot(index:2, state:ACTIVE, resource profile:
ResourceProfile{managedMemory=16.000mb (16777216 bytes),
networkMemory=8.000mb (8388608 bytes)}, allocationId:
da9c2d5e020a3726c2322ec3a2751385, jobId: 1a828d53bc6a886fe0fc7c454e6e66b7).
2020-07-07 12:15:19,454 INFO  [TaskSlotTableImpl] - Free slot
TaskSlot(index:6, state:ACTIVE, resource profile:
ResourceProfile{managedMemory=16.000mb (16777216 bytes),
networkMemory=8.000mb (8388608 bytes)}, allocationId:
ea0301a300a6eccd4a86b5c7061eba6b, jobId: 1a828d53bc6a886fe0fc7c454e6e66b7).
2020-07-07 12:15:19,495 INFO  [DispatcherRestEndpoint] - Removing cache
directory C:\Users\RAHUL~1.KUM\AppData\Local\Temp\flink-web-ui
2020-07-07 12:15:19,496 INFO  [DispatcherRestEndpoint] - Shut down complete.
2020-07-07 12:15:19,502 INFO  [StandaloneResourceManager] - Shut down
cluster because application is in CANCELED, diagnostics
DispatcherResourceManagerComponent has been closed..
2020-07-07 12:15:19,504 INFO  [DispatcherResourceManagerComponent] -
Closing components.
2020-07-07 12:15:19,507 INFO  [SessionDispatcherLeaderProcess] - Stopping
SessionDispatcherLeaderProcess.
2020-07-07 12:15:19,507 INFO  [StandaloneDispatcher] - Stopping dispatcher
akka://flink/user/dispatcher.
2020-07-07 12:15:19,507 INFO  [StandaloneDispatcher] - Stopping all
currently running jobs of dispatcher akka://flink/user/dispatcher.
2020-07-07 12:15:19,508 INFO  [SlotManagerImpl] - Closing the SlotManager.
2020-07-07 12:15:19,509 INFO  [SlotManagerImpl] - Suspending the
SlotManager.
2020-07-07 12:15:19,508 INFO  [BackPressureRequestCoordinator] - Shutting
down back pressure request coordinator.
2020-07-07 12:15:19,509 INFO  [StandaloneDispatcher] - Stopped dispatcher
akka://flink/user/dispatcher.
2020-07-07 12:15:19,512 INFO  [TaskExecutor] - Close JobManager connection
for job 1a828d53bc6a886fe0fc7c454e6e66b7.
2020-07-07 12:15:19,518 INFO  [JobLeaderService] - Stop job leader service.
2020-07-07 12:15:19,519 INFO  [TaskExecutorLocalStateStoresManager] -
Shutting down TaskExecutorLocalStateStoresManager.
2020-07-07 12:15:19,527 INFO  [FileChannelManagerImpl] - FileChannelManager
removed spill file directory
C:\Users\RAHUL~1.KUM\AppData\Local\Temp\flink-io-c3083c09-e755-46a5-a9ea-ff95ffce4972
2020-07-07 12:15:19,527 INFO  [NettyShuffleEnvironment] - Shutting down the
network environment and its components.
2020-07-07 12:15:19,529 INFO  [FileChannelManagerImpl] - FileChannelManager
removed spill file directory
C:\Users\RAHUL~1.KUM\AppData\Local\Temp\flink-netty-shuffle-108bc4f3-b0b7-4012-9c6d-e1080749a094
2020-07-07 12:15:19,530 INFO  [KvStateService] - Shutting down the kvState
service and its components.
2020-07-07 12:15:19,530 INFO  [JobLeaderService] - Stop job leader service.
2020-07-07 12:15:19,532 INFO  [FileCache] - removed file cache directory
C:\Users\RAHUL~1.KUM\AppData\Local\Temp\flink-dist-cache-ee90e750-8e6f-41c9-bab0-53fb3d189c71
2020-07-07 12:15:19,532 INFO  [TaskExecutor] - Stopped TaskExecutor
akka://flink/user/taskmanager_0.
2020-07-07 12:15:19,533 INFO  [AkkaRpcService] - Stopping Akka RPC service.
2020-07-07 12:15:19,630 INFO  [AkkaRpcService] - Stopping Akka RPC service.
2020-07-07 12:15:19,631 INFO  [AkkaRpcService] - Stopped Akka RPC service.
2020-07-07 12:15:19,641 INFO  [PermanentBlobCache] - Shutting down BLOB
cache
2020-07-07 12:15:19,644 INFO  [TransientBlobCache] - Shutting down BLOB
cache
2020-07-07 12:15:19,648 INFO  [BlobServer] - Stopped BLOB server at
0.0.0.0:50104
2020-07-07 12:15:19,648 INFO  [AkkaRpcService] - Stopped Akka RPC service.

> Task :SignalPatternMatchingApp.main() FAILED

Execution failed for task ':SignalPatternMatchingApp.main()'.
> Process 'command 'C:/Program Files/Java/jdk1.8.0_241/bin/java.exe''
finished with non-zero exit value 1




On Fri, Jul 3, 2020 at 3:07 PM Kostas Kloudas <kk...@gmail.com> wrote:

> Hi all,
>
> Just as an addition to what Dawid asked, I would also like to ask:
> 1) which Flink version are you using? because the stack trace line
> numbers do not match the current master.
> 2) as a clarification (although maybe not relevant here), there is no
> guarantee on the order of the elements, so
> the non-broadcast side may be faster and when you do
>
> incomingPattern = ctx.getBroadcastState(ruleDescriptor).get(Key);
>
> the "Key" may not be there yet.
>
> Cheers,
> Kostas
>
> On Fri, Jul 3, 2020 at 9:56 AM Dawid Wysakowicz <dw...@apache.org>
> wrote:
> >
> > Hi Rahul.
> >
> > Could you verify that the provided code is the one that fails? Something
> > does not seem right for me in the stacktrace. The stacktrace shows that
> > you call processElement recursively, but I can not see that in the code:
> >
> >
> com.westpac.itm.eq.pattern.TestProcess.processElement(TestProcess.java:35)
> >     at
> >
> com.westpac.itm.eq.pattern.TestProcess.processElement(TestProcess.java:15)
> >     at
> >
> > Where do you exactly get the exception? When accessing the local
> > variable Map<String,String> incomingRule? Is it only a typo or are you
> > really using
> >
> > Hashmap instead of java.util.HashMap? Not sure what is the Hashmap
> class...
> >
> > If you still find some problem there, could you provide is with an
> > example with which we could reproduce the problem?
> >
> > Best,
> >
> > Dawid
> >
> > On 15/06/2020 16:21, bujjirahul45 . wrote:
> > > I have some interesting scenario i am working on pattern matching in
> flink
> > > evaluating the incoming data against a set of patterns using
> > > keyedbroadcastprocessfunction, when i am running the program in IDE i
> am
> > > getting null pointer exception in processElements method when trying to
> > > access ReadOnlyContext but the same program is running fine in flink
> > > terminal, below is my keyedbroadcastprocessfunction
> > >
> > > public class TestProcess extends KeyedBroadcastProcessFunction<String,
> > > Tuple2<String, sampleSignal>,
> > >         Tuple2<String, Map<String, String>>, Tuple2<String,
> sampleSignal>> {
> > >
> > >     public static final MapStateDescriptor <String,Map<String,String>>
> > > ruleDescriptor =
> > >             new MapStateDescriptor <>("RuleDiscriptor",
> > >                     ,BasicTypeInfo.STRING_TYPE_INFO
> > >                     ,new MapTypeInfo<>(String.class,String.class));
> > >
> > >     @Override
> > >     public void processElement(Tuple2<String, sampleSignal> value,
> > > ReadOnlyContext ctx, Collector<Tuple2<String,
> > >             sampleSignal>> out) throws Exception {
> > >
> > >         System.out.println("sampleSignal: " +value.f1.toString());
> > >
> > >         String Context =
> ctx.getBroadcastState(ruleDescriptor).toString();
> > >
> > >         Map<String,String> incomingRule = new Hashmap<>();
> > >
> > >         incomingPattern =
> ctx.getBroadcastState(ruleDescriptor).get(Key);
> > >
> > >         /*It's hitting nullpointer exception when printing the size of
> > > hashmpa*/
> > >         System.out.println("Map Size: " +incomingRule.size());
> > >
> > >         System.out.println("Context: " +Context);
> > >
> > >         System.out.println("Before Rule Iterator");
> > >
> > >         /*I tried below way to print the values in broadcaststream
> just to
> > > print the values
> > >           in broadcast state it don't print anything*/
> > >         for(Map.Entry<String, Map<String, String>> rules:
> > >
>  ctx.getBroadcastState(ruleDescriptor).immutableEntries()){
> > >             System.out.println("Key: " +rules.getKey());
> > >             System.out.println("Value: "+rules.getValue());
> > >         }
> > >
> > >
> > >         for(Map.Entry<String,String> rules: incomingRule.entrySet()){
> > >
> > >             System.out.println("Key: " +rules.getKey());
> > >             System.out.println("Value: "+rules.getValue());
> > >         }
> > >
> > >         out.collect(new Tuple2<>(value.f0,value.f1));
> > >
> > >     }
> > >
> > >     @Override
> > >     public void processBroadcastElement(Tuple2<String, Map<String,
> String>>
> > > value, Context ctx,
> > >                                         Collector<Tuple2<String,
> > > sampleSignal>> out) throws Exception {
> > >
> > >         System.out.println("BroadCastState Key: " +value.f0);
> > >         System.out.println("BroadCastState Value: " +value.f1);
> > >         ctx.getBroadcastState(ruleDescriptor).put(value.f0,value.f1);
> > >
> > >     }
> > > }
> > > Below is the IDE Terminal output with error exception
> > >
> > > /*Its prints below data in BroadCastState in processBroadcastElement*/
> > > BroadCastState Key: Key
> > > BroadCastState Value: {"RuleKey":"RuleValue"}
> > >
> > >
> > > /*Its printing below data in processElement*/
> > >
> > > sampleSignal: {SignalData}
> > >
> > > When it hits the Map in which i am storing the Rule Name and Rule
> Condition
> > > its throwing nullpointer exception and below is the stack trace of
> error
> > >
> > > Exception in thread "main"
> > > org.apache.flink.runtime.client.JobExecutionException: Job execution
> failed.
> > >     at
> > >
> org.apache.flink.runtime.jobmaster.JobResult.toJobExecutionResult(JobResult.java:146)
> > >     at
> > >
> org.apache.flink.runtime.minicluster.MiniCluster.executeJobBlocking(MiniCluster.java:638)
> > >     at
> > >
> org.apache.flink.streaming.api.environment.LocalStreamEnvironment.execute(LocalStreamEnvironment.java:123)
> > >     at com.westpac.itm.eq.pattern.App.main(App.java:34)
> > > Caused by: java.lang.NullPointerException
> > >     at
> > >
> com.westpac.itm.eq.pattern.TestProcess.processElement(TestProcess.java:35)
> > >     at
> > >
> com.westpac.itm.eq.pattern.TestProcess.processElement(TestProcess.java:15)
> > >     at
> > > org.apache.flink.streaming.api.operators.co
> .CoBroadcastWithKeyedOperator.processElement1(CoBroadcastWithKeyedOperator.java:113)
> > >     at
> > > org.apache.flink.streaming.runtime.io
> .StreamTwoInputProcessor.processInput(StreamTwoInputProcessor.java:238)
> > > Caused by: java.lang.NullPointerException
> > >
> > >     at
> > >
> org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask.run(TwoInputStreamTask.java:117)
> > >     at
> > >
> org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:300)
> > >     at org.apache.flink.runtime.taskmanager.Task.run(Task.java:711)
> > >     at java.lang.Thread.run(Thread.java:748)
> > >
> > >
> > > Please help me in solving the issue
> > >
> > > Thanks,
> > > Rahul.
> > >
> >
>

Re: NullPointer Exception while trying to access or read ReadOnly ctx in processElement method in KeyedBroadCastProcessFunction in Apache Flink

Posted by Kostas Kloudas <kk...@gmail.com>.
Hi all,

Just as an addition to what Dawid asked, I would also like to ask:
1) which Flink version are you using? because the stack trace line
numbers do not match the current master.
2) as a clarification (although maybe not relevant here), there is no
guarantee on the order of the elements, so
the non-broadcast side may be faster and when you do

incomingPattern = ctx.getBroadcastState(ruleDescriptor).get(Key);

the "Key" may not be there yet.

Cheers,
Kostas

On Fri, Jul 3, 2020 at 9:56 AM Dawid Wysakowicz <dw...@apache.org> wrote:
>
> Hi Rahul.
>
> Could you verify that the provided code is the one that fails? Something
> does not seem right for me in the stacktrace. The stacktrace shows that
> you call processElement recursively, but I can not see that in the code:
>
> com.westpac.itm.eq.pattern.TestProcess.processElement(TestProcess.java:35)
>     at
> com.westpac.itm.eq.pattern.TestProcess.processElement(TestProcess.java:15)
>     at
>
> Where do you exactly get the exception? When accessing the local
> variable Map<String,String> incomingRule? Is it only a typo or are you
> really using
>
> Hashmap instead of java.util.HashMap? Not sure what is the Hashmap class...
>
> If you still find some problem there, could you provide is with an
> example with which we could reproduce the problem?
>
> Best,
>
> Dawid
>
> On 15/06/2020 16:21, bujjirahul45 . wrote:
> > I have some interesting scenario i am working on pattern matching in flink
> > evaluating the incoming data against a set of patterns using
> > keyedbroadcastprocessfunction, when i am running the program in IDE i am
> > getting null pointer exception in processElements method when trying to
> > access ReadOnlyContext but the same program is running fine in flink
> > terminal, below is my keyedbroadcastprocessfunction
> >
> > public class TestProcess extends KeyedBroadcastProcessFunction<String,
> > Tuple2<String, sampleSignal>,
> >         Tuple2<String, Map<String, String>>, Tuple2<String, sampleSignal>> {
> >
> >     public static final MapStateDescriptor <String,Map<String,String>>
> > ruleDescriptor =
> >             new MapStateDescriptor <>("RuleDiscriptor",
> >                     ,BasicTypeInfo.STRING_TYPE_INFO
> >                     ,new MapTypeInfo<>(String.class,String.class));
> >
> >     @Override
> >     public void processElement(Tuple2<String, sampleSignal> value,
> > ReadOnlyContext ctx, Collector<Tuple2<String,
> >             sampleSignal>> out) throws Exception {
> >
> >         System.out.println("sampleSignal: " +value.f1.toString());
> >
> >         String Context = ctx.getBroadcastState(ruleDescriptor).toString();
> >
> >         Map<String,String> incomingRule = new Hashmap<>();
> >
> >         incomingPattern = ctx.getBroadcastState(ruleDescriptor).get(Key);
> >
> >         /*It's hitting nullpointer exception when printing the size of
> > hashmpa*/
> >         System.out.println("Map Size: " +incomingRule.size());
> >
> >         System.out.println("Context: " +Context);
> >
> >         System.out.println("Before Rule Iterator");
> >
> >         /*I tried below way to print the values in broadcaststream just to
> > print the values
> >           in broadcast state it don't print anything*/
> >         for(Map.Entry<String, Map<String, String>> rules:
> >                 ctx.getBroadcastState(ruleDescriptor).immutableEntries()){
> >             System.out.println("Key: " +rules.getKey());
> >             System.out.println("Value: "+rules.getValue());
> >         }
> >
> >
> >         for(Map.Entry<String,String> rules: incomingRule.entrySet()){
> >
> >             System.out.println("Key: " +rules.getKey());
> >             System.out.println("Value: "+rules.getValue());
> >         }
> >
> >         out.collect(new Tuple2<>(value.f0,value.f1));
> >
> >     }
> >
> >     @Override
> >     public void processBroadcastElement(Tuple2<String, Map<String, String>>
> > value, Context ctx,
> >                                         Collector<Tuple2<String,
> > sampleSignal>> out) throws Exception {
> >
> >         System.out.println("BroadCastState Key: " +value.f0);
> >         System.out.println("BroadCastState Value: " +value.f1);
> >         ctx.getBroadcastState(ruleDescriptor).put(value.f0,value.f1);
> >
> >     }
> > }
> > Below is the IDE Terminal output with error exception
> >
> > /*Its prints below data in BroadCastState in processBroadcastElement*/
> > BroadCastState Key: Key
> > BroadCastState Value: {"RuleKey":"RuleValue"}
> >
> >
> > /*Its printing below data in processElement*/
> >
> > sampleSignal: {SignalData}
> >
> > When it hits the Map in which i am storing the Rule Name and Rule Condition
> > its throwing nullpointer exception and below is the stack trace of error
> >
> > Exception in thread "main"
> > org.apache.flink.runtime.client.JobExecutionException: Job execution failed.
> >     at
> > org.apache.flink.runtime.jobmaster.JobResult.toJobExecutionResult(JobResult.java:146)
> >     at
> > org.apache.flink.runtime.minicluster.MiniCluster.executeJobBlocking(MiniCluster.java:638)
> >     at
> > org.apache.flink.streaming.api.environment.LocalStreamEnvironment.execute(LocalStreamEnvironment.java:123)
> >     at com.westpac.itm.eq.pattern.App.main(App.java:34)
> > Caused by: java.lang.NullPointerException
> >     at
> > com.westpac.itm.eq.pattern.TestProcess.processElement(TestProcess.java:35)
> >     at
> > com.westpac.itm.eq.pattern.TestProcess.processElement(TestProcess.java:15)
> >     at
> > org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator.processElement1(CoBroadcastWithKeyedOperator.java:113)
> >     at
> > org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.processInput(StreamTwoInputProcessor.java:238)
> > Caused by: java.lang.NullPointerException
> >
> >     at
> > org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask.run(TwoInputStreamTask.java:117)
> >     at
> > org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:300)
> >     at org.apache.flink.runtime.taskmanager.Task.run(Task.java:711)
> >     at java.lang.Thread.run(Thread.java:748)
> >
> >
> > Please help me in solving the issue
> >
> > Thanks,
> > Rahul.
> >
>