You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@streampipes.apache.org by "Patrick Wiener (Jira)" <ji...@apache.org> on 2021/01/19 19:51:00 UTC

[jira] [Created] (STREAMPIPES-283) NullPointer Exception in Flink pattern detection processor

Patrick Wiener created STREAMPIPES-283:
------------------------------------------

             Summary: NullPointer Exception in Flink pattern detection processor
                 Key: STREAMPIPES-283
                 URL: https://issues.apache.org/jira/browse/STREAMPIPES-283
             Project: StreamPipes
          Issue Type: Bug
          Components: Pipeline Elements
    Affects Versions: 0.67.0
            Reporter: Patrick Wiener
             Fix For: 0.68.0


There is a bug in the Sequence pattern detection processing for Flink currently leading to a Nullpointer Exception in this method:
{code:java}
@Override
public void processElement1(Event value, Context ctx, Collector<Event> out) throws Exception {
 state.update(new EventStorage(System.currentTimeMillis(), value));
}{code}
See error log:
{code:java}
pipeline-elements-all-flink_1  | Caused by: java.lang.NullPointerException
pipeline-elements-all-flink_1  | 	at org.apache.streampipes.processors.pattern.detection.flink.processor.sequence.Sequence.processElement1(Sequence.java:48)
pipeline-elements-all-flink_1  | 	at org.apache.streampipes.processors.pattern.detection.flink.processor.sequence.Sequence.processElement1(Sequence.java:26)
pipeline-elements-all-flink_1  | 	at org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator.processElement1(LegacyKeyedCoProcessOperator.java:81)
pipeline-elements-all-flink_1  | 	at org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor.processInput(StreamTwoInputProcessor.java:259)
pipeline-elements-all-flink_1  | 	at org.apache.flink.streaming.runtime.tasks.StreamTask.processInput(StreamTask.java:279)
pipeline-elements-all-flink_1  | 	at org.apache.flink.streaming.runtime.tasks.StreamTask.run(StreamTask.java:301)
pipeline-elements-all-flink_1  | 	at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:406)
pipeline-elements-all-flink_1  | 	at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:705)
pipeline-elements-all-flink_1  | 	at org.apache.flink.runtime.taskmanager.Task.run(Task.java:530)
pipeline-elements-all-flink_1  | 	at java.lang.Thread.run(Unknown Source)
{code}



--
This message was sent by Atlassian Jira
(v8.3.4#803005)