You are viewing a plain text version of this content. The canonical link for it is here.
Posted to user-zh@flink.apache.org by "casel.chen" <ca...@126.com> on 2021/11/23 15:13:25 UTC

Re:PartitionNotFoundException

忘记说flink版本是 1.12.5




在 2021-11-23 23:12:32,"casel.chen" <ca...@126.com> 写道:

我有一个flink作业跑在native k8s上面,以application mode运行,之前运行是OK的,最近人为重启了该作业,作业虽能启动,但运行了五分钟后就抛如下异常。完整的日志文件见附件。请问这个异常跟什么有关?我查了一下有说增大 `taskmanager.network.request-backoff.max` 参数,可我设置成 30000000 还是会抛此异常。


2021-11-23 20:36:32
org.apache.flink.runtime.io.network.partition.PartitionNotFoundException: Partition 3a0b0f75636082fb0557fdf435392f88#7@f6b347a8236376356ec64a81775d39e9 not found.
  at org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel.failPartitionRequest(RemoteInputChannel.java:280)
  at org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel.retriggerSubpartitionRequest(RemoteInputChannel.java:198)
  at org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate.retriggerPartitionRequest(SingleInputGate.java:515)
  at org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate.lambda$triggerPartitionStateCheck$1(SingleInputGate.java:841)
  at java.util.concurrent.CompletableFuture.uniAccept(CompletableFuture.java:670)
  at java.util.concurrent.CompletableFuture$UniAccept.tryFire(CompletableFuture.java:646)
  at java.util.concurrent.CompletableFuture$Completion.run(CompletableFuture.java:456)
  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)