You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@flink.apache.org by "Stefan Richter (JIRA)" <ji...@apache.org> on 2017/04/18 19:50:41 UTC

[jira] [Commented] (FLINK-6321) RocksDB state backend Checkpointing is not working with KeydCEP.

    [ https://issues.apache.org/jira/browse/FLINK-6321?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel&focusedCommentId=15973369#comment-15973369 ] 

Stefan Richter commented on FLINK-6321:
---------------------------------------

The reported exception is probably not showing the root cause of the problem. Typically, this exception simply means that the checkpoint got canceled by the checkpoint coordinator because the snapshot failed in one task. Can you find other exceptions earlier in the log that could hint the actual cause for the cancelation?

> RocksDB state backend Checkpointing is not working with KeydCEP.
> ----------------------------------------------------------------
>
>                 Key: FLINK-6321
>                 URL: https://issues.apache.org/jira/browse/FLINK-6321
>             Project: Flink
>          Issue Type: Bug
>          Components: CEP, State Backends, Checkpointing
>    Affects Versions: 1.2.0
>         Environment: yarn-cluster, RocksDB State backend, Checkpointing every 1000 ms
>            Reporter: Shashank Agarwal
>
> Checkpointing is not working with RocksDBStateBackend when using CEP. It's working fine with FsStateBackend and MemoryStateBackend. Application failing every-time.
> {code}
> 04/18/2017 21:53:20	Job execution switched to status FAILING.
> AsynchronousException{java.lang.Exception: Could not materialize checkpoint 46 for operator KeyedCEPPatternOperator -> Map (1/4).}
> 	at org.apache.flink.streaming.runtime.tasks.StreamTask$AsyncCheckpointRunnable.run(StreamTask.java:980)
> 	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
> 	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
> 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1142)
> 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:617)
> 	at java.lang.Thread.run(Thread.java:745)
> Caused by: java.lang.Exception: Could not materialize checkpoint 46 for operator KeyedCEPPatternOperator -> Map (1/4).
> 	... 6 more
> Caused by: java.util.concurrent.CancellationException
> 	at java.util.concurrent.FutureTask.report(FutureTask.java:121)
> 	at java.util.concurrent.FutureTask.get(FutureTask.java:192)
> 	at org.apache.flink.util.FutureUtil.runIfNotDoneAndGet(FutureUtil.java:40)
> 	at org.apache.flink.streaming.runtime.tasks.StreamTask$AsyncCheckpointRunnable.run(StreamTask.java:915)
> 	... 5 more
> {code}



--
This message was sent by Atlassian JIRA
(v6.3.15#6346)