You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@flink.apache.org by "Zhipeng Zhang (Jira)" <ji...@apache.org> on 2022/07/29 07:09:00 UTC

[jira] [Created] (FLINK-28739) Illegal State for checkpoint in LogisticRegressionTest.test_get_model_data

Zhipeng Zhang created FLINK-28739:
-------------------------------------

             Summary: Illegal State for checkpoint in LogisticRegressionTest.test_get_model_data 
                 Key: FLINK-28739
                 URL: https://issues.apache.org/jira/browse/FLINK-28739
             Project: Flink
          Issue Type: Bug
    Affects Versions: ml-2.1.0
            Reporter: Zhipeng Zhang
             Fix For: ml-2.2.0, ml-2.1.0


Caused by: java.lang.IllegalStateException: Should be blocked by checkpoint. 
[157|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:158]E at org.apache.flink.util.Preconditions.checkState(Preconditions.java:193) 
[158|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:159]E at org.apache.flink.runtime.io.network.partition.PipelinedSubpartition.resumeConsumption(PipelinedSubpartition.java:381) 
[159|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:160]E at org.apache.flink.runtime.io.network.partition.PipelinedSubpartitionView.resumeConsumption(PipelinedSubpartitionView.java:79) 
[160|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:161]E at org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel.resumeConsumption(LocalInputChannel.java:286) 
[161|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:162]E at org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate.resumeConsumption(SingleInputGate.java:941) 
[162|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:163]E at org.apache.flink.runtime.taskmanager.InputGateWithMetrics.resumeConsumption(InputGateWithMetrics.java:60) 
[163|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:164]E at org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler.processBarrier(SingleCheckpointBarrierHandler.java:223) 
[164|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:165]E at org.apache.flink.streaming.runtime.tasks.StreamTask.triggerUnfinishedChannelsCheckpoint(StreamTask.java:1172) 
[165|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:166]E at org.apache.flink.streaming.runtime.tasks.StreamTask.lambda$triggerCheckpointAsync$11(StreamTask.java:1089) 
[166|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:167]E at org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor$1.runThrowing(StreamTaskActionExecutor.java:50) 
[167|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:168]E at org.apache.flink.streaming.runtime.tasks.mailbox.Mail.run(Mail.java:90) 
[168|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:169]E at org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl.yield(MailboxExecutorImpl.java:86) 
[169|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:170]E at org.apache.flink.iteration.operator.HeadOperator.endInput(HeadOperator.java:407) 
[170|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:171]E at org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper.endOperatorInput(StreamOperatorWrapper.java:96) 
[171|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:172]E at org.apache.flink.streaming.runtime.tasks.RegularOperatorChain.endInput(RegularOperatorChain.java:97) 
[172|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:173]E at org.apache.flink.streaming.runtime.io.StreamOneInputProcessor.processInput(StreamOneInputProcessor.java:68) 
[173|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:174]E at org.apache.flink.streaming.runtime.tasks.StreamTask.processInput(StreamTask.java:519) 
[174|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:175]E at org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMailboxLoop(MailboxProcessor.java:203) 
[175|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:176]E at org.apache.flink.streaming.runtime.tasks.StreamTask.runMailboxLoop(StreamTask.java:804) 
[176|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:177]E at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:753) 
[177|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:178]E at org.apache.flink.runtime.taskmanager.Task.runWithSystemExitMonitoring(Task.java:948) 
[178|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:179]E at org.apache.flink.runtime.taskmanager.Task.restoreAndInvoke(Task.java:927) 
[179|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:180]E at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:741) 
[180|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:181]E at org.apache.flink.runtime.taskmanager.Task.run(Task.java:563) 
[181|https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true#step:9:182]E at java.lang.Thread.run(Thread.java:750)
 
 
https://github.com/apache/flink-ml/runs/7351668847?check_suite_focus=true



--
This message was sent by Atlassian Jira
(v8.20.10#820010)