You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@flink.apache.org by "Till Rohrmann (JIRA)" <ji...@apache.org> on 2017/09/28 15:39:01 UTC

[jira] [Assigned] (FLINK-7734) test instability in ResourceManagerTest

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

Till Rohrmann reassigned FLINK-7734:
------------------------------------

    Assignee: Till Rohrmann

> test instability in ResourceManagerTest
> ---------------------------------------
>
>                 Key: FLINK-7734
>                 URL: https://issues.apache.org/jira/browse/FLINK-7734
>             Project: Flink
>          Issue Type: Bug
>          Components: ResourceManager, Tests
>    Affects Versions: 1.4.0
>            Reporter: Nico Kruber
>            Assignee: Till Rohrmann
>            Priority: Critical
>              Labels: test-stability
>
> {code}
> Tests run: 8, Failures: 0, Errors: 1, Skipped: 0, Time elapsed: 4.033 sec <<< FAILURE! - in org.apache.flink.runtime.clusterframework.ResourceManagerTest
> testHeartbeatTimeoutWithTaskExecutor(org.apache.flink.runtime.clusterframework.ResourceManagerTest)  Time elapsed: 0.716 sec  <<< ERROR!
> java.util.concurrent.ExecutionException: org.apache.flink.runtime.rpc.exceptions.FencingTokenException: Fencing token mismatch: Ignoring message LocalFencedMessage(null, LocalRpcInvocation(registerTaskExecutor(String, ResourceID, SlotReport, Time))) because the fencing token null did not match the expected fencing token 9320b08d25f4e942b332acbae9464e8b.
> 	at java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
> 	at java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1915)
> 	at org.apache.flink.runtime.clusterframework.ResourceManagerTest.testHeartbeatTimeoutWithTaskExecutor(ResourceManagerTest.java:541)
> Caused by: org.apache.flink.runtime.rpc.exceptions.FencingTokenException: Fencing token mismatch: Ignoring message LocalFencedMessage(null, LocalRpcInvocation(registerTaskExecutor(String, ResourceID, SlotReport, Time))) because the fencing token null did not match the expected fencing token 9320b08d25f4e942b332acbae9464e8b.
> 	at org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor.handleMessage(FencedAkkaRpcActor.java:73)
> 	at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.lambda$onReceive$0(AkkaRpcActor.java:129)
> 	at akka.actor.ActorCell$$anonfun$become$1.applyOrElse(ActorCell.scala:534)
> 	at akka.actor.Actor$class.aroundReceive(Actor.scala:467)
> 	at akka.actor.UntypedActor.aroundReceive(UntypedActor.scala:97)
> 	at akka.actor.ActorCell.receiveMessage(ActorCell.scala:516)
> 	at akka.actor.ActorCell.invoke(ActorCell.scala:487)
> 	at akka.dispatch.Mailbox.processMailbox(Mailbox.scala:238)
> 	at akka.dispatch.Mailbox.run(Mailbox.scala:220)
> 	at akka.dispatch.ForkJoinExecutorConfigurator$AkkaForkJoinTask.exec(AbstractDispatcher.scala:397)
> 	at scala.concurrent.forkjoin.ForkJoinTask.doExec(ForkJoinTask.java:260)
> 	at scala.concurrent.forkjoin.ForkJoinPool$WorkQueue.runTask(ForkJoinPool.java:1339)
> 	at scala.concurrent.forkjoin.ForkJoinPool.runWorker(ForkJoinPool.java:1979)
> 	at scala.concurrent.forkjoin.ForkJoinWorkerThread.run(ForkJoinWorkerThread.java:107)
> {code}
> https://travis-ci.org/NicoK/flink/jobs/280858456



--
This message was sent by Atlassian JIRA
(v6.4.14#64029)