You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@flink.apache.org by "Chesnay Schepler (Jira)" <ji...@apache.org> on 2020/01/31 11:10:00 UTC

[jira] [Closed] (FLINK-15423) Show the detail of submitting job fail

     [ https://issues.apache.org/jira/browse/FLINK-15423?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ]

Chesnay Schepler closed FLINK-15423.
------------------------------------
    Resolution: Not A Problem

The error cause was contained in the stack trace:

{{java.lang.IllegalArgumentException: Operator parallelism not within bounds: 214748364}}

> Show the detail of submitting job fail
> --------------------------------------
>
>                 Key: FLINK-15423
>                 URL: https://issues.apache.org/jira/browse/FLINK-15423
>             Project: Flink
>          Issue Type: Improvement
>          Components: Runtime / REST
>            Reporter: lining
>            Priority: Major
>
> Now when the user fails to submit the job, could we return the details of the failure?
> For example:
>    - in Flink web UI
>    - url: [http://localhost:8081/jars/ac2873e5-1f5d-493b-97b3-2c658261ee68_TopSpeedWindowing.jar/run?entry-class=org.apache.flink.streaming.examples.windowing.TopSpeedWindowing&parallelism=214748364]
>   - result: \{"errors":["Internal server error.","<Exception on server side:\norg.apache.flink.runtime.client.JobSubmissionException: Failed to submit job.\n\tat org.apache.flink.runtime.dispatcher.Dispatcher.lambda$internalSubmitJob$3(Dispatcher.java:336)\n\tat java.util.concurrent.CompletableFuture.uniHandle(CompletableFuture.java:822)\n\tat java.util.concurrent.CompletableFuture$UniHandle.tryFire(CompletableFuture.java:797)\n\tat java.util.concurrent.CompletableFuture$Completion.run(CompletableFuture.java:442)\n\tat akka.dispatch.TaskInvocation.run(AbstractDispatcher.scala:40)\n\tat akka.dispatch.ForkJoinExecutorConfigurator$AkkaForkJoinTask.exec(ForkJoinExecutorConfigurator.scala:44)\n\tat akka.dispatch.forkjoin.ForkJoinTask.doExec(ForkJoinTask.java:260)\n\tat akka.dispatch.forkjoin.ForkJoinPool$WorkQueue.runTask(ForkJoinPool.java:1339)\n\tat akka.dispatch.forkjoin.ForkJoinPool.runWorker(ForkJoinPool.java:1979)\n\tat akka.dispatch.forkjoin.ForkJoinWorkerThread.run(ForkJoinWorkerThread.java:107)\nCaused by: java.lang.RuntimeException: org.apache.flink.runtime.client.JobExecutionException: Could not set up JobManager\n\tat org.apache.flink.util.function.CheckedSupplier.lambda$unchecked$0(CheckedSupplier.java:36)\n\tat java.util.concurrent.CompletableFuture$AsyncSupply.run(CompletableFuture.java:1590)\n\t... 6 more\nCaused by: org.apache.flink.runtime.client.JobExecutionException: Could not set up JobManager\n\tat org.apache.flink.runtime.jobmaster.JobManagerRunnerImpl.<init>(JobManagerRunnerImpl.java:152)\n\tat org.apache.flink.runtime.dispatcher.DefaultJobManagerRunnerFactory.createJobManagerRunner(DefaultJobManagerRunnerFactory.java:84)\n\tat org.apache.flink.runtime.dispatcher.Dispatcher.lambda$createJobManagerRunner$6(Dispatcher.java:379)\n\tat org.apache.flink.util.function.CheckedSupplier.lambda$unchecked$0(CheckedSupplier.java:34)\n\t... 7 more\nCaused by: java.lang.IllegalArgumentException: Operator parallelism not within bounds: 214748364\n\tat org.apache.flink.util.Preconditions.checkArgument(Preconditions.java:139)\n\tat org.apache.flink.runtime.state.KeyGroupRangeAssignment.checkParallelismPreconditions(KeyGroupRangeAssignment.java:141)\n\tat org.apache.flink.runtime.state.KeyGroupRangeAssignment.computeDefaultMaxParallelism(KeyGroupRangeAssignment.java:131)\n\tat org.apache.flink.runtime.executiongraph.ExecutionJobVertex.<init>(ExecutionJobVertex.java:184)\n\tat org.apache.flink.runtime.executiongraph.ExecutionGraph.attachJobGraph(ExecutionGraph.java:806)\n\tat org.apache.flink.runtime.executiongraph.ExecutionGraphBuilder.buildGraph(ExecutionGraphBuilder.java:228)\n\tat org.apache.flink.runtime.scheduler.SchedulerBase.createExecutionGraph(SchedulerBase.java:253)\n\tat org.apache.flink.runtime.scheduler.SchedulerBase.createAndRestoreExecutionGraph(SchedulerBase.java:225)\n\tat org.apache.flink.runtime.scheduler.SchedulerBase.<init>(SchedulerBase.java:213)\n\tat org.apache.flink.runtime.scheduler.DefaultScheduler.<init>(DefaultScheduler.java:117)\n\tat org.apache.flink.runtime.scheduler.DefaultSchedulerFactory.createInstance(DefaultSchedulerFactory.java:105)\n\tat org.apache.flink.runtime.jobmaster.JobMaster.createScheduler(JobMaster.java:278)\n\tat org.apache.flink.runtime.jobmaster.JobMaster.<init>(JobMaster.java:266)\n\tat org.apache.flink.runtime.jobmaster.factories.DefaultJobMasterServiceFactory.createJobMasterService(DefaultJobMasterServiceFactory.java:98)\n\tat org.apache.flink.runtime.jobmaster.factories.DefaultJobMasterServiceFactory.createJobMasterService(DefaultJobMasterServiceFactory.java:40)\n\tat org.apache.flink.runtime.jobmaster.JobManagerRunnerImpl.<init>(JobManagerRunnerImpl.java:146)\n\t... 10 more\n\nEnd of exception on server side>"]}



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