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 2020/08/28 09:41:00 UTC

[jira] [Closed] (FLINK-15225) LeaderChangeClusterComponentsTest#testReelectionOfDispatcher occasionally requires 30 seconds

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

Till Rohrmann closed FLINK-15225.
---------------------------------
    Resolution: Cannot Reproduce

The test failure does not seem to occur very often. Closing this ticket until the problem reoccurs.

> LeaderChangeClusterComponentsTest#testReelectionOfDispatcher occasionally requires 30 seconds
> ---------------------------------------------------------------------------------------------
>
>                 Key: FLINK-15225
>                 URL: https://issues.apache.org/jira/browse/FLINK-15225
>             Project: Flink
>          Issue Type: Improvement
>          Components: Runtime / Coordination, Tests
>    Affects Versions: 1.10.0
>            Reporter: Chesnay Schepler
>            Priority: Major
>
> {code:java}
> 20845 [flink-akka.actor.default-dispatcher-5] INFO  org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl  - Starting the SlotManager.
> 20845 [mini-cluster-io-thread-1] INFO  org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess  - Recover all persisted job graphs.
> 20845 [mini-cluster-io-thread-1] INFO  org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess  - Successfully recovered 0 persisted job graphs.
> 20845 [flink-akka.actor.default-dispatcher-5] DEBUG org.apache.flink.runtime.resourcemanager.StandaloneResourceManager  - Trigger heartbeat request.
> 20845 [flink-akka.actor.default-dispatcher-5] DEBUG org.apache.flink.runtime.resourcemanager.StandaloneResourceManager  - Trigger heartbeat request.
> 20845 [flink-akka.actor.default-dispatcher-2] INFO  org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService  - Received confirmation of leadership for leader akka://flink/user/resourcemanager9fa41f3a-7bd4-4f72-ae07-76b75499c88d , session=e73f31a7-c45f-4328-addd-3d7aa17fd083
> 20845 [mini-cluster-io-thread-1] INFO  org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Starting RPC endpoint for org.apache.flink.runtime.dispatcher.StandaloneDispatcher at akka://flink/user/dispatcherd5f8446f-b44d-4bcd-88b3-65105c1c6ca0 .
> 20845 [pool-1-thread-1] DEBUG org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Try to connect to remote RPC endpoint with address akka://flink/user/resourcemanager9fa41f3a-7bd4-4f72-ae07-76b75499c88d. Returning a org.apache.flink.runtime.resourcemanager.ResourceManagerGateway gateway.
> 20845 [flink-akka.actor.default-dispatcher-5] INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor  - Connecting to ResourceManager akka://flink/user/resourcemanager9fa41f3a-7bd4-4f72-ae07-76b75499c88d(addd3d7aa17fd083e73f31a7c45f4328).
> 20845 [flink-akka.actor.default-dispatcher-5] DEBUG org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Try to connect to remote RPC endpoint with address akka://flink/user/resourcemanager9fa41f3a-7bd4-4f72-ae07-76b75499c88d. Returning a org.apache.flink.runtime.resourcemanager.ResourceManagerGateway gateway.
> 20845 [pool-1-thread-1] DEBUG org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Try to connect to remote RPC endpoint with address akka://flink/user/resourcemanager9fa41f3a-7bd4-4f72-ae07-76b75499c88d. Returning a org.apache.flink.runtime.resourcemanager.ResourceManagerGateway gateway.
> 20846 [flink-akka.actor.default-dispatcher-2] INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor  - Resolved ResourceManager address, beginning registration
> 20846 [flink-akka.actor.default-dispatcher-5] INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor  - Connecting to ResourceManager akka://flink/user/resourcemanager9fa41f3a-7bd4-4f72-ae07-76b75499c88d(addd3d7aa17fd083e73f31a7c45f4328).
> 20846 [flink-akka.actor.default-dispatcher-2] INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor  - Registration at ResourceManager attempt 1 (timeout=100ms)
> 20846 [flink-akka.actor.default-dispatcher-5] DEBUG org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Try to connect to remote RPC endpoint with address akka://flink/user/resourcemanager9fa41f3a-7bd4-4f72-ae07-76b75499c88d. Returning a org.apache.flink.runtime.resourcemanager.ResourceManagerGateway gateway.
> 20846 [flink-akka.actor.default-dispatcher-5] INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor  - Resolved ResourceManager address, beginning registration
> 20846 [flink-akka.actor.default-dispatcher-5] INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor  - Registration at ResourceManager attempt 1 (timeout=100ms)
> 20846 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Try to connect to remote RPC endpoint with address akka://flink/user/taskmanager_285. Returning a org.apache.flink.runtime.taskexecutor.TaskExecutorGateway gateway.
> 20846 [mini-cluster-io-thread-1] INFO  org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService  - Received confirmation of leadership for leader akka://flink/user/dispatcherd5f8446f-b44d-4bcd-88b3-65105c1c6ca0 , session=d20872e6-0b96-43ea-9da2-7590a255e906
> 20846 [pool-1-thread-1] DEBUG org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Try to connect to remote RPC endpoint with address akka://flink/user/dispatcherd5f8446f-b44d-4bcd-88b3-65105c1c6ca0. Returning a org.apache.flink.runtime.dispatcher.DispatcherGateway gateway.
> 20846 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Try to connect to remote RPC endpoint with address akka://flink/user/taskmanager_286. Returning a org.apache.flink.runtime.taskexecutor.TaskExecutorGateway gateway.
> 20846 [pool-1-thread-1] DEBUG org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Try to connect to remote RPC endpoint with address akka://flink/user/dispatcherd5f8446f-b44d-4bcd-88b3-65105c1c6ca0. Returning a org.apache.flink.runtime.dispatcher.DispatcherGateway gateway.
> 20846 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.resourcemanager.StandaloneResourceManager  - Registering TaskManager with ResourceID 0f553ce4-9ee6-4861-9961-de414cf8d08b (akka://flink/user/taskmanager_285) at ResourceManager
> 20846 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.resourcemanager.StandaloneResourceManager  - Registering TaskManager with ResourceID 30248eb7-9288-488b-874a-204845181b60 (akka://flink/user/taskmanager_286) at ResourceManager
> 20846 [flink-akka.actor.default-dispatcher-4] INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor  - Successful registration at resource manager akka://flink/user/resourcemanager9fa41f3a-7bd4-4f72-ae07-76b75499c88d under registration id 3075b1693bff8da60555d090ff5123dc.
> 20846 [flink-akka.actor.default-dispatcher-2] INFO  org.apache.flink.runtime.taskexecutor.TaskExecutor  - Successful registration at resource manager akka://flink/user/resourcemanager9fa41f3a-7bd4-4f72-ae07-76b75499c88d under registration id 2407f57c0c14584af2107ae72ea04867.
> 20846 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl  - Registering TaskManager 0f553ce4-9ee6-4861-9961-de414cf8d08b under 3075b1693bff8da60555d090ff5123dc at the SlotManager.
> 20846 [flink-akka.actor.default-dispatcher-4] INFO  org.apache.flink.runtime.dispatcher.StandaloneDispatcher  - Received JobGraph submission 10916cea5ecc0ea53989d755e8699478 (Blocking test job).
> 20846 [flink-akka.actor.default-dispatcher-4] INFO  org.apache.flink.runtime.dispatcher.StandaloneDispatcher  - Submitting job 10916cea5ecc0ea53989d755e8699478 (Blocking test job).
> 20846 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl  - Registering TaskManager 30248eb7-9288-488b-874a-204845181b60 under 2407f57c0c14584af2107ae72ea04867 at the SlotManager.
> 20846 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Starting RPC endpoint for org.apache.flink.runtime.jobmaster.JobMaster at akka://flink/user/jobmanager_287 .
> 20846 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Initializing job Blocking test job (10916cea5ecc0ea53989d755e8699478).
> 20846 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Using restart back off time strategy NoRestartBackoffTimeStrategy for Blocking test job (10916cea5ecc0ea53989d755e8699478).
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Running initialization on master for job Blocking test job (10916cea5ecc0ea53989d755e8699478).
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Successfully ran initialization on master in 0 ms.
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.jobmaster.JobMaster  - Adding 1 vertices from job graph Blocking test job (10916cea5ecc0ea53989d755e8699478).
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.executiongraph.ExecutionGraph  - Attaching 1 topologically sorted vertices to existing job graph with 0 vertices and 0 intermediate results.
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.executiongraph.ExecutionGraph  - Connecting ExecutionJobVertex 36153b5f02971ac3141ec6a366a00464 (blocking operator) to 0 predecessors.
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.jobmaster.JobMaster  - Successfully created execution graph from job graph Blocking test job (10916cea5ecc0ea53989d755e8699478).
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy  - Start building failover regions.
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy  - Creating a failover region with 1 vertices.
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy  - Creating a failover region with 1 vertices.
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy  - Creating a failover region with 1 vertices.
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy  - Creating a failover region with 1 vertices.
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy  - Created 4 failover regions.
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Using failover strategy org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy@4a0a5390 for Blocking test job (10916cea5ecc0ea53989d755e8699478).
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService  - Proposing leadership to contender akka://flink/user/jobmanager_287
> 20847 [pool-1-thread-1] INFO  org.apache.flink.runtime.jobmaster.JobManagerRunnerImpl  - JobManager runner for job Blocking test job (10916cea5ecc0ea53989d755e8699478) was granted leadership with session id 39ab559a-76e6-408e-9da0-f411625eeda5 at akka://flink/user/jobmanager_287.
> 20847 [Time-limited test] INFO  org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService  - Revoking leadership of org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunner@4cfbe5ca.
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Starting execution of job Blocking test job (10916cea5ecc0ea53989d755e8699478) under job master id 9da0f411625eeda539ab559a76e6408e.
> 20847 [pool-1-thread-1] INFO  org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess  - Stopping SessionDispatcherLeaderProcess.
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Starting scheduling with scheduling strategy [org.apache.flink.runtime.scheduler.strategy.LazyFromSourcesSchedulingStrategy]
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - Job Blocking test job (10916cea5ecc0ea53989d755e8699478) switched from state CREATED to RUNNING.
> 20847 [flink-akka.actor.default-dispatcher-2] INFO  org.apache.flink.runtime.dispatcher.StandaloneDispatcher  - Stopping dispatcher akka://flink/user/dispatcherd5f8446f-b44d-4bcd-88b3-65105c1c6ca0.
> 20847 [flink-akka.actor.default-dispatcher-2] INFO  org.apache.flink.runtime.dispatcher.StandaloneDispatcher  - Stopping all currently running jobs of dispatcher akka://flink/user/dispatcherd5f8446f-b44d-4bcd-88b3-65105c1c6ca0.
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - blocking operator (1/4) (daeaeda48899ddb597bf2249739d21a2) switched from CREATED to SCHEDULED.
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - blocking operator (2/4) (eca90f0e31fe3e10041541b602d07a07) switched from CREATED to SCHEDULED.
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - blocking operator (3/4) (411f597cd777705a3199770a2d0a826b) switched from CREATED to SCHEDULED.
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - blocking operator (4/4) (93d481fc25c6b31bac3804298a5aaae2) switched from CREATED to SCHEDULED.
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.scheduler.DefaultExecutionSlotAllocator  - Allocate slot with id SlotRequestId{4f37fb217e29615eb4d23a5c8d0d35da} for execution 36153b5f02971ac3141ec6a366a00464_0
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl  - Received slot request [SlotRequestId{4f37fb217e29615eb4d23a5c8d0d35da}] for task: null
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl  - Cannot serve slot request, no ResourceManager connected. Adding as pending request [SlotRequestId{4f37fb217e29615eb4d23a5c8d0d35da}]
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.scheduler.DefaultExecutionSlotAllocator  - Allocate slot with id SlotRequestId{82ae5d4df5fe6fa591e7e62f3eed0027} for execution 36153b5f02971ac3141ec6a366a00464_1
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl  - Received slot request [SlotRequestId{82ae5d4df5fe6fa591e7e62f3eed0027}] for task: null
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl  - Cannot serve slot request, no ResourceManager connected. Adding as pending request [SlotRequestId{82ae5d4df5fe6fa591e7e62f3eed0027}]
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.scheduler.DefaultExecutionSlotAllocator  - Allocate slot with id SlotRequestId{5bc58f32a012441c51111596eb51365c} for execution 36153b5f02971ac3141ec6a366a00464_2
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl  - Received slot request [SlotRequestId{5bc58f32a012441c51111596eb51365c}] for task: null
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl  - Cannot serve slot request, no ResourceManager connected. Adding as pending request [SlotRequestId{5bc58f32a012441c51111596eb51365c}]
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.scheduler.DefaultExecutionSlotAllocator  - Allocate slot with id SlotRequestId{e0647296e4d35e129acb9c5bb6c08b5c} for execution 36153b5f02971ac3141ec6a366a00464_3
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl  - Received slot request [SlotRequestId{e0647296e4d35e129acb9c5bb6c08b5c}] for task: null
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl  - Cannot serve slot request, no ResourceManager connected. Adding as pending request [SlotRequestId{e0647296e4d35e129acb9c5bb6c08b5c}]
> 20847 [jobmanager-future-thread-1] INFO  org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService  - Received confirmation of leadership for leader akka://flink/user/jobmanager_287 , session=39ab559a-76e6-408e-9da0-f411625eeda5
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.jobmaster.JobMaster  - Trigger heartbeat request.
> 20847 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Connecting to ResourceManager akka://flink/user/resourcemanager9fa41f3a-7bd4-4f72-ae07-76b75499c88d(addd3d7aa17fd083e73f31a7c45f4328)
> 20847 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Try to connect to remote RPC endpoint with address akka://flink/user/resourcemanager9fa41f3a-7bd4-4f72-ae07-76b75499c88d. Returning a org.apache.flink.runtime.resourcemanager.ResourceManagerGateway gateway.
> 20848 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Stopping the JobMaster for job Blocking test job(10916cea5ecc0ea53989d755e8699478).
> 20848 [flink-akka.actor.default-dispatcher-2] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Resolved ResourceManager address, beginning registration
> 20848 [flink-akka.actor.default-dispatcher-2] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Registration at ResourceManager attempt 1 (timeout=100ms)
> 20848 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - Job Blocking test job (10916cea5ecc0ea53989d755e8699478) switched from state RUNNING to SUSPENDED.
> org.apache.flink.util.FlinkException: JobManager is shutting down.
> 	at org.apache.flink.runtime.jobmaster.JobMaster.onStop(JobMaster.java:350)
> 	at org.apache.flink.runtime.rpc.RpcEndpoint.internalCallOnStop(RpcEndpoint.java:218)
> 	at org.apache.flink.runtime.rpc.akka.AkkaRpcActor$StartedState.terminate(AkkaRpcActor.java:509)
> 	at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleControlMessage(AkkaRpcActor.java:175)
> 	at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:26)
> 	at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:21)
> 	at scala.PartialFunction$class.applyOrElse(PartialFunction.scala:123)
> 	at akka.japi.pf.UnitCaseStatement.applyOrElse(CaseStatements.scala:21)
> 	at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:170)
> 	at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:171)
> 	at akka.actor.Actor$class.aroundReceive(Actor.scala:517)
> 	at akka.actor.AbstractActor.aroundReceive(AbstractActor.scala:225)
> 	at akka.actor.ActorCell.receiveMessage(ActorCell.scala:592)
> 	at akka.actor.ActorCell.invoke(ActorCell.scala:561)
> 	at akka.dispatch.Mailbox.processMailbox(Mailbox.scala:258)
> 	at akka.dispatch.Mailbox.run(Mailbox.scala:225)
> 	at akka.dispatch.Mailbox.exec(Mailbox.scala:235)
> 	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)
> 20848 [flink-akka.actor.default-dispatcher-2] DEBUG org.apache.flink.runtime.resourcemanager.JobLeaderIdService  - Add job 10916cea5ecc0ea53989d755e8699478 to job leader id monitoring.
> 20848 [flink-akka.actor.default-dispatcher-2] INFO  org.apache.flink.runtime.resourcemanager.StandaloneResourceManager  - Registering job manager 9da0f411625eeda539ab559a76e6408e@akka://flink/user/jobmanager_287 for job 10916cea5ecc0ea53989d755e8699478.
> 20848 [pool-1-thread-1] DEBUG org.apache.flink.runtime.resourcemanager.JobLeaderIdService  - Found a new job leader 39ab559a-76e6-408e-9da0-f411625eeda5@akka://flink/user/jobmanager_287.
> 20848 [flink-akka.actor.default-dispatcher-2] DEBUG org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Try to connect to remote RPC endpoint with address akka://flink/user/jobmanager_287. Returning a org.apache.flink.runtime.jobmaster.JobMasterGateway gateway.
> 20848 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - blocking operator (1/4) (daeaeda48899ddb597bf2249739d21a2) switched from SCHEDULED to CANCELING.
> 20848 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - blocking operator (1/4) (daeaeda48899ddb597bf2249739d21a2) switched from CANCELING to CANCELED.
> 20848 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - Discarding the results produced by task execution daeaeda48899ddb597bf2249739d21a2.
> 20848 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - blocking operator (2/4) (eca90f0e31fe3e10041541b602d07a07) switched from SCHEDULED to CANCELING.
> 20848 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - blocking operator (2/4) (eca90f0e31fe3e10041541b602d07a07) switched from CANCELING to CANCELED.
> 20848 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - Discarding the results produced by task execution eca90f0e31fe3e10041541b602d07a07.
> 20848 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - blocking operator (3/4) (411f597cd777705a3199770a2d0a826b) switched from SCHEDULED to CANCELING.
> 20848 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - blocking operator (3/4) (411f597cd777705a3199770a2d0a826b) switched from CANCELING to CANCELED.
> 20848 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - Discarding the results produced by task execution 411f597cd777705a3199770a2d0a826b.
> 20848 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - blocking operator (4/4) (93d481fc25c6b31bac3804298a5aaae2) switched from SCHEDULED to CANCELING.
> 20848 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - blocking operator (4/4) (93d481fc25c6b31bac3804298a5aaae2) switched from CANCELING to CANCELED.
> 20848 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - Discarding the results produced by task execution 93d481fc25c6b31bac3804298a5aaae2.
> 20848 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - Job 10916cea5ecc0ea53989d755e8699478 has been suspended.
> 20848 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl  - Suspending SlotPool.
> 20848 [jobmanager-future-thread-1] DEBUG org.apache.flink.runtime.jobmaster.JobMaster  - Retrying registration towards akka://flink/user/resourcemanager9fa41f3a-7bd4-4f72-ae07-76b75499c88d was cancelled.
> 20848 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl  - Stopping SlotPool.
> 20848 [pool-1-thread-1] DEBUG org.apache.flink.runtime.resourcemanager.JobLeaderIdService  - Found a new job leader null@null.
> 20848 [flink-akka.actor.default-dispatcher-4] DEBUG org.apache.flink.runtime.resourcemanager.StandaloneResourceManager  - Discard job leader lost leadership for outdated leader 9da0f411625eeda539ab559a76e6408e for job 10916cea5ecc0ea53989d755e8699478.
> 20848 [flink-akka.actor.default-dispatcher-4] DEBUG org.apache.flink.runtime.dispatcher.StandaloneDispatcher  - There is a newer JobManagerRunner for the job 10916cea5ecc0ea53989d755e8699478.
> 20848 [Time-limited test] INFO  org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService  - Proposing leadership to contender LeaderContender: DefaultDispatcherRunner
> 20848 [pool-1-thread-1] DEBUG org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunner  - Create new DispatcherLeaderProcess with leader session id 73495bcd-e324-4d15-8b41-863bfb3cfbdc.
> 20848 [flink-akka.actor.default-dispatcher-2] INFO  org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureRequestCoordinator  - Shutting down back pressure request coordinator.
> 20848 [flink-akka.actor.default-dispatcher-2] INFO  org.apache.flink.runtime.dispatcher.StandaloneDispatcher  - Stopped dispatcher akka://flink/user/dispatcherd5f8446f-b44d-4bcd-88b3-65105c1c6ca0.
> 20848 [flink-akka.actor.default-dispatcher-4] DEBUG org.apache.flink.runtime.resourcemanager.StandaloneResourceManager  - Registration of job manager 9da0f411625eeda539ab559a76e6408e@akka://flink/user/jobmanager_287 failed.
> java.util.concurrent.CompletionException: org.apache.flink.runtime.rpc.exceptions.RpcConnectionException: Could not connect to rpc endpoint under address akka://flink/user/jobmanager_287.
> 	at org.apache.flink.runtime.rpc.akka.AkkaRpcService.lambda$connectInternal$6(AkkaRpcService.java:452)
> 	at java.base/java.util.concurrent.CompletableFuture$UniApply.tryFire(CompletableFuture.java:642)
> 	at java.base/java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:506)
> 	at java.base/java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:2073)
> 	at org.apache.flink.runtime.concurrent.FutureUtils$1.onComplete(FutureUtils.java:874)
> 	at akka.dispatch.OnComplete.internal(Future.scala:264)
> 	at akka.dispatch.OnComplete.internal(Future.scala:261)
> 	at akka.dispatch.japi$CallbackBridge.apply(Future.scala:191)
> 	at akka.dispatch.japi$CallbackBridge.apply(Future.scala:188)
> 	at scala.concurrent.impl.CallbackRunnable.run(Promise.scala:36)
> 	at org.apache.flink.runtime.concurrent.Executors$DirectExecutionContext.execute(Executors.java:74)
> 	at scala.concurrent.impl.CallbackRunnable.executeWithValue(Promise.scala:44)
> 	at scala.concurrent.impl.Promise$DefaultPromise.tryComplete(Promise.scala:252)
> 	at scala.concurrent.Promise$class.complete(Promise.scala:55)
> 	at scala.concurrent.impl.Promise$DefaultPromise.complete(Promise.scala:157)
> 	at scala.concurrent.Future$$anonfun$map$1.apply(Future.scala:237)
> 	at scala.concurrent.Future$$anonfun$map$1.apply(Future.scala:237)
> 	at scala.concurrent.impl.CallbackRunnable.run(Promise.scala:36)
> 	at scala.concurrent.BatchingExecutor$Batch$$anonfun$run$1.processBatch$1(BatchingExecutor.scala:63)
> 	at scala.concurrent.BatchingExecutor$Batch$$anonfun$run$1.apply$mcV$sp(BatchingExecutor.scala:78)
> 	at scala.concurrent.BatchingExecutor$Batch$$anonfun$run$1.apply(BatchingExecutor.scala:55)
> 	at scala.concurrent.BatchingExecutor$Batch$$anonfun$run$1.apply(BatchingExecutor.scala:55)
> 	at scala.concurrent.BlockContext$.withBlockContext(BlockContext.scala:72)
> 	at scala.concurrent.BatchingExecutor$Batch.run(BatchingExecutor.scala:54)
> 	at scala.concurrent.Future$InternalCallbackExecutor$.unbatchedExecute(Future.scala:601)
> 	at scala.concurrent.BatchingExecutor$class.execute(BatchingExecutor.scala:106)
> 	at scala.concurrent.Future$InternalCallbackExecutor$.execute(Future.scala:599)
> 	at scala.concurrent.impl.CallbackRunnable.executeWithValue(Promise.scala:44)
> 	at scala.concurrent.impl.Promise$DefaultPromise.tryComplete(Promise.scala:252)
> 	at akka.pattern.PromiseActorRef.$bang(AskSupport.scala:572)
> 	at akka.actor.EmptyLocalActorRef.specialHandle(ActorRef.scala:551)
> 	at akka.actor.DeadLetterActorRef.specialHandle(ActorRef.scala:593)
> 	at akka.actor.DeadLetterActorRef.$bang(ActorRef.scala:582)
> 	at akka.actor.ActorRef.tell(ActorRef.scala:126)
> 	at akka.dispatch.Mailboxes$$anon$1$$anon$2.enqueue(Mailboxes.scala:36)
> 	at akka.dispatch.QueueBasedMessageQueue$class.cleanUp(Mailbox.scala:487)
> 	at akka.dispatch.UnboundedMailbox$MessageQueue.cleanUp(Mailbox.scala:616)
> 	at akka.dispatch.Mailbox.cleanUp(Mailbox.scala:330)
> 	at akka.dispatch.MessageDispatcher.unregister(AbstractDispatcher.scala:210)
> 	at akka.dispatch.MessageDispatcher.detach(AbstractDispatcher.scala:140)
> 	at akka.actor.dungeon.FaultHandling$class.akka$actor$dungeon$FaultHandling$$finishTerminate(FaultHandling.scala:212)
> 	at akka.actor.dungeon.FaultHandling$class.terminate(FaultHandling.scala:172)
> 	at akka.actor.ActorCell.terminate(ActorCell.scala:429)
> 	at akka.actor.ActorCell.invokeAll$1(ActorCell.scala:533)
> 	at akka.actor.ActorCell.systemInvoke(ActorCell.scala:549)
> 	at akka.dispatch.Mailbox.processAllSystemMessages(Mailbox.scala:283)
> 	at akka.dispatch.Mailbox.processMailbox(Mailbox.scala:261)
> 	at akka.dispatch.Mailbox.run(Mailbox.scala:225)
> 	at akka.dispatch.Mailbox.exec(Mailbox.scala:235)
> 	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)
> Caused by: org.apache.flink.runtime.rpc.exceptions.RpcConnectionException: Could not connect to rpc endpoint under address akka://flink/user/jobmanager_287.
> 	... 53 more
> 20848 [mini-cluster-io-thread-2] INFO  org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess  - Start SessionDispatcherLeaderProcess.
> 20849 [mini-cluster-io-thread-3] INFO  org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess  - Recover all persisted job graphs.
> 20849 [mini-cluster-io-thread-3] INFO  org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess  - Successfully recovered 0 persisted job graphs.
> 20849 [mini-cluster-io-thread-3] INFO  org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Starting RPC endpoint for org.apache.flink.runtime.dispatcher.StandaloneDispatcher at akka://flink/user/dispatcher8411eb0e-aa2f-41c7-96f1-ffa17a27da03 .
> 20849 [mini-cluster-io-thread-3] INFO  org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService  - Received confirmation of leadership for leader akka://flink/user/dispatcher8411eb0e-aa2f-41c7-96f1-ffa17a27da03 , session=73495bcd-e324-4d15-8b41-863bfb3cfbdc
> 20849 [pool-1-thread-1] DEBUG org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Try to connect to remote RPC endpoint with address akka://flink/user/dispatcher8411eb0e-aa2f-41c7-96f1-ffa17a27da03. Returning a org.apache.flink.runtime.dispatcher.DispatcherGateway gateway.
> 20849 [pool-1-thread-1] DEBUG org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Try to connect to remote RPC endpoint with address akka://flink/user/dispatcher8411eb0e-aa2f-41c7-96f1-ffa17a27da03. Returning a org.apache.flink.runtime.dispatcher.DispatcherGateway gateway.
> 20849 [pool-1-thread-1] DEBUG org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Try to connect to remote RPC endpoint with address akka://flink/user/dispatcher8411eb0e-aa2f-41c7-96f1-ffa17a27da03. Returning a org.apache.flink.runtime.dispatcher.DispatcherGateway gateway.
> 20849 [pool-1-thread-1] DEBUG org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Try to connect to remote RPC endpoint with address akka://flink/user/dispatcher8411eb0e-aa2f-41c7-96f1-ffa17a27da03. Returning a org.apache.flink.runtime.dispatcher.DispatcherGateway gateway.
> 20849 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.dispatcher.StandaloneDispatcher  - Received JobGraph submission 10916cea5ecc0ea53989d755e8699478 (Blocking test job).
> 20849 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.dispatcher.StandaloneDispatcher  - Submitting job 10916cea5ecc0ea53989d755e8699478 (Blocking test job).
> 20850 [flink-akka.actor.default-dispatcher-5] INFO  org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Starting RPC endpoint for org.apache.flink.runtime.jobmaster.JobMaster at akka://flink/user/jobmanager_288 .
> 20850 [flink-akka.actor.default-dispatcher-5] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Initializing job Blocking test job (10916cea5ecc0ea53989d755e8699478).
> 20850 [flink-akka.actor.default-dispatcher-5] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Using restart back off time strategy NoRestartBackoffTimeStrategy for Blocking test job (10916cea5ecc0ea53989d755e8699478).
> 20850 [flink-akka.actor.default-dispatcher-5] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Running initialization on master for job Blocking test job (10916cea5ecc0ea53989d755e8699478).
> 20850 [flink-akka.actor.default-dispatcher-5] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Successfully ran initialization on master in 0 ms.
> 20850 [flink-akka.actor.default-dispatcher-5] DEBUG org.apache.flink.runtime.jobmaster.JobMaster  - Adding 1 vertices from job graph Blocking test job (10916cea5ecc0ea53989d755e8699478).
> 20850 [flink-akka.actor.default-dispatcher-5] DEBUG org.apache.flink.runtime.executiongraph.ExecutionGraph  - Attaching 1 topologically sorted vertices to existing job graph with 0 vertices and 0 intermediate results.
> 20850 [flink-akka.actor.default-dispatcher-5] DEBUG org.apache.flink.runtime.executiongraph.ExecutionGraph  - Connecting ExecutionJobVertex 36153b5f02971ac3141ec6a366a00464 (blocking operator) to 0 predecessors.
> 20850 [flink-akka.actor.default-dispatcher-5] DEBUG org.apache.flink.runtime.jobmaster.JobMaster  - Successfully created execution graph from job graph Blocking test job (10916cea5ecc0ea53989d755e8699478).
> 20850 [flink-akka.actor.default-dispatcher-5] INFO  org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy  - Start building failover regions.
> 20850 [flink-akka.actor.default-dispatcher-5] DEBUG org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy  - Creating a failover region with 1 vertices.
> 20850 [flink-akka.actor.default-dispatcher-5] DEBUG org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy  - Creating a failover region with 1 vertices.
> 20850 [flink-akka.actor.default-dispatcher-5] DEBUG org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy  - Creating a failover region with 1 vertices.
> 20850 [flink-akka.actor.default-dispatcher-5] DEBUG org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy  - Creating a failover region with 1 vertices.
> 20850 [flink-akka.actor.default-dispatcher-5] INFO  org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy  - Created 4 failover regions.
> 20850 [flink-akka.actor.default-dispatcher-5] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Using failover strategy org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy@278dfbf for Blocking test job (10916cea5ecc0ea53989d755e8699478).
> 20850 [flink-akka.actor.default-dispatcher-5] INFO  org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService  - Proposing leadership to contender akka://flink/user/jobmanager_288
> 20850 [pool-1-thread-1] INFO  org.apache.flink.runtime.jobmaster.JobManagerRunnerImpl  - JobManager runner for job Blocking test job (10916cea5ecc0ea53989d755e8699478) was granted leadership with session id feafc884-4fbd-49e0-b35a-21d553ed03da at akka://flink/user/jobmanager_288.
> 20850 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Starting execution of job Blocking test job (10916cea5ecc0ea53989d755e8699478) under job master id b35a21d553ed03dafeafc8844fbd49e0.
> 20850 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Starting scheduling with scheduling strategy [org.apache.flink.runtime.scheduler.strategy.LazyFromSourcesSchedulingStrategy]
> 20850 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - Job Blocking test job (10916cea5ecc0ea53989d755e8699478) switched from state CREATED to RUNNING.
> 20850 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - blocking operator (1/4) (da2cc6b05eb054ba81678a2d47c2ad1a) switched from CREATED to SCHEDULED.
> 20850 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - blocking operator (2/4) (dd6940b933e1b6373ee014cec8e7cbe9) switched from CREATED to SCHEDULED.
> 20851 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - blocking operator (3/4) (20f73631beab206c03673a81d520638e) switched from CREATED to SCHEDULED.
> 20851 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph  - blocking operator (4/4) (bd0fbc82bd04edcdeeae48ac85259cef) switched from CREATED to SCHEDULED.
> 20851 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.scheduler.DefaultExecutionSlotAllocator  - Allocate slot with id SlotRequestId{b8ff29fdfdb95ee6656d681fac7ce8fa} for execution 36153b5f02971ac3141ec6a366a00464_0
> 20851 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl  - Received slot request [SlotRequestId{b8ff29fdfdb95ee6656d681fac7ce8fa}] for task: null
> 20851 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl  - Cannot serve slot request, no ResourceManager connected. Adding as pending request [SlotRequestId{b8ff29fdfdb95ee6656d681fac7ce8fa}]
> 20851 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.scheduler.DefaultExecutionSlotAllocator  - Allocate slot with id SlotRequestId{dbcbd0676ca49c8fea8f4532c34eeffd} for execution 36153b5f02971ac3141ec6a366a00464_1
> 20851 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl  - Received slot request [SlotRequestId{dbcbd0676ca49c8fea8f4532c34eeffd}] for task: null
> 20851 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl  - Cannot serve slot request, no ResourceManager connected. Adding as pending request [SlotRequestId{dbcbd0676ca49c8fea8f4532c34eeffd}]
> 20851 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.scheduler.DefaultExecutionSlotAllocator  - Allocate slot with id SlotRequestId{d12f5bb630b6295e60ac962e5eeda235} for execution 36153b5f02971ac3141ec6a366a00464_2
> 20851 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl  - Received slot request [SlotRequestId{d12f5bb630b6295e60ac962e5eeda235}] for task: null
> 20851 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl  - Cannot serve slot request, no ResourceManager connected. Adding as pending request [SlotRequestId{d12f5bb630b6295e60ac962e5eeda235}]
> 20851 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.scheduler.DefaultExecutionSlotAllocator  - Allocate slot with id SlotRequestId{8e00d9199f13765ccf4f23ea98523da4} for execution 36153b5f02971ac3141ec6a366a00464_3
> 20851 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl  - Received slot request [SlotRequestId{8e00d9199f13765ccf4f23ea98523da4}] for task: null
> 20851 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl  - Cannot serve slot request, no ResourceManager connected. Adding as pending request [SlotRequestId{8e00d9199f13765ccf4f23ea98523da4}]
> 20851 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.jobmaster.JobMaster  - Trigger heartbeat request.
> 20851 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Connecting to ResourceManager akka://flink/user/resourcemanager9fa41f3a-7bd4-4f72-ae07-76b75499c88d(addd3d7aa17fd083e73f31a7c45f4328)
> 20851 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Try to connect to remote RPC endpoint with address akka://flink/user/resourcemanager9fa41f3a-7bd4-4f72-ae07-76b75499c88d. Returning a org.apache.flink.runtime.resourcemanager.ResourceManagerGateway gateway.
> 20851 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Resolved ResourceManager address, beginning registration
> 20851 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Registration at ResourceManager attempt 1 (timeout=100ms)
> 20851 [flink-akka.actor.default-dispatcher-3] INFO  org.apache.flink.runtime.resourcemanager.StandaloneResourceManager  - Registering job manager b35a21d553ed03dafeafc8844fbd49e0@akka://flink/user/jobmanager_288 for job 10916cea5ecc0ea53989d755e8699478.
> 20851 [flink-akka.actor.default-dispatcher-3] DEBUG org.apache.flink.runtime.rpc.akka.AkkaRpcService  - Try to connect to remote RPC endpoint with address akka://flink/user/jobmanager_288. Returning a org.apache.flink.runtime.jobmaster.JobMasterGateway gateway.
> 20851 [jobmanager-future-thread-2] INFO  org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService  - Received confirmation of leadership for leader akka://flink/user/jobmanager_288 , session=feafc884-4fbd-49e0-b35a-21d553ed03da
> 20851 [pool-1-thread-1] DEBUG org.apache.flink.runtime.resourcemanager.JobLeaderIdService  - Found a new job leader feafc884-4fbd-49e0-b35a-21d553ed03da@akka://flink/user/jobmanager_288.
> 20851 [flink-akka.actor.default-dispatcher-4] DEBUG org.apache.flink.runtime.resourcemanager.StandaloneResourceManager  - The leading JobMaster id null did not match the received JobMaster id b35a21d553ed03dafeafc8844fbd49e0. This indicates that a JobMaster leader change has happened.
> 20851 [flink-akka.actor.default-dispatcher-4] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Registration at ResourceManager was declined: The leading JobMaster id null did not match the received JobMaster id b35a21d553ed03dafeafc8844fbd49e0. This indicates that a JobMaster leader change has happened.
> 20851 [flink-akka.actor.default-dispatcher-4] INFO  org.apache.flink.runtime.jobmaster.JobMaster  - Pausing and re-attempting registration in 30000 ms
> {code}
>  
> FYI [~trohrmann]



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