You are viewing a plain text version of this content. The canonical link for it is here.
Posted to builds@beam.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2020/10/04 16:09:40 UTC

beam_PostCommit_Java_Nexmark_Flink - Build # 6302 - Aborted!

beam_PostCommit_Java_Nexmark_Flink - Build # 6302 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Java_Nexmark_Flink/6302/ to view the results.

Jenkins build is back to normal : beam_PostCommit_Java_Nexmark_Flink #6315

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Java_Nexmark_Flink/6315/display/redirect?page=changes>


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


beam_PostCommit_Java_Nexmark_Flink - Build # 6314 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Java_Nexmark_Flink - Build # 6314 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Java_Nexmark_Flink/6314/ to view the results.

beam_PostCommit_Java_Nexmark_Flink - Build # 6313 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Java_Nexmark_Flink - Build # 6313 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Java_Nexmark_Flink/6313/ to view the results.

beam_PostCommit_Java_Nexmark_Flink - Build # 6312 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Java_Nexmark_Flink - Build # 6312 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Java_Nexmark_Flink/6312/ to view the results.

Build failed in Jenkins: beam_PostCommit_Java_Nexmark_Flink #6311

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Java_Nexmark_Flink/6311/display/redirect?page=changes>

Changes:

[noreply] Update Dataflow Python container to beam-master-20201005 (#13011)


------------------------------------------
[...truncated 43.15 MB...]
	at org.apache.beam.runners.flink.FlinkRunner.run(FlinkRunner.java:89)
	at org.apache.beam.sdk.Pipeline.run(Pipeline.java:317)
	at org.apache.beam.sdk.Pipeline.run(Pipeline.java:303)
	at org.apache.beam.sdk.nexmark.NexmarkLauncher.run(NexmarkLauncher.java:1213)
	at org.apache.beam.sdk.nexmark.Main$Run.call(Main.java:96)
	at org.apache.beam.sdk.nexmark.Main$Run.call(Main.java:85)
	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
	at java.lang.Thread.run(Thread.java:748)
Caused by: org.apache.flink.runtime.client.JobExecutionException: Job execution failed.
	at org.apache.flink.runtime.jobmaster.JobResult.toJobExecutionResult(JobResult.java:147)
	at org.apache.flink.client.program.PerJobMiniClusterFactory$PerJobMiniClusterJobClient.lambda$getJobExecutionResult$2(PerJobMiniClusterFactory.java:175)
	at java.util.concurrent.CompletableFuture.uniApply(CompletableFuture.java:616)
	at java.util.concurrent.CompletableFuture$UniApply.tryFire(CompletableFuture.java:591)
	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
	at java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:1975)
	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 akka.pattern.PromiseActorRef.$bang(AskSupport.scala:572)
	at akka.pattern.PipeToSupport$PipeableFuture$$anonfun$pipeTo$1.applyOrElse(PipeToSupport.scala:22)
	at akka.pattern.PipeToSupport$PipeableFuture$$anonfun$pipeTo$1.applyOrElse(PipeToSupport.scala:21)
	at scala.concurrent.Future$$anonfun$andThen$1.apply(Future.scala:436)
	at scala.concurrent.Future$$anonfun$andThen$1.apply(Future.scala:435)
	at scala.concurrent.impl.CallbackRunnable.run(Promise.scala:36)
	at akka.dispatch.BatchingExecutor$AbstractBatch.processBatch(BatchingExecutor.scala:55)
	at akka.dispatch.BatchingExecutor$BlockableBatch$$anonfun$run$1.apply$mcV$sp(BatchingExecutor.scala:91)
	at akka.dispatch.BatchingExecutor$BlockableBatch$$anonfun$run$1.apply(BatchingExecutor.scala:91)
	at akka.dispatch.BatchingExecutor$BlockableBatch$$anonfun$run$1.apply(BatchingExecutor.scala:91)
	at scala.concurrent.BlockContext$.withBlockContext(BlockContext.scala:72)
	at akka.dispatch.BatchingExecutor$BlockableBatch.run(BatchingExecutor.scala:90)
	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)
Caused by: org.apache.flink.runtime.JobException: Recovery is suppressed by NoRestartBackoffTimeStrategy
	at org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.handleFailure(ExecutionFailureHandler.java:110)
	at org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.getFailureHandlingResult(ExecutionFailureHandler.java:76)
	at org.apache.flink.runtime.scheduler.DefaultScheduler.handleTaskFailure(DefaultScheduler.java:192)
	at org.apache.flink.runtime.scheduler.DefaultScheduler.maybeHandleTaskFailure(DefaultScheduler.java:186)
	at org.apache.flink.runtime.scheduler.DefaultScheduler.updateTaskExecutionStateInternal(DefaultScheduler.java:180)
	at org.apache.flink.runtime.scheduler.SchedulerBase.updateTaskExecutionState(SchedulerBase.java:496)
	at org.apache.flink.runtime.jobmaster.JobMaster.updateTaskExecutionState(JobMaster.java:380)
	at sun.reflect.GeneratedMethodAccessor35.invoke(Unknown Source)
	at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
	at java.lang.reflect.Method.invoke(Method.java:498)
	at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcInvocation(AkkaRpcActor.java:284)
	at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcMessage(AkkaRpcActor.java:199)
	at org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor.handleRpcMessage(FencedAkkaRpcActor.java:74)
	at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleMessage(AkkaRpcActor.java:152)
	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 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)
	... 4 more
Caused by: org.apache.flink.streaming.runtime.tasks.AsynchronousException: Caught exception while processing timer.
	at org.apache.flink.streaming.runtime.tasks.StreamTask$StreamTaskAsyncExceptionHandler.handleAsyncException(StreamTask.java:1073)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.handleAsyncException(StreamTask.java:1041)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.invokeProcessingTimeCallback(StreamTask.java:1503)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.lambda$null$10(StreamTask.java:1492)
	at org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor$SynchronizedStreamTaskActionExecutor.run(StreamTaskActionExecutor.java:87)
	at org.apache.flink.streaming.runtime.tasks.mailbox.Mail.run(Mail.java:78)
	at org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.processMail(MailboxProcessor.java:261)
	at org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMailboxLoop(MailboxProcessor.java:186)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.runMailboxLoop(StreamTask.java:485)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:469)
	at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:708)
	at org.apache.flink.runtime.taskmanager.Task.run(Task.java:533)
	at java.lang.Thread.run(Thread.java:748)
Caused by: TimerException{org.apache.beam.sdk.util.UserCodeException: java.lang.NullPointerException}
	... 11 more
Caused by: org.apache.beam.sdk.util.UserCodeException: java.lang.NullPointerException
	at org.apache.beam.sdk.util.UserCodeException.wrap(UserCodeException.java:36)
	at org.apache.beam.sdk.io.Read$UnboundedSourceAsSDFWrapperFn$DoFnInvoker.invokeNewWatermarkEstimator(Unknown Source)
	at org.apache.beam.runners.core.SplittableParDoViaKeyedWorkItems$ProcessFn.processElement(SplittableParDoViaKeyedWorkItems.java:439)
	at org.apache.beam.runners.core.SplittableParDoViaKeyedWorkItems$ProcessFn$DoFnInvoker.invokeProcessElement(Unknown Source)
	at org.apache.beam.runners.core.SimpleDoFnRunner.invokeProcessElement(SimpleDoFnRunner.java:227)
	at org.apache.beam.runners.core.SimpleDoFnRunner.processElement(SimpleDoFnRunner.java:183)
	at org.apache.beam.runners.flink.metrics.DoFnRunnerWithMetricsUpdate.processElement(DoFnRunnerWithMetricsUpdate.java:62)
	at org.apache.beam.runners.flink.translation.wrappers.streaming.SplittableDoFnOperator.fireTimer(SplittableDoFnOperator.java:171)
	at org.apache.beam.runners.flink.translation.wrappers.streaming.DoFnOperator.fireTimerInternal(DoFnOperator.java:984)
	at org.apache.beam.runners.flink.translation.wrappers.streaming.DoFnOperator.onProcessingTime(DoFnOperator.java:979)
	at org.apache.flink.streaming.api.operators.InternalTimerServiceImpl.onProcessingTime(InternalTimerServiceImpl.java:260)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.invokeProcessingTimeCallback(StreamTask.java:1501)
	... 10 more
Caused by: java.lang.NullPointerException

Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:3, state:ACTIVE, resource profile: ResourceProfile{managedMemory=8.000mb (8388608 bytes), networkMemory=4.000mb (4194304 bytes)}, allocationId: a2c100590747d72a9241b6b8dd881424, jobId: d448a43197f239503e0edade359d5267).
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.jobmaster.JobMaster onStop
INFO: Stopping the JobMaster for job main-jenkins-1006181149-9c79ae81(d448a43197f239503e0edade359d5267).
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:6, state:ACTIVE, resource profile: ResourceProfile{managedMemory=8.000mb (8388608 bytes), networkMemory=4.000mb (4194304 bytes)}, allocationId: a6b90dd766ee3c5863cafecba68e89f4, jobId: d448a43197f239503e0edade359d5267).
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:9, state:ACTIVE, resource profile: ResourceProfile{managedMemory=8.000mb (8388608 bytes), networkMemory=4.000mb (4194304 bytes)}, allocationId: 61f5c4745b033e2d67e97f1efc728609, jobId: d448a43197f239503e0edade359d5267).
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:5, state:ACTIVE, resource profile: ResourceProfile{managedMemory=8.000mb (8388608 bytes), networkMemory=4.000mb (4194304 bytes)}, allocationId: 7479d5f108804fac83049f9eea81bdfb, jobId: d448a43197f239503e0edade359d5267).
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl suspend
INFO: Suspending SlotPool.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.jobmaster.JobMaster dissolveResourceManagerConnection
INFO: Close ResourceManager connection 99c445d25f3a8fbe89a9b0b6a935b8c0: JobManager is shutting down..
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:7, state:ACTIVE, resource profile: ResourceProfile{managedMemory=8.000mb (8388608 bytes), networkMemory=4.000mb (4194304 bytes)}, allocationId: 37e60e6990ebadb7dd214d87ebf0bf69, jobId: d448a43197f239503e0edade359d5267).
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl close
INFO: Stopping SlotPool.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:13, state:ACTIVE, resource profile: ResourceProfile{managedMemory=8.000mb (8388608 bytes), networkMemory=4.000mb (4194304 bytes)}, allocationId: bbc2eea60bc100900bfa23d8eba28a9a, jobId: d448a43197f239503e0edade359d5267).
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:0, state:ACTIVE, resource profile: ResourceProfile{managedMemory=8.000mb (8388608 bytes), networkMemory=4.000mb (4194304 bytes)}, allocationId: 141582e87178c18a8dcc1a6980a2fa98, jobId: d448a43197f239503e0edade359d5267).
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.resourcemanager.ResourceManager closeJobManagerConnection
INFO: Disconnect job manager a225861fed902abb2b2dc41f2ee240c1@akka://flink/user/jobmanager_29 for job d448a43197f239503e0edade359d5267 from the resource manager.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:2, state:ACTIVE, resource profile: ResourceProfile{managedMemory=8.000mb (8388608 bytes), networkMemory=4.000mb (4194304 bytes)}, allocationId: dc44b686d5c7674afba04e5a6e414b25, jobId: d448a43197f239503e0edade359d5267).
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:15, state:ACTIVE, resource profile: ResourceProfile{managedMemory=8.000mb (8388608 bytes), networkMemory=4.000mb (4194304 bytes)}, allocationId: 41d3f45e513ec668d450eda6fdbba487, jobId: d448a43197f239503e0edade359d5267).
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:11, state:ACTIVE, resource profile: ResourceProfile{managedMemory=8.000mb (8388608 bytes), networkMemory=4.000mb (4194304 bytes)}, allocationId: 27392e6144716ac771eeb15470699a6e, jobId: d448a43197f239503e0edade359d5267).
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:4, state:ACTIVE, resource profile: ResourceProfile{managedMemory=8.000mb (8388608 bytes), networkMemory=4.000mb (4194304 bytes)}, allocationId: 6d14f71e813c29f2bb8be992da866a4e, jobId: d448a43197f239503e0edade359d5267).
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:12, state:ACTIVE, resource profile: ResourceProfile{managedMemory=8.000mb (8388608 bytes), networkMemory=4.000mb (4194304 bytes)}, allocationId: 1c3a72b059145d821165d34234e8cf86, jobId: d448a43197f239503e0edade359d5267).
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:1, state:ACTIVE, resource profile: ResourceProfile{managedMemory=8.000mb (8388608 bytes), networkMemory=4.000mb (4194304 bytes)}, allocationId: 6cf0ce19e2c31da1fce89df06cff54ba, jobId: d448a43197f239503e0edade359d5267).
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:10, state:ACTIVE, resource profile: ResourceProfile{managedMemory=8.000mb (8388608 bytes), networkMemory=4.000mb (4194304 bytes)}, allocationId: 299c0f3d7e91779851fbda2419cf2aaf, jobId: d448a43197f239503e0edade359d5267).
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.TaskExecutor$JobLeaderListenerImpl jobManagerLostLeadership
INFO: JobManager for job d448a43197f239503e0edade359d5267 with leader id a225861fed902abb2b2dc41f2ee240c1 lost leadership.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:8, state:ACTIVE, resource profile: ResourceProfile{managedMemory=8.000mb (8388608 bytes), networkMemory=4.000mb (4194304 bytes)}, allocationId: f95974bc4cadfa65d4c8163dd4827d27, jobId: d448a43197f239503e0edade359d5267).
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:14, state:ACTIVE, resource profile: ResourceProfile{managedMemory=8.000mb (8388608 bytes), networkMemory=4.000mb (4194304 bytes)}, allocationId: 65e8becb8ae51a4875b0355b5e44115c, jobId: d448a43197f239503e0edade359d5267).
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.TaskExecutor closeJobManagerConnection
INFO: Close JobManager connection for job d448a43197f239503e0edade359d5267.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.TaskExecutor closeJobManagerConnection
INFO: Close JobManager connection for job d448a43197f239503e0edade359d5267.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.JobLeaderService stop
INFO: Stop job leader service.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager shutdown
INFO: Shutting down TaskExecutorLocalStateStoresManager.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.webmonitor.WebMonitorEndpoint lambda$shutDownInternal$5
INFO: Removing cache directory /tmp/flink-web-ui
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.rest.RestServerEndpoint lambda$closeAsync$1
INFO: Shut down complete.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.io.disk.FileChannelManagerImpl lambda$getFileCloser$0
INFO: FileChannelManager removed spill file directory /tmp/flink-io-a60b5b86-da9b-4c3a-92a5-45efba18a144
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.resourcemanager.ResourceManager deregisterApplication
INFO: Shut down cluster because application is in CANCELED, diagnostics DispatcherResourceManagerComponent has been closed..
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.io.network.NettyShuffleEnvironment close
INFO: Shutting down the network environment and its components.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent closeAsyncInternal
INFO: Closing components.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess closeInternal
INFO: Stopping SessionDispatcherLeaderProcess.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.dispatcher.Dispatcher onStop
INFO: Stopping dispatcher akka://flink/user/dispatcher.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.io.disk.FileChannelManagerImpl lambda$getFileCloser$0
INFO: FileChannelManager removed spill file directory /tmp/flink-netty-shuffle-7dfc08c9-fb6b-4850-8767-06918f6820e7
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.dispatcher.Dispatcher terminateJobManagerRunners
INFO: Stopping all currently running jobs of dispatcher akka://flink/user/dispatcher.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl close
INFO: Closing the SlotManager.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.KvStateService shutdown
INFO: Shutting down the kvState service and its components.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl suspend
INFO: Suspending the SlotManager.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.JobLeaderService stop
INFO: Stop job leader service.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.filecache.FileCache shutdown
INFO: removed file cache directory /tmp/flink-dist-cache-7154c5ae-a5fd-4cec-a42b-caf2d2999761
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.taskexecutor.TaskExecutor handleOnStopException
INFO: Stopped TaskExecutor akka://flink/user/taskmanager_28.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureRequestCoordinator shutDown
INFO: Shutting down back pressure request coordinator.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.dispatcher.Dispatcher lambda$onStop$1
INFO: Stopped dispatcher akka://flink/user/dispatcher.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.rpc.akka.AkkaRpcService stopService
INFO: Stopping Akka RPC service.
Oct 06, 2020 6:11:50 PM akka.event.slf4j.Slf4jLogger$$anonfun$receive$1$$anonfun$applyOrElse$3 apply$mcV$sp
INFO: Shutting down remote daemon.
Oct 06, 2020 6:11:50 PM akka.event.slf4j.Slf4jLogger$$anonfun$receive$1$$anonfun$applyOrElse$3 apply$mcV$sp
INFO: Remote daemon shut down; proceeding with flushing remote transports.
Oct 06, 2020 6:11:50 PM akka.event.slf4j.Slf4jLogger$$anonfun$receive$1$$anonfun$applyOrElse$3 apply$mcV$sp
INFO: Remoting shut down.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.rpc.akka.AkkaRpcService stopService
INFO: Stopping Akka RPC service.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.rpc.akka.AkkaRpcService lambda$stopService$5
INFO: Stopped Akka RPC service.
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.blob.AbstractBlobCache close
INFO: Shutting down BLOB cache
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.blob.AbstractBlobCache close
INFO: Shutting down BLOB cache
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.blob.BlobServer close
INFO: Stopped BLOB server at 0.0.0.0:42599
Oct 06, 2020 6:11:50 PM org.apache.flink.runtime.rpc.akka.AkkaRpcService lambda$stopService$5
INFO: Stopped Akka RPC service.
FATAL: command execution failed
java.io.IOException: Backing channel 'apache-beam-jenkins-16' is disconnected.
	at hudson.remoting.RemoteInvocationHandler.channelOrFail(RemoteInvocationHandler.java:216)
	at hudson.remoting.RemoteInvocationHandler.invoke(RemoteInvocationHandler.java:285)
	at com.sun.proxy.$Proxy140.isAlive(Unknown Source)
	at hudson.Launcher$RemoteLauncher$ProcImpl.isAlive(Launcher.java:1147)
	at hudson.Launcher$RemoteLauncher$ProcImpl.join(Launcher.java:1139)
	at hudson.Launcher$ProcStarter.join(Launcher.java:469)
	at hudson.plugins.gradle.Gradle.perform(Gradle.java:317)
	at hudson.tasks.BuildStepMonitor$1.perform(BuildStepMonitor.java:20)
	at hudson.model.AbstractBuild$AbstractBuildExecution.perform(AbstractBuild.java:741)
	at hudson.model.Build$BuildExecution.build(Build.java:206)
	at hudson.model.Build$BuildExecution.doRun(Build.java:163)
	at hudson.model.AbstractBuild$AbstractBuildExecution.run(AbstractBuild.java:504)
	at hudson.model.Run.execute(Run.java:1880)
	at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:43)
	at hudson.model.ResourceController.execute(ResourceController.java:97)
	at hudson.model.Executor.run(Executor.java:428)
Caused by: hudson.remoting.Channel$OrderlyShutdown: Command Close created at
	at hudson.remoting.Channel$CloseCommand.execute(Channel.java:1314)
	at hudson.remoting.Channel$1.handle(Channel.java:606)
	at hudson.remoting.SynchronousCommandTransport$ReaderThread.run(SynchronousCommandTransport.java:85)
Caused by: Command Close created at
	at hudson.remoting.Command.<init>(Command.java:70)
	at hudson.remoting.Channel$CloseCommand.<init>(Channel.java:1308)
	at hudson.remoting.Channel$CloseCommand.<init>(Channel.java:1306)
	at hudson.remoting.Channel.close(Channel.java:1479)
	at hudson.remoting.Channel.close(Channel.java:1446)
	at hudson.remoting.Channel$CloseCommand.execute(Channel.java:1313)
	... 2 more
Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
ERROR: apache-beam-jenkins-16 is offline; cannot locate JDK 1.8 (latest)

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


beam_PostCommit_Java_Nexmark_Flink - Build # 6310 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Java_Nexmark_Flink - Build # 6310 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Java_Nexmark_Flink/6310/ to view the results.

beam_PostCommit_Java_Nexmark_Flink - Build # 6309 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Java_Nexmark_Flink - Build # 6309 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Java_Nexmark_Flink/6309/ to view the results.

beam_PostCommit_Java_Nexmark_Flink - Build # 6308 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Java_Nexmark_Flink - Build # 6308 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Java_Nexmark_Flink/6308/ to view the results.

beam_PostCommit_Java_Nexmark_Flink - Build # 6307 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Java_Nexmark_Flink - Build # 6307 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Java_Nexmark_Flink/6307/ to view the results.

beam_PostCommit_Java_Nexmark_Flink - Build # 6306 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Java_Nexmark_Flink - Build # 6306 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Java_Nexmark_Flink/6306/ to view the results.

beam_PostCommit_Java_Nexmark_Flink - Build # 6305 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Java_Nexmark_Flink - Build # 6305 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Java_Nexmark_Flink/6305/ to view the results.

beam_PostCommit_Java_Nexmark_Flink - Build # 6304 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Java_Nexmark_Flink - Build # 6304 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Java_Nexmark_Flink/6304/ to view the results.

beam_PostCommit_Java_Nexmark_Flink - Build # 6303 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Java_Nexmark_Flink - Build # 6303 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Java_Nexmark_Flink/6303/ to view the results.