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 2019/01/03 18:42:59 UTC

Build failed in Jenkins: beam_PostCommit_Java_PVR_Flink_Streaming #340

See <https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/340/display/redirect>

------------------------------------------
[...truncated 176.49 MB...]
    	at akka.dispatch.japi$CallbackBridge.apply(Future.scala:186)
    	at akka.dispatch.japi$CallbackBridge.apply(Future.scala:183)
    	at scala.concurrent.impl.CallbackRunnable.run(Promise.scala:36)
    	at org.apache.flink.runtime.concurrent.Executors$DirectExecutionContext.execute(Executors.java:83)
    	at scala.concurrent.impl.CallbackRunnable.executeWithValue(Promise.scala:44)
    	at scala.concurrent.impl.Promise$DefaultPromise.tryComplete(Promise.scala:252)
    	at akka.pattern.PromiseActorRef$$anonfun$1.apply$mcV$sp(AskSupport.scala:603)
    	at akka.actor.Scheduler$$anon$4.run(Scheduler.scala:126)
    	at akka.actor.LightArrayRevolverScheduler$TaskHolder.run(LightArrayRevolverScheduler.scala:338)
    	at akka.actor.LightArrayRevolverScheduler$$anonfun$close$1.apply(LightArrayRevolverScheduler.scala:142)
    	at akka.actor.LightArrayRevolverScheduler$$anonfun$close$1.apply(LightArrayRevolverScheduler.scala:141)
    	at scala.collection.Iterator$class.foreach(Iterator.scala:891)
    	at scala.collection.AbstractIterator.foreach(Iterator.scala:1334)
    	at scala.collection.IterableLike$class.foreach(IterableLike.scala:72)
    	at scala.collection.AbstractIterable.foreach(Iterable.scala:54)
    	at akka.actor.LightArrayRevolverScheduler.close(LightArrayRevolverScheduler.scala:140)
    	at akka.actor.ActorSystemImpl.stopScheduler(ActorSystem.scala:892)
    	at akka.actor.ActorSystemImpl$$anonfun$liftedTree2$1$1.apply$mcV$sp(ActorSystem.scala:826)
    	at akka.actor.ActorSystemImpl$$anonfun$liftedTree2$1$1.apply(ActorSystem.scala:826)
    	at akka.actor.ActorSystemImpl$$anonfun$liftedTree2$1$1.apply(ActorSystem.scala:826)
    	at akka.actor.ActorSystemImpl$$anon$3.run(ActorSystem.scala:842)
    	at akka.actor.ActorSystemImpl$TerminationCallbacks$$anonfun$addRec$1$1.applyOrElse(ActorSystem.scala:1021)
    	at akka.actor.ActorSystemImpl$TerminationCallbacks$$anonfun$addRec$1$1.applyOrElse(ActorSystem.scala:1021)
    	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:39)
    	at akka.dispatch.ForkJoinExecutorConfigurator$AkkaForkJoinTask.exec(AbstractDispatcher.scala:415)
    	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)
    Caused by: akka.pattern.AskTimeoutException: Ask timed out on [Actor[akka://flink/user/taskmanager_130#823340673]] after [10000 ms]. Sender[null] sent message of type "org.apache.flink.runtime.rpc.messages.CallAsync".
    	at akka.pattern.PromiseActorRef$$anonfun$1.apply$mcV$sp(AskSupport.scala:604)
    	... 31 more
    [flink-akka.actor.default-dispatcher-2] WARN org.apache.flink.runtime.taskexecutor.TaskExecutor - Could not send heartbeat to target with id 2182939fbe7bc848661c96238c7d07f3.
    java.util.concurrent.CompletionException: akka.pattern.AskTimeoutException: Ask timed out on [Actor[akka://flink/user/taskmanager_130#823340673]] after [10000 ms]. Sender[null] sent message of type "org.apache.flink.runtime.rpc.messages.CallAsync".
    	at java.util.concurrent.CompletableFuture.encodeThrowable(CompletableFuture.java:292)
    	at java.util.concurrent.CompletableFuture.completeThrowable(CompletableFuture.java:308)
    	at java.util.concurrent.CompletableFuture.uniAccept(CompletableFuture.java:647)
    	at java.util.concurrent.CompletableFuture$UniAccept.tryFire(CompletableFuture.java:632)
    	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:474)
    	at java.util.concurrent.CompletableFuture.completeExceptionally(CompletableFuture.java:1977)
    	at org.apache.flink.runtime.concurrent.FutureUtils$1.onComplete(FutureUtils.java:772)
    	at akka.dispatch.OnComplete.internal(Future.scala:258)
    	at akka.dispatch.OnComplete.internal(Future.scala:256)
    	at akka.dispatch.japi$CallbackBridge.apply(Future.scala:186)
    	at akka.dispatch.japi$CallbackBridge.apply(Future.scala:183)
    	at scala.concurrent.impl.CallbackRunnable.run(Promise.scala:36)
    	at org.apache.flink.runtime.concurrent.Executors$DirectExecutionContext.execute(Executors.java:83)
    	at scala.concurrent.impl.CallbackRunnable.executeWithValue(Promise.scala:44)
    	at scala.concurrent.impl.Promise$DefaultPromise.tryComplete(Promise.scala:252)
    	at akka.pattern.PromiseActorRef$$anonfun$1.apply$mcV$sp(AskSupport.scala:603)
    	at akka.actor.Scheduler$$anon$4.run(Scheduler.scala:126)
    	at akka.actor.LightArrayRevolverScheduler$TaskHolder.run(LightArrayRevolverScheduler.scala:338)
    	at akka.actor.LightArrayRevolverScheduler$$anonfun$close$1.apply(LightArrayRevolverScheduler.scala:142)
    	at akka.actor.LightArrayRevolverScheduler$$anonfun$close$1.apply(LightArrayRevolverScheduler.scala:141)
    	at scala.collection.Iterator$class.foreach(Iterator.scala:891)
    	at scala.collection.AbstractIterator.foreach(Iterator.scala:1334)
    	at scala.collection.IterableLike$class.foreach(IterableLike.scala:72)
    	at scala.collection.AbstractIterable.foreach(Iterable.scala:54)
    	at akka.actor.LightArrayRevolverScheduler.close(LightArrayRevolverScheduler.scala:140)
    	at akka.actor.ActorSystemImpl.stopScheduler(ActorSystem.scala:892)
    	at akka.actor.ActorSystemImpl$$anonfun$liftedTree2$1$1.apply$mcV$sp(ActorSystem.scala:826)
    	at akka.actor.ActorSystemImpl$$anonfun$liftedTree2$1$1.apply(ActorSystem.scala:826)
    	at akka.actor.ActorSystemImpl$$anonfun$liftedTree2$1$1.apply(ActorSystem.scala:826)
    	at akka.actor.ActorSystemImpl$$anon$3.run(ActorSystem.scala:842)
    	at akka.actor.ActorSystemImpl$TerminationCallbacks$$anonfun$addRec$1$1.applyOrElse(ActorSystem.scala:1021)
    	at akka.actor.ActorSystemImpl$TerminationCallbacks$$anonfun$addRec$1$1.applyOrElse(ActorSystem.scala:1021)
    	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:39)
    	at akka.dispatch.ForkJoinExecutorConfigurator$AkkaForkJoinTask.exec(AbstractDispatcher.scala:415)
    	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)
    Caused by: akka.pattern.AskTimeoutException: Ask timed out on [Actor[akka://flink/user/taskmanager_130#823340673]] after [10000 ms]. Sender[null] sent message of type "org.apache.flink.runtime.rpc.messages.CallAsync".
    	at akka.pattern.PromiseActorRef$$anonfun$1.apply$mcV$sp(AskSupport.scala:604)
    	... 31 more
    [flink-akka.actor.default-dispatcher-2] WARN org.apache.flink.runtime.taskexecutor.TaskExecutor - Could not send heartbeat to target with id 2182939fbe7bc848661c96238c7d07f3.
    java.util.concurrent.CompletionException: akka.pattern.AskTimeoutException: Ask timed out on [Actor[akka://flink/user/taskmanager_130#823340673]] after [10000 ms]. Sender[null] sent message of type "org.apache.flink.runtime.rpc.messages.CallAsync".
    	at java.util.concurrent.CompletableFuture.encodeThrowable(CompletableFuture.java:292)
    	at java.util.concurrent.CompletableFuture.completeThrowable(CompletableFuture.java:308)
    	at java.util.concurrent.CompletableFuture.uniAccept(CompletableFuture.java:647)
    	at java.util.concurrent.CompletableFuture$UniAccept.tryFire(CompletableFuture.java:632)
    	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:474)
    	at java.util.concurrent.CompletableFuture.completeExceptionally(CompletableFuture.java:1977)
    	at org.apache.flink.runtime.concurrent.FutureUtils$1.onComplete(FutureUtils.java:772)
    	at akka.dispatch.OnComplete.internal(Future.scala:258)
    	at akka.dispatch.OnComplete.internal(Future.scala:256)
    	at akka.dispatch.japi$CallbackBridge.apply(Future.scala:186)
    	at akka.dispatch.japi$CallbackBridge.apply(Future.scala:183)
    	at scala.concurrent.impl.CallbackRunnable.run(Promise.scala:36)
    	at org.apache.flink.runtime.concurrent.Executors$DirectExecutionContext.execute(Executors.java:83)
    	at scala.concurrent.impl.CallbackRunnable.executeWithValue(Promise.scala:44)
    	at scala.concurrent.impl.Promise$DefaultPromise.tryComplete(Promise.scala:252)
    	at akka.pattern.PromiseActorRef$$anonfun$1.apply$mcV$sp(AskSupport.scala:603)
    	at akka.actor.Scheduler$$anon$4.run(Scheduler.scala:126)
    	at akka.actor.LightArrayRevolverScheduler$TaskHolder.run(LightArrayRevolverScheduler.scala:338)
    	at akka.actor.LightArrayRevolverScheduler$$anonfun$close$1.apply(LightArrayRevolverScheduler.scala:142)
    	at akka.actor.LightArrayRevolverScheduler$$anonfun$close$1.apply(LightArrayRevolverScheduler.scala:141)
    	at scala.collection.Iterator$class.foreach(Iterator.scala:891)
    	at scala.collection.AbstractIterator.foreach(Iterator.scala:1334)
    	at scala.collection.IterableLike$class.foreach(IterableLike.scala:72)
    	at scala.collection.AbstractIterable.foreach(Iterable.scala:54)
    	at akka.actor.LightArrayRevolverScheduler.close(LightArrayRevolverScheduler.scala:140)
    	at akka.actor.ActorSystemImpl.stopScheduler(ActorSystem.scala:892)
    	at akka.actor.ActorSystemImpl$$anonfun$liftedTree2$1$1.apply$mcV$sp(ActorSystem.scala:826)
    	at akka.actor.ActorSystemImpl$$anonfun$liftedTree2$1$1.apply(ActorSystem.scala:826)
    	at akka.actor.ActorSystemImpl$$anonfun$liftedTree2$1$1.apply(ActorSystem.scala:826)
    	at akka.actor.ActorSystemImpl$$anon$3.run(ActorSystem.scala:842)
    	at akka.actor.ActorSystemImpl$TerminationCallbacks$$anonfun$addRec$1$1.applyOrElse(ActorSystem.scala:1021)
    	at akka.actor.ActorSystemImpl$TerminationCallbacks$$anonfun$addRec$1$1.applyOrElse(ActorSystem.scala:1021)
    	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:39)
    	at akka.dispatch.ForkJoinExecutorConfigurator$AkkaForkJoinTask.exec(AbstractDispatcher.scala:415)
    	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)
    Caused by: akka.pattern.AskTimeoutException: Ask timed out on [Actor[akka://flink/user/taskmanager_130#823340673]] after [10000 ms]. Sender[null] sent message of type "org.apache.flink.runtime.rpc.messages.CallAsync".
    	at akka.pattern.PromiseActorRef$$anonfun$1.apply$mcV$sp(AskSupport.scala:604)
    	... 31 more
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.blob.PermanentBlobCache - Shutting down BLOB cache
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.blob.TransientBlobCache - Shutting down BLOB cache
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:39797
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.rpc.akka.AkkaRpcService - Stopped Akka RPC service.
    [flink-runner-job-server] ERROR org.apache.beam.runners.flink.FlinkJobInvocation - Error during job invocation countingsourcetest0testunboundedsourcesplits-jenkins-0103184113-5439537c_e1376c1c-2cb3-4963-96db-dd56b1face51.
    org.apache.flink.runtime.client.JobExecutionException: Job execution failed.
    	at org.apache.flink.runtime.jobmaster.JobResult.toJobExecutionResult(JobResult.java:146)
    	at org.apache.flink.runtime.minicluster.MiniCluster.executeJobBlocking(MiniCluster.java:632)
    	at org.apache.flink.streaming.api.environment.LocalStreamEnvironment.execute(LocalStreamEnvironment.java:123)
    	at org.apache.beam.runners.flink.FlinkStreamingPortablePipelineTranslator$StreamingTranslationContext.execute(FlinkStreamingPortablePipelineTranslator.java:157)
    	at org.apache.beam.runners.flink.FlinkJobInvocation.runPipelineWithTranslator(FlinkJobInvocation.java:142)
    	at org.apache.beam.runners.flink.FlinkJobInvocation.runPipeline(FlinkJobInvocation.java:112)
    	at org.apache.beam.repackaged.beam_runners_flink_2.11.com.google.common.util.concurrent.TrustedListenableFutureTask$TrustedFutureInterruptibleTask.runInterruptibly(TrustedListenableFutureTask.java:111)
    	at org.apache.beam.repackaged.beam_runners_flink_2.11.com.google.common.util.concurrent.InterruptibleTask.run(InterruptibleTask.java:58)
    	at org.apache.beam.repackaged.beam_runners_flink_2.11.com.google.common.util.concurrent.TrustedListenableFutureTask.run(TrustedListenableFutureTask.java:75)
    	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: java.lang.Exception: Cannot deploy task split8/Reshuffle/Reshuffle/GroupByKey -> [11]{split8, Flatten.PCollections, Distinct, Count, Min, Max} (13/16) (245f95cec150155c26c9de80b4da6826) - TaskManager (82677efc-d062-4fe8-a020-87994b15107a @ localhost (dataPort=-1)) not responding after a rpcTimeout of 10000 ms
    	at org.apache.flink.runtime.executiongraph.Execution.lambda$deploy$5(Execution.java:601)
    	at java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:760)
    	at java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:736)
    	at java.util.concurrent.CompletableFuture$Completion.run(CompletableFuture.java:442)
    	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
    	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
    	at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.access$201(ScheduledThreadPoolExecutor.java:180)
    	at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:293)
    	... 3 more
    Caused by: akka.pattern.AskTimeoutException: Ask timed out on [Actor[akka://flink/user/taskmanager_130#823340673]] after [10000 ms]. Sender[null] sent message of type "org.apache.flink.runtime.rpc.messages.LocalRpcInvocation".
    	at akka.pattern.PromiseActorRef$$anonfun$1.apply$mcV$sp(AskSupport.scala:604)
    	at akka.actor.Scheduler$$anon$4.run(Scheduler.scala:126)
    	at scala.concurrent.Future$InternalCallbackExecutor$.unbatchedExecute(Future.scala:601)
    	at scala.concurrent.BatchingExecutor$class.execute(BatchingExecutor.scala:109)
    	at scala.concurrent.Future$InternalCallbackExecutor$.execute(Future.scala:599)
    	at akka.actor.LightArrayRevolverScheduler$TaskHolder.executeTask(LightArrayRevolverScheduler.scala:329)
    	at akka.actor.LightArrayRevolverScheduler$$anon$4.executeBucket$1(LightArrayRevolverScheduler.scala:280)
    	at akka.actor.LightArrayRevolverScheduler$$anon$4.nextTick(LightArrayRevolverScheduler.scala:284)
    	at akka.actor.LightArrayRevolverScheduler$$anon$4.run(LightArrayRevolverScheduler.scala:236)
    	... 1 more
    [flink-runner-job-server] INFO org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService - Manifest at /tmp/beam-artifact-staging/countingsourcetest0testunboundedsourcesplits-jenkins-0103184113-5439537c_6809991b-36f0-4ad3-88c5-70457e212c21/MANIFEST has 186 artifact locations
    [flink-runner-job-server] INFO org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactStagingService - Removed dir /tmp/beam-artifact-staging/countingsourcetest0testunboundedsourcesplits-jenkins-0103184113-5439537c_6809991b-36f0-4ad3-88c5-70457e212c21/
Could not stop org.gradle.internal.actor.internal.DefaultActorFactory$NonBlockingActor@4c08251d.
org.gradle.internal.dispatch.DispatchException: Could not dispatch message [MethodInvocation method: stop()].
	at org.gradle.internal.dispatch.ExceptionTrackingFailureHandler.dispatchFailed(ExceptionTrackingFailureHandler.java:34)
	at org.gradle.internal.dispatch.FailureHandlingDispatch.dispatch(FailureHandlingDispatch.java:31)
	at org.gradle.internal.dispatch.AsyncDispatch.dispatchMessages(AsyncDispatch.java:133)
	at org.gradle.internal.dispatch.AsyncDispatch.access$000(AsyncDispatch.java:34)
	at org.gradle.internal.dispatch.AsyncDispatch$1.run(AsyncDispatch.java:73)
	at org.gradle.internal.operations.CurrentBuildOperationPreservingRunnable.run(CurrentBuildOperationPreservingRunnable.java:42)
	at org.gradle.internal.concurrent.ExecutorPolicy$CatchAndRecordFailures.onExecute(ExecutorPolicy.java:63)
	at org.gradle.internal.concurrent.ManagedExecutorImpl$1.run(ManagedExecutorImpl.java:46)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
	at org.gradle.internal.concurrent.ThreadFactoryImpl$ManagedThreadRunnable.run(ThreadFactoryImpl.java:55)
	at java.lang.Thread.run(Thread.java:748)
Caused by: org.gradle.process.internal.ExecException: Process 'Gradle Test Executor 1' finished with non-zero exit value 137
This problem might be caused by incorrect test process configuration.
Please refer to the test execution section in the user guide at https://docs.gradle.org/4.10.2/userguide/java_plugin.html#sec:test_execution
	at org.gradle.api.internal.tasks.testing.worker.ForkingTestClassProcessor.stop(ForkingTestClassProcessor.java:155)
	at org.gradle.api.internal.tasks.testing.processors.RestartEveryNTestClassProcessor.endBatch(RestartEveryNTestClassProcessor.java:77)
	at org.gradle.api.internal.tasks.testing.processors.RestartEveryNTestClassProcessor.stop(RestartEveryNTestClassProcessor.java:62)
	at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
	at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:62)
	at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
	at java.lang.reflect.Method.invoke(Method.java:498)
	at org.gradle.internal.dispatch.ReflectionDispatch.dispatch(ReflectionDispatch.java:35)
	at org.gradle.internal.dispatch.ReflectionDispatch.dispatch(ReflectionDispatch.java:24)
	at org.gradle.internal.dispatch.FailureHandlingDispatch.dispatch(FailureHandlingDispatch.java:29)
	... 10 more

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testCombinePerKeyLambda SKIPPED

org.apache.beam.sdk.io.CountingSourceTest > testUnboundedSourceSplits SKIPPED

138 tests completed, 4 failed, 4 skipped

> Task :beam-runners-flink_2.11-job-server:validatesPortableRunnerStreaming FAILED
:beam-runners-flink_2.11-job-server:validatesPortableRunnerStreaming (Thread[Task worker for ':' Thread 5,5,main]) completed. Took 27 mins 49.64 secs.

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':beam-runners-flink_2.11-job-server:validatesPortableRunnerStreaming'.
> Process 'Gradle Test Executor 2' finished with non-zero exit value 137
  This problem might be caused by incorrect test process configuration.
  Please refer to the test execution section in the user guide at https://docs.gradle.org/4.10.2/userguide/java_plugin.html#sec:test_execution

* Try:
Run with --stacktrace option to get the stack trace. Run with --debug option to get more log output. Run with --scan to get full insights.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 30m 2s
75 actionable tasks: 70 executed, 4 from cache, 1 up-to-date

Publishing build scan...
https://gradle.com/s/q2vjepakdmdhy

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

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


Build failed in Jenkins: beam_PostCommit_Java_PVR_Flink_Streaming #343

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/343/display/redirect>

------------------------------------------
[...truncated 232.96 MB...]
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (1/16) (f8561fbd3489b4cd66f66e463fcdc7a8) switched from RUNNING to FINISHED.
    [ToKeyedWorkItem (9/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task ToKeyedWorkItem (9/16) (e3d5adb7869bbe2886418396a39a9134) [FINISHED]
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem 0473e548b1ad675bc1da3943452b95b6.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem 9f85d6dd9771c2480cf348f0e5f25c7d.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem 5f06ef10c105d37dbe77ef44d22af83e.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem e3d5adb7869bbe2886418396a39a9134.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (10/16) (77fa81111199993e0f32c4bd276d166a) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (5/16) (33f6b4ca1430be80702aedc71deb6271) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (12/16) (c9f321efed37bf81812e2b25c6264219) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (9/16) (782935d55bd17f5a000f27b73ce2ad49) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (1/16) (0473e548b1ad675bc1da3943452b95b6) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (10/16) (9f85d6dd9771c2480cf348f0e5f25c7d) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (5/16) (5f06ef10c105d37dbe77ef44d22af83e) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (9/16) (e3d5adb7869bbe2886418396a39a9134) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (8/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (8/16) (779abca59923f9e70f921821057ffaf3) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (8/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (8/16) (779abca59923f9e70f921821057ffaf3).
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (14/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (14/16) (6c4e3d8cf1609930cc684113bc5aab1b) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (14/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (14/16) (6c4e3d8cf1609930cc684113bc5aab1b).
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (8/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (8/16) (779abca59923f9e70f921821057ffaf3) [FINISHED]
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (14/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (14/16) (6c4e3d8cf1609930cc684113bc5aab1b) [FINISHED]
    [flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} 779abca59923f9e70f921821057ffaf3.
    [flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} 6c4e3d8cf1609930cc684113bc5aab1b.
    [ToKeyedWorkItem (8/16)] INFO org.apache.flink.runtime.taskmanager.Task - ToKeyedWorkItem (8/16) (67542c2d850fcff079886eeb0335321e) switched from RUNNING to FINISHED.
    [ToKeyedWorkItem (8/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for ToKeyedWorkItem (8/16) (67542c2d850fcff079886eeb0335321e).
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (15/16) (599ee92db49bd832c723bd25866c4e09) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (15/16) (599ee92db49bd832c723bd25866c4e09).
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (7/16) (4101ebf14b84334bf999c42f20fd538a) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (7/16) (4101ebf14b84334bf999c42f20fd538a).
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (8/16) (779abca59923f9e70f921821057ffaf3) switched from RUNNING to FINISHED.
    [ToKeyedWorkItem (8/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task ToKeyedWorkItem (8/16) (67542c2d850fcff079886eeb0335321e) [FINISHED]
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (15/16) (599ee92db49bd832c723bd25866c4e09) [FINISHED]
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (7/16) (4101ebf14b84334bf999c42f20fd538a) [FINISHED]
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (3/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (3/16) (ca9b3551e9eaae6ebce2ca2b0bd885cb) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (3/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (3/16) (ca9b3551e9eaae6ebce2ca2b0bd885cb).
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (3/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (3/16) (ca9b3551e9eaae6ebce2ca2b0bd885cb) [FINISHED]
    [ToKeyedWorkItem (14/16)] INFO org.apache.flink.runtime.taskmanager.Task - ToKeyedWorkItem (14/16) (c7cdf58e4eb610c2dba312015c9e7ec5) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem 67542c2d850fcff079886eeb0335321e.
    [ToKeyedWorkItem (14/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for ToKeyedWorkItem (14/16) (c7cdf58e4eb610c2dba312015c9e7ec5).
    [ToKeyedWorkItem (14/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task ToKeyedWorkItem (14/16) (c7cdf58e4eb610c2dba312015c9e7ec5) [FINISHED]
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} 599ee92db49bd832c723bd25866c4e09.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (14/16) (6c4e3d8cf1609930cc684113bc5aab1b) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (8/16) (67542c2d850fcff079886eeb0335321e) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} 4101ebf14b84334bf999c42f20fd538a.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} ca9b3551e9eaae6ebce2ca2b0bd885cb.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (15/16) (599ee92db49bd832c723bd25866c4e09) switched from RUNNING to FINISHED.
    [ToKeyedWorkItem (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - ToKeyedWorkItem (15/16) (d4d2631e9d09b48d4b6678dc68d35417) switched from RUNNING to FINISHED.
    [ToKeyedWorkItem (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for ToKeyedWorkItem (15/16) (d4d2631e9d09b48d4b6678dc68d35417).
    [ToKeyedWorkItem (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - ToKeyedWorkItem (7/16) (7841fceaafd60145ba1cc761c8c2a49b) switched from RUNNING to FINISHED.
    [ToKeyedWorkItem (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task ToKeyedWorkItem (15/16) (d4d2631e9d09b48d4b6678dc68d35417) [FINISHED]
    [ToKeyedWorkItem (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for ToKeyedWorkItem (7/16) (7841fceaafd60145ba1cc761c8c2a49b).
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem c7cdf58e4eb610c2dba312015c9e7ec5.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem d4d2631e9d09b48d4b6678dc68d35417.
    [ToKeyedWorkItem (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task ToKeyedWorkItem (7/16) (7841fceaafd60145ba1cc761c8c2a49b) [FINISHED]
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem 7841fceaafd60145ba1cc761c8c2a49b.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (7/16) (4101ebf14b84334bf999c42f20fd538a) switched from RUNNING to FINISHED.
    [ToKeyedWorkItem (3/16)] INFO org.apache.flink.runtime.taskmanager.Task - ToKeyedWorkItem (3/16) (744f2b206c569c470276f2ecfe4ba1ed) switched from RUNNING to FINISHED.
    [ToKeyedWorkItem (3/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for ToKeyedWorkItem (3/16) (744f2b206c569c470276f2ecfe4ba1ed).
    [ToKeyedWorkItem (3/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task ToKeyedWorkItem (3/16) (744f2b206c569c470276f2ecfe4ba1ed) [FINISHED]
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem 744f2b206c569c470276f2ecfe4ba1ed.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (3/16) (ca9b3551e9eaae6ebce2ca2b0bd885cb) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (14/16) (c7cdf58e4eb610c2dba312015c9e7ec5) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (15/16) (d4d2631e9d09b48d4b6678dc68d35417) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (7/16) (7841fceaafd60145ba1cc761c8c2a49b) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (3/16) (744f2b206c569c470276f2ecfe4ba1ed) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (2/16) (672d3b538c95d03ae16107cb33791c0a) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (2/16) (672d3b538c95d03ae16107cb33791c0a).
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (2/16) (672d3b538c95d03ae16107cb33791c0a) [FINISHED]
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} 672d3b538c95d03ae16107cb33791c0a.
    [ToKeyedWorkItem (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - ToKeyedWorkItem (2/16) (7d69bb594ae1b65240a2122ab6497e0f) switched from RUNNING to FINISHED.
    [ToKeyedWorkItem (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for ToKeyedWorkItem (2/16) (7d69bb594ae1b65240a2122ab6497e0f).
    [ToKeyedWorkItem (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task ToKeyedWorkItem (2/16) (7d69bb594ae1b65240a2122ab6497e0f) [FINISHED]
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem 7d69bb594ae1b65240a2122ab6497e0f.
    [flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (2/16) (672d3b538c95d03ae16107cb33791c0a) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (2/16) (7d69bb594ae1b65240a2122ab6497e0f) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (4/16)] WARN org.apache.flink.metrics.MetricGroup - Name collision: Group already contains a Metric with the name 'beam.metric:user:org.apache.beam.sdk.testing.PAssert:PAssertSuccess'. Metric will not be reported.[localhost, taskmanager, 6df1e05a-c09a-4274-a46c-85bf7de4e987, reifytimestampstest0invaluessucceeds-jenkins-0104064227-77de412c, [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions}, 3]
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (12/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (12/16) (137aa4ccf228821d713a22c3a03cdf1e) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (12/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (12/16) (137aa4ccf228821d713a22c3a03cdf1e).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (12/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (12/16) (137aa4ccf228821d713a22c3a03cdf1e) [FINISHED]
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 137aa4ccf228821d713a22c3a03cdf1e.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (2/16) (6c589341178f28369ed8b9c5b7f6f48d) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (11/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (11/16) (2e6aba4f758b7ef1e7841cbe1502dc6f) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (11/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (11/16) (2e6aba4f758b7ef1e7841cbe1502dc6f).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (2/16) (6c589341178f28369ed8b9c5b7f6f48d).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (11/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (11/16) (2e6aba4f758b7ef1e7841cbe1502dc6f) [FINISHED]
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (2/16) (6c589341178f28369ed8b9c5b7f6f48d) [FINISHED]
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 2e6aba4f758b7ef1e7841cbe1502dc6f.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (6/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (6/16) (25cbda590b647567e7967d319d2b9df5) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (6/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (6/16) (25cbda590b647567e7967d319d2b9df5).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (8/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (8/16) (e10584386d60601b6fdc0bc25b10830c) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (6/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (6/16) (25cbda590b647567e7967d319d2b9df5) [FINISHED]
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (8/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (8/16) (e10584386d60601b6fdc0bc25b10830c).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (8/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (8/16) (e10584386d60601b6fdc0bc25b10830c) [FINISHED]
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 6c589341178f28369ed8b9c5b7f6f48d.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 25cbda590b647567e7967d319d2b9df5.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (12/16) (137aa4ccf228821d713a22c3a03cdf1e) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} e10584386d60601b6fdc0bc25b10830c.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (11/16) (2e6aba4f758b7ef1e7841cbe1502dc6f) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (7/16) (859e54a291ca9b03c88a9ec61e152616) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (7/16) (859e54a291ca9b03c88a9ec61e152616).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (7/16) (859e54a291ca9b03c88a9ec61e152616) [FINISHED]
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (9/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (9/16) (dea971e457c30d7a5075be9cd9ca08ab) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 859e54a291ca9b03c88a9ec61e152616.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (9/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (9/16) (dea971e457c30d7a5075be9cd9ca08ab).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (9/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (9/16) (dea971e457c30d7a5075be9cd9ca08ab) [FINISHED]
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (2/16) (6c589341178f28369ed8b9c5b7f6f48d) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} dea971e457c30d7a5075be9cd9ca08ab.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (6/16) (25cbda590b647567e7967d319d2b9df5) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (10/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (10/16) (fd66f0f30754de293dcaf6f3b1c3bfff) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (10/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (10/16) (fd66f0f30754de293dcaf6f3b1c3bfff).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (10/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (10/16) (fd66f0f30754de293dcaf6f3b1c3bfff) [FINISHED]
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (8/16) (e10584386d60601b6fdc0bc25b10830c) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} fd66f0f30754de293dcaf6f3b1c3bfff.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (7/16) (859e54a291ca9b03c88a9ec61e152616) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (13/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (13/16) (08298ec35e9ecb83e7611c4eff290c94) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (13/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (13/16) (08298ec35e9ecb83e7611c4eff290c94).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (13/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (13/16) (08298ec35e9ecb83e7611c4eff290c94) [FINISHED]
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (15/16) (63ab32302b9f09d4a3aea2a9ce862c71) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (15/16) (63ab32302b9f09d4a3aea2a9ce862c71).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (15/16) (63ab32302b9f09d4a3aea2a9ce862c71) [FINISHED]
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 08298ec35e9ecb83e7611c4eff290c94.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (9/16) (dea971e457c30d7a5075be9cd9ca08ab) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 63ab32302b9f09d4a3aea2a9ce862c71.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (10/16) (fd66f0f30754de293dcaf6f3b1c3bfff) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (3/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (3/16) (dcb59b8e18da0c337cb0595b18b6fd67) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (3/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (3/16) (dcb59b8e18da0c337cb0595b18b6fd67).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (3/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (3/16) (dcb59b8e18da0c337cb0595b18b6fd67) [FINISHED]
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} dcb59b8e18da0c337cb0595b18b6fd67.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (13/16) (08298ec35e9ecb83e7611c4eff290c94) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (1/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (1/16) (211ce5e2b2118bb4304931fe7753251c) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (1/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (1/16) (211ce5e2b2118bb4304931fe7753251c).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (1/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (1/16) (211ce5e2b2118bb4304931fe7753251c) [FINISHED]
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (5/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (5/16) (f8528543151649734bc119c47fed2123) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (15/16) (63ab32302b9f09d4a3aea2a9ce862c71) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 211ce5e2b2118bb4304931fe7753251c.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (5/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (5/16) (f8528543151649734bc119c47fed2123).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (5/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (5/16) (f8528543151649734bc119c47fed2123) [FINISHED]
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} f8528543151649734bc119c47fed2123.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (3/16) (dcb59b8e18da0c337cb0595b18b6fd67) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (14/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (14/16) (f367ccdd2f9438c57759fa2184c1189d) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (14/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (14/16) (f367ccdd2f9438c57759fa2184c1189d).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (14/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (14/16) (f367ccdd2f9438c57759fa2184c1189d) [FINISHED]
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (1/16) (211ce5e2b2118bb4304931fe7753251c) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} f367ccdd2f9438c57759fa2184c1189d.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (16/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (16/16) (f807058eb252cdb55dfad973038dab14) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (5/16) (f8528543151649734bc119c47fed2123) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (16/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (16/16) (f807058eb252cdb55dfad973038dab14).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (16/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (16/16) (f807058eb252cdb55dfad973038dab14) [FINISHED]
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} f807058eb252cdb55dfad973038dab14.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (14/16) (f367ccdd2f9438c57759fa2184c1189d) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (16/16) (f807058eb252cdb55dfad973038dab14) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (4/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (4/16) (035fa164f7a77147ba5f53b98d016bcd) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (4/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (4/16) (035fa164f7a77147ba5f53b98d016bcd).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (4/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (4/16) (035fa164f7a77147ba5f53b98d016bcd) [FINISHED]
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 035fa164f7a77147ba5f53b98d016bcd.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (4/16) (035fa164f7a77147ba5f53b98d016bcd) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Job reifytimestampstest0invaluessucceeds-jenkins-0104064227-77de412c (74d3560bc4c6dec7461aac8b30028759) switched from state RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.checkpoint.CheckpointCoordinator - Stopping checkpoint coordinator for job 74d3560bc4c6dec7461aac8b30028759.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore - Shutting down
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.dispatcher.StandaloneDispatcher - Job 74d3560bc4c6dec7461aac8b30028759 reached globally terminal state FINISHED.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.jobmaster.JobMaster - Stopping the JobMaster for job reifytimestampstest0invaluessucceeds-jenkins-0104064227-77de412c(74d3560bc4c6dec7461aac8b30028759).
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Close JobManager connection for job 74d3560bc4c6dec7461aac8b30028759.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.jobmaster.JobMaster - Close ResourceManager connection 542f45f4e786242e279f8cf0fef82b7d: JobManager is shutting down..
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.resourcemanager.StandaloneResourceManager - Disconnect job manager a1ee2e3120a1bf383ab192f4cb254401@akka://flink/user/jobmanager_231 for job 74d3560bc4c6dec7461aac8b30028759 from the resource manager.
    [flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.jobmaster.slotpool.SlotPool - Suspending SlotPool.
    [flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.jobmaster.slotpool.SlotPool - Stopping SlotPool.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - JobManager for job 74d3560bc4c6dec7461aac8b30028759 with leader id a1ee2e3120a1bf383ab192f4cb254401 lost leadership.
    [flink-runner-job-server] INFO org.apache.flink.runtime.minicluster.MiniCluster - Shutting down Flink Mini Cluster
    [flink-runner-job-server] INFO org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint - Shutting down rest endpoint.
    [flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.dispatcher.StandaloneDispatcher - Stopping dispatcher akka://flink/user/dispatcher1f296857-e9ee-434d-a87e-db6ddc142acc.
    [flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.dispatcher.StandaloneDispatcher - Stopping all currently running jobs of dispatcher akka://flink/user/dispatcher1f296857-e9ee-434d-a87e-db6ddc142acc.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:1, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{f5b27bf048c20ea6690655bcc35806eb}, jobId: 74d3560bc4c6dec7461aac8b30028759).
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator - Shutting down stack trace sample coordinator.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.dispatcher.StandaloneDispatcher - Stopped dispatcher akka://flink/user/dispatcher1f296857-e9ee-434d-a87e-db6ddc142acc.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:10, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{7b4ae48b5c8e0ebfd478e6b04894a505}, jobId: 74d3560bc4c6dec7461aac8b30028759).
    [flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager - Closing the SlotManager.
    [flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager - Suspending the SlotManager.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:8, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{bc900b7b3d3e9c5b8c9c2d5662800812}, jobId: 74d3560bc4c6dec7461aac8b30028759).
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:2, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{801d18a704e05f4f572c44b60d406c7f}, jobId: 74d3560bc4c6dec7461aac8b30028759).
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:4, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{ca68fac55150a0c64004a60d539d9577}, jobId: 74d3560bc4c6dec7461aac8b30028759).
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:13, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{2349f954071ce45bfbbef0482c7e459a}, jobId: 74d3560bc4c6dec7461aac8b30028759).
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:15, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{fa6573a550c34f1620748c863ec8913f}, jobId: 74d3560bc4c6dec7461aac8b30028759).
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:9, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{1a5f1c5166abaf824d4b4288b1f9c906}, jobId: 74d3560bc4c6dec7461aac8b30028759).
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:5, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{d02f8a6a5dc23929decff1ac4434e9e6}, jobId: 74d3560bc4c6dec7461aac8b30028759).
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:6, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{19c7fcbad7c88cea934b69242a74dce1}, jobId: 74d3560bc4c6dec7461aac8b30028759).
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:14, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{e3104591814f3907cfd5cf9eeaba8a4d}, jobId: 74d3560bc4c6dec7461aac8b30028759).
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:12, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{1f2014835a3f473e35b44076466efad8}, jobId: 74d3560bc4c6dec7461aac8b30028759).
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:3, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{c3b06435980395ade2e755bd902da6cb}, jobId: 74d3560bc4c6dec7461aac8b30028759).
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:11, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{586b1ab00df8d0cae25fd033f1b1b51e}, jobId: 74d3560bc4c6dec7461aac8b30028759).
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:0, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{b98f8b835e0aca68957267f76f5004c6}, jobId: 74d3560bc4c6dec7461aac8b30028759).
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:7, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{ec9125a47e6927ea4f22ae78ef641a72}, jobId: 74d3560bc4c6dec7461aac8b30028759).
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.JobLeaderService - Remove job 74d3560bc4c6dec7461aac8b30028759 from job leader monitoring.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Close JobManager connection for job 74d3560bc4c6dec7461aac8b30028759.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Close JobManager connection for job 74d3560bc4c6dec7461aac8b30028759.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Stopping TaskExecutor akka://flink/user/taskmanager_230.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager - Shutting down TaskExecutorLocalStateStoresManager.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.io.disk.iomanager.IOManager - I/O manager removed spill file directory /tmp/flink-io-369980a2-ddfa-4c58-8399-1c69ebc0abb2
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.io.network.NetworkEnvironment - Shutting down the network environment and its components.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.JobLeaderService - Stop job leader service.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Stopped TaskExecutor akka://flink/user/taskmanager_230.
    [ForkJoinPool.commonPool-worker-2] INFO org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint - Removing cache directory /tmp/flink-web-ui
    [ForkJoinPool.commonPool-worker-2] INFO org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint - Shut down complete.
    [ForkJoinPool.commonPool-worker-2] INFO org.apache.flink.runtime.rpc.akka.AkkaRpcService - Stopping Akka RPC service.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.blob.PermanentBlobCache - Shutting down BLOB cache
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.blob.TransientBlobCache - Shutting down BLOB cache
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:40553
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.rpc.akka.AkkaRpcService - Stopped Akka RPC service.
    [flink-runner-job-server] INFO org.apache.beam.runners.flink.FlinkRunner - Execution finished in 10136 msecs
    [flink-runner-job-server] INFO org.apache.beam.runners.flink.FlinkRunner - Final accumulator values:
    [flink-runner-job-server] INFO org.apache.beam.runners.flink.FlinkRunner - __metricscontainers : org.apache.beam.runners.core.metrics.MetricsContainerStepMap@3d4703a8
    [flink-runner-job-server] INFO org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService - Manifest at /tmp/beam-artifact-staging/reifytimestampstest0invaluessucceeds-jenkins-0104064227-77de412c_199fbc61-1a19-4937-9a87-50256d64c4c3/MANIFEST has 186 artifact locations
    [flink-runner-job-server] INFO org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactStagingService - Removed dir /tmp/beam-artifact-staging/reifytimestampstest0invaluessucceeds-jenkins-0104064227-77de412c_199fbc61-1a19-4937-9a87-50256d64c4c3/
    [Test worker] INFO org.apache.beam.runners.flink.FlinkJobServerDriver - JobServer stopped on localhost:46191
    [Test worker] INFO org.apache.beam.runners.flink.FlinkJobServerDriver - ArtifactStagingServer stopped on localhost:34559

Gradle Test Executor 1 finished executing tests.

> Task :beam-runners-flink_2.11-job-server:validatesPortableRunnerStreaming

196 tests completed, 2 failed, 2 skipped
Finished generating test XML results (1.444 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/ws/src/runners/flink/job-server/build/test-results/validatesPortableRunnerStreaming>
Generating HTML test report...
Finished generating test html results (0.877 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/ws/src/runners/flink/job-server/build/reports/tests/validatesPortableRunnerStreaming>

> Task :beam-runners-flink_2.11-job-server:validatesPortableRunnerStreaming FAILED
:beam-runners-flink_2.11-job-server:validatesPortableRunnerStreaming (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 39 mins 15.893 secs.

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':beam-runners-flink_2.11-job-server:validatesPortableRunnerStreaming'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/ws/src/runners/flink/job-server/build/reports/tests/validatesPortableRunnerStreaming/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --debug option to get more log output. Run with --scan to get full insights.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 42m 47s
75 actionable tasks: 70 executed, 4 from cache, 1 up-to-date

Publishing build scan...
https://gradle.com/s/jtqi4d3brqqb2

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

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


Build failed in Jenkins: beam_PostCommit_Java_PVR_Flink_Streaming #342

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/342/display/redirect>

------------------------------------------
[...truncated 23.48 KB...]
Resolving github.com/golang/snappy: commit='553a641470496b2327abcac10b36396bd98e45c9', urls=[https://github.com/golang/snappy.git, git@github.com:golang/snappy.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving github.com/google/go-cmp: commit='3af367b6b30c263d47e8895973edcca9a49cf029', urls=[https://github.com/google/go-cmp.git, git@github.com:google/go-cmp.git]
Resolving github.com/google/pprof: commit='a8f279b7952b27edbcb72e5a6c69ee9be4c8ad93', urls=[https://github.com/google/pprof.git, git@github.com:google/pprof.git]
Resolving github.com/googleapis/gax-go: commit='317e0006254c44a0ac427cc52a0e083ff0b9622f', urls=[https://github.com/googleapis/gax-go.git, git@github.com:googleapis/gax-go.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving github.com/hashicorp/hcl: commit='23c074d0eceb2b8a5bfdbb271ab780cde70f05a8', urls=[https://github.com/hashicorp/hcl.git, git@github.com:hashicorp/hcl.git]
Resolving github.com/ianlancetaylor/demangle: commit='4883227f66371e02c4948937d3e2be1664d9be38', urls=[https://github.com/ianlancetaylor/demangle.git, git@github.com:ianlancetaylor/demangle.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving github.com/kr/fs: commit='2788f0dbd16903de03cb8186e5c7d97b69ad387b', urls=[https://github.com/kr/fs.git, git@github.com:kr/fs.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving github.com/magiconair/properties: commit='49d762b9817ba1c2e9d0c69183c2b4a8b8f1d934', urls=[https://github.com/magiconair/properties.git, git@github.com:magiconair/properties.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving github.com/mitchellh/go-homedir: commit='b8bc1bf767474819792c23f32d8286a45736f1c6', urls=[https://github.com/mitchellh/go-homedir.git, git@github.com:mitchellh/go-homedir.git]
Resolving github.com/mitchellh/mapstructure: commit='a4e142e9c047c904fa2f1e144d9a84e6133024bc', urls=[https://github.com/mitchellh/mapstructure.git, git@github.com:mitchellh/mapstructure.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving github.com/openzipkin/zipkin-go: commit='3741243b287094fda649c7f0fa74bd51f37dc122', urls=[https://github.com/openzipkin/zipkin-go.git, git@github.com:openzipkin/zipkin-go.git]
Resolving github.com/pelletier/go-toml: commit='acdc4509485b587f5e675510c4f2c63e90ff68a8', urls=[https://github.com/pelletier/go-toml.git, git@github.com:pelletier/go-toml.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving github.com/pierrec/lz4: commit='ed8d4cc3b461464e69798080a0092bd028910298', urls=[https://github.com/pierrec/lz4.git, git@github.com:pierrec/lz4.git]
Resolving github.com/pierrec/xxHash: commit='a0006b13c722f7f12368c00a3d3c2ae8a999a0c6', urls=[https://github.com/pierrec/xxHash.git, git@github.com:pierrec/xxHash.git]
Resolving github.com/pkg/errors: commit='30136e27e2ac8d167177e8a583aa4c3fea5be833', urls=[https://github.com/pkg/errors.git, git@github.com:pkg/errors.git]
Resolving github.com/pkg/sftp: commit='22e9c1ccc02fc1b9fa3264572e49109b68a86947', urls=[https://github.com/pkg/sftp.git, git@github.com:pkg/sftp.git]
Resolving github.com/prometheus/client_golang: commit='9bb6ab929dcbe1c8393cd9ef70387cb69811bd1c', urls=[https://github.com/prometheus/client_golang.git, git@github.com:prometheus/client_golang.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving github.com/prometheus/procfs: commit='cb4147076ac75738c9a7d279075a253c0cc5acbd', urls=[https://github.com/prometheus/procfs.git, git@github.com:prometheus/procfs.git]
Resolving github.com/rcrowley/go-metrics: commit='8732c616f52954686704c8645fe1a9d59e9df7c1', urls=[https://github.com/rcrowley/go-metrics.git, git@github.com:rcrowley/go-metrics.git]
Resolving github.com/cpuguy83/go-md2man: commit='dc9f53734905c233adfc09fd4f063dce63ce3daf', urls=[https://github.com/cpuguy83/go-md2man.git, git@github.com:cpuguy83/go-md2man.git]
Resolving cached github.com/cpuguy83/go-md2man: commit='dc9f53734905c233adfc09fd4f063dce63ce3daf', urls=[https://github.com/cpuguy83/go-md2man.git, git@github.com:cpuguy83/go-md2man.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving github.com/spf13/afero: commit='bb8f1927f2a9d3ab41c9340aa034f6b803f4359c', urls=[https://github.com/spf13/afero.git, git@github.com:spf13/afero.git]
Resolving github.com/spf13/cast: commit='acbeb36b902d72a7a4c18e8f3241075e7ab763e4', urls=[https://github.com/spf13/cast.git, git@github.com:spf13/cast.git]
Resolving github.com/spf13/cobra: commit='93959269ad99e80983c9ba742a7e01203a4c0e4f', urls=[https://github.com/spf13/cobra.git, git@github.com:spf13/cobra.git]
Resolving github.com/spf13/jwalterweatherman: commit='7c0cea34c8ece3fbeb2b27ab9b59511d360fb394', urls=[https://github.com/spf13/jwalterweatherman.git, git@github.com:spf13/jwalterweatherman.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving github.com/spf13/viper: commit='aafc9e6bc7b7bb53ddaa75a5ef49a17d6e654be5', urls=[https://github.com/spf13/viper.git, git@github.com:spf13/viper.git]
Resolving github.com/stathat/go: commit='74669b9f388d9d788c97399a0824adbfee78400e', urls=[https://github.com/stathat/go.git, git@github.com:stathat/go.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving github.com/xordataexchange/crypt: commit='b2862e3d0a775f18c7cfe02273500ae307b61218', urls=[https://github.com/xordataexchange/crypt.git, git@github.com:xordataexchange/crypt.git]
Resolving go.opencensus.io: commit='aa2b39d1618ef56ba156f27cfcdae9042f68f0bc', urls=[https://github.com/census-instrumentation/opencensus-go]
Resolving golang.org/x/crypto: commit='d9133f5469342136e669e85192a26056b587f503', urls=[https://go.googlesource.com/crypto]
Resolving golang.org/x/debug: commit='95515998a8a4bd7448134b2cb5971dbeb12e0b77', urls=[https://go.googlesource.com/debug]
Resolving golang.org/x/net: commit='2fb46b16b8dda405028c50f7c7f0f9dd1fa6bfb1', urls=[https://go.googlesource.com/net]
Resolving golang.org/x/oauth2: commit='a032972e28060ca4f5644acffae3dfc268cc09db', urls=[https://go.googlesource.com/oauth2]
Resolving golang.org/x/sync: commit='fd80eb99c8f653c847d294a001bdf2a3a6f768f5', urls=[https://go.googlesource.com/sync]

> Task :beam-sdks-java-core:shadowJar
> Task :beam-sdks-java-extensions-protobuf:extractIncludeProto
> Task :beam-sdks-java-extensions-protobuf:generateProto NO-SOURCE

> Task :beam-sdks-go:resolveBuildDependencies
Resolving golang.org/x/sys: commit='37707fdb30a5b38865cfb95e5aab41707daec7fd', urls=[https://go.googlesource.com/sys]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]

> Task :beam-vendor-sdks-java-extensions-protobuf:compileJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.

> Task :beam-sdks-java-extensions-protobuf:compileJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.

> Task :beam-sdks-java-extensions-protobuf:classes
> Task :beam-vendor-sdks-java-extensions-protobuf:classes

> Task :beam-sdks-java-fn-execution:compileJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

> Task :beam-sdks-java-fn-execution:classes

> Task :beam-sdks-java-extensions-google-cloud-platform-core:compileJava
Note: <https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/ws/src/sdks/java/extensions/google-cloud-platform-core/src/main/java/org/apache/beam/sdk/util/GcsUtil.java> uses or overrides a deprecated API.
Note: Recompile with -Xlint:deprecation for details.

> Task :beam-sdks-java-extensions-google-cloud-platform-core:classes
> Task :beam-vendor-sdks-java-extensions-protobuf:shadowJar
> Task :beam-sdks-java-extensions-protobuf:shadowJar
> Task :beam-sdks-java-fn-execution:shadowJar
> Task :beam-sdks-java-extensions-google-cloud-platform-core:shadowJar

> Task :beam-runners-core-construction-java:compileJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

> Task :beam-runners-core-construction-java:classes
> Task :beam-sdks-java-core:compileTestJava
> Task :beam-runners-core-construction-java:shadowJar

> Task :beam-sdks-java-io-google-cloud-platform:compileJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

> Task :beam-sdks-java-io-google-cloud-platform:classes
> Task :beam-sdks-java-io-google-cloud-platform:shadowJar

> Task :beam-sdks-java-core:compileTestJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

> Task :beam-sdks-java-core:testClasses

> Task :beam-runners-core-java:compileJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

> Task :beam-runners-core-construction-java:compileTestJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

> Task :beam-runners-core-construction-java:testClasses
> Task :beam-runners-core-java:classes
> Task :beam-runners-core-construction-java:shadowTestJar
> Task :beam-runners-core-java:shadowJar
> Task :beam-sdks-java-core:shadowTestJar

> Task :beam-sdks-java-harness:compileJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

> Task :beam-sdks-java-harness:classes
> Task :beam-sdks-java-harness:jar

> Task :beam-runners-core-java:compileTestJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

> Task :beam-runners-core-java:testClasses
> Task :beam-runners-core-java:shadowTestJar

> Task :beam-sdks-go:resolveBuildDependencies
Resolving google.golang.org/api: commit='386d4e5f4f92f86e6aec85985761bba4b938a2d5', urls=[https://code.googlesource.com/google-api-go-client]
Resolving google.golang.org/genproto: commit='2b5a72b8730b0b16380010cfe5286c42108d88e7', urls=[https://github.com/google/go-genproto]
Resolving google.golang.org/grpc: commit='7646b5360d049a7ca31e9133315db43456f39e2e', urls=[https://github.com/grpc/grpc-go]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]
Resolving cached github.com/coreos/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/coreos/etcd.git, git@github.com:coreos/etcd.git]

> Task :beam-sdks-java-harness:shadowJar
> Task :beam-sdks-java-container:copyDockerfileDependencies

> Task :beam-runners-java-fn-execution:compileJava
Note: <https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/ws/src/runners/java-fn-execution/src/main/java/org/apache/beam/runners/fnexecution/ServerFactory.java> uses or overrides a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

> Task :beam-runners-java-fn-execution:classes
> Task :beam-runners-java-fn-execution:shadowJar
> Task :beam-sdks-go:installDependencies
> Task :beam-runners-reference-java:compileJava
> Task :beam-runners-reference-java:classes
> Task :beam-runners-reference-java:shadowJar

> Task :beam-runners-reference-java:compileTestJava
Note: <https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/ws/src/runners/reference/java/src/test/java/org/apache/beam/runners/reference/CloseableResourceTest.java> uses or overrides a deprecated API.
Note: Recompile with -Xlint:deprecation for details.

> Task :beam-runners-reference-java:testClasses

> Task :beam-runners-flink_2.11:compileJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

> Task :beam-runners-flink_2.11:classes
> Task :beam-runners-reference-java:shadowTestJar
> Task :beam-runners-flink_2.11:shadowJar

> Task :beam-runners-flink_2.11:compileTestJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

> Task :beam-runners-flink_2.11:testClasses
> Task :beam-runners-flink_2.11:shadowTestJar
> Task :beam-sdks-go:buildLinuxAmd64
> Task :beam-sdks-go:build

> Task :beam-sdks-java-container:resolveBuildDependencies
Resolving ./github.com/apache/beam/sdks/go@<https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/ws/src/sdks/go>

> Task :beam-sdks-java-container:installDependencies
> Task :beam-sdks-java-container:buildLinuxAmd64
> Task :beam-sdks-java-container:build
> Task :beam-sdks-java-container:dockerPrepare
> Task :beam-sdks-java-container:docker
> Task :beam-runners-flink_2.11-job-server:validatesPortableRunnerStreaming

org.apache.beam.sdk.testing.PAssertTest > testWindowedIsEqualTo FAILED
    java.lang.AssertionError at PAssertTest.java:328

org.apache.beam.sdk.transforms.ParDoTest$StateTests > testBagStateSideInput FAILED
    java.lang.AssertionError at ParDoTest.java:2012

196 tests completed, 2 failed, 2 skipped

> Task :beam-runners-flink_2.11-job-server:validatesPortableRunnerStreaming FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':beam-runners-flink_2.11-job-server:validatesPortableRunnerStreaming'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/ws/src/runners/flink/job-server/build/reports/tests/validatesPortableRunnerStreaming/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 39m 53s
75 actionable tasks: 70 executed, 4 from cache, 1 up-to-date

Publishing build scan...
https://gradle.com/s/r32nduqmp54jg

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

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


Build failed in Jenkins: beam_PostCommit_Java_PVR_Flink_Streaming #341

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/341/display/redirect?page=changes>

Changes:

[ehudm] [BEAM-5959] Reorder methods according to convention

------------------------------------------
[...truncated 234.81 MB...]
    [ToKeyedWorkItem (6/16)] INFO org.apache.flink.runtime.taskmanager.Task - ToKeyedWorkItem (6/16) (10df18185925d9c3b7e4bcb6ed9927d4) switched from RUNNING to FINISHED.
    [ToKeyedWorkItem (3/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for ToKeyedWorkItem (3/16) (80c04dd6af8db4b1b9a5e161fc1ea25b).
    [ToKeyedWorkItem (6/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for ToKeyedWorkItem (6/16) (10df18185925d9c3b7e4bcb6ed9927d4).
    [ToKeyedWorkItem (3/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task ToKeyedWorkItem (3/16) (80c04dd6af8db4b1b9a5e161fc1ea25b) [FINISHED]
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem a9269cb1eac195b369029fdf024c2133.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (14/16) (2cc650c43b14332183b12e915c2f945f) switched from RUNNING to FINISHED.
    [ToKeyedWorkItem (6/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task ToKeyedWorkItem (6/16) (10df18185925d9c3b7e4bcb6ed9927d4) [FINISHED]
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem 80c04dd6af8db4b1b9a5e161fc1ea25b.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem 10df18185925d9c3b7e4bcb6ed9927d4.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (13/16) (18a388f8cd632ac399cf7787a4ca5366) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (3/16) (82a64ce643c4cf5200eb40fa3ffc45ba) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (6/16) (291c216245442fee5d65a3a9981b9a27) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (13/16) (a9269cb1eac195b369029fdf024c2133) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (3/16) (80c04dd6af8db4b1b9a5e161fc1ea25b) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (6/16) (10df18185925d9c3b7e4bcb6ed9927d4) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (7/16) (e8ca043fb127d4513c793b9623b2dd1b) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (7/16) (e8ca043fb127d4513c793b9623b2dd1b).
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (5/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (5/16) (0660f5bc1a1539448fe83a6f8c683a40) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (5/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (5/16) (0660f5bc1a1539448fe83a6f8c683a40).
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (7/16) (e8ca043fb127d4513c793b9623b2dd1b) [FINISHED]
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (5/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (5/16) (0660f5bc1a1539448fe83a6f8c683a40) [FINISHED]
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} e8ca043fb127d4513c793b9623b2dd1b.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (15/16) (a2699189dfe380255455880f7a53b090) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (15/16) (a2699189dfe380255455880f7a53b090).
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (15/16) (a2699189dfe380255455880f7a53b090) [FINISHED]
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (4/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (4/16) (8c88e50410d8a5a871c30fdbc4f1638e) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (4/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (4/16) (8c88e50410d8a5a871c30fdbc4f1638e).
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} 0660f5bc1a1539448fe83a6f8c683a40.
    [ToKeyedWorkItem (5/16)] INFO org.apache.flink.runtime.taskmanager.Task - ToKeyedWorkItem (5/16) (7c28bbb1d49be2f777eeda983ccf5ed3) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (1/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (1/16) (7d91cfea606498c9e60044d7090507f1) switched from RUNNING to FINISHED.
    [ToKeyedWorkItem (5/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for ToKeyedWorkItem (5/16) (7c28bbb1d49be2f777eeda983ccf5ed3).
    [ToKeyedWorkItem (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - ToKeyedWorkItem (7/16) (f7705a33df2d7def55bccb34a0f42af9) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (1/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (1/16) (7d91cfea606498c9e60044d7090507f1).
    [ToKeyedWorkItem (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for ToKeyedWorkItem (7/16) (f7705a33df2d7def55bccb34a0f42af9).
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (4/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (4/16) (8c88e50410d8a5a871c30fdbc4f1638e) [FINISHED]
    [ToKeyedWorkItem (5/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task ToKeyedWorkItem (5/16) (7c28bbb1d49be2f777eeda983ccf5ed3) [FINISHED]
    [ToKeyedWorkItem (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task ToKeyedWorkItem (7/16) (f7705a33df2d7def55bccb34a0f42af9) [FINISHED]
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} a2699189dfe380255455880f7a53b090.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (7/16) (e8ca043fb127d4513c793b9623b2dd1b) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (1/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (1/16) (7d91cfea606498c9e60044d7090507f1) [FINISHED]
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} 8c88e50410d8a5a871c30fdbc4f1638e.
    [ToKeyedWorkItem (1/16)] INFO org.apache.flink.runtime.taskmanager.Task - ToKeyedWorkItem (1/16) (39ada8cde4dc5f6c8d97f73773ea77f7) switched from RUNNING to FINISHED.
    [ToKeyedWorkItem (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - ToKeyedWorkItem (15/16) (7dd02d217611b560fe7e0abe5eba6907) switched from RUNNING to FINISHED.
    [ToKeyedWorkItem (4/16)] INFO org.apache.flink.runtime.taskmanager.Task - ToKeyedWorkItem (4/16) (98b30ef8f8a7581e5cc2a50d75b9c15d) switched from RUNNING to FINISHED.
    [ToKeyedWorkItem (1/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for ToKeyedWorkItem (1/16) (39ada8cde4dc5f6c8d97f73773ea77f7).
    [ToKeyedWorkItem (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for ToKeyedWorkItem (15/16) (7dd02d217611b560fe7e0abe5eba6907).
    [ToKeyedWorkItem (4/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for ToKeyedWorkItem (4/16) (98b30ef8f8a7581e5cc2a50d75b9c15d).
    [ToKeyedWorkItem (1/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task ToKeyedWorkItem (1/16) (39ada8cde4dc5f6c8d97f73773ea77f7) [FINISHED]
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (5/16) (0660f5bc1a1539448fe83a6f8c683a40) switched from RUNNING to FINISHED.
    [ToKeyedWorkItem (4/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task ToKeyedWorkItem (4/16) (98b30ef8f8a7581e5cc2a50d75b9c15d) [FINISHED]
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem 7c28bbb1d49be2f777eeda983ccf5ed3.
    [ToKeyedWorkItem (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task ToKeyedWorkItem (15/16) (7dd02d217611b560fe7e0abe5eba6907) [FINISHED]
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (15/16) (a2699189dfe380255455880f7a53b090) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem f7705a33df2d7def55bccb34a0f42af9.
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} 7d91cfea606498c9e60044d7090507f1.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (4/16) (8c88e50410d8a5a871c30fdbc4f1638e) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem 39ada8cde4dc5f6c8d97f73773ea77f7.
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem 98b30ef8f8a7581e5cc2a50d75b9c15d.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (5/16) (7c28bbb1d49be2f777eeda983ccf5ed3) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem 7dd02d217611b560fe7e0abe5eba6907.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (7/16) (f7705a33df2d7def55bccb34a0f42af9) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (1/16) (7d91cfea606498c9e60044d7090507f1) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (1/16) (39ada8cde4dc5f6c8d97f73773ea77f7) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (4/16) (98b30ef8f8a7581e5cc2a50d75b9c15d) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (15/16) (7dd02d217611b560fe7e0abe5eba6907) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (2/16) (a5e08a8088730cdc576d3966aac37d75) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (2/16) (a5e08a8088730cdc576d3966aac37d75).
    [PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (2/16) (a5e08a8088730cdc576d3966aac37d75) [FINISHED]
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} a5e08a8088730cdc576d3966aac37d75.
    [ToKeyedWorkItem (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - ToKeyedWorkItem (2/16) (8c6b2bad6b01888b0fd1db73f7cd99be) switched from RUNNING to FINISHED.
    [ToKeyedWorkItem (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for ToKeyedWorkItem (2/16) (8c6b2bad6b01888b0fd1db73f7cd99be).
    [ToKeyedWorkItem (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task ToKeyedWorkItem (2/16) (8c6b2bad6b01888b0fd1db73f7cd99be) [FINISHED]
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem 8c6b2bad6b01888b0fd1db73f7cd99be.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GatherAllOutputs/GroupByKey -> [6]PAssert$132/GroupGlobally/{GatherAllOutputs, RewindowActuals, KeyForDummy, RemoveActualsTriggering, FlattenDummyAndContents, NeverTrigger} (2/16) (a5e08a8088730cdc576d3966aac37d75) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (2/16) (8c6b2bad6b01888b0fd1db73f7cd99be) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (4/16)] WARN org.apache.flink.metrics.MetricGroup - Name collision: Group already contains a Metric with the name 'beam.metric:user:org.apache.beam.sdk.testing.PAssert:PAssertSuccess'. Metric will not be reported.[localhost, taskmanager, 4693d00c-be97-4752-8db7-1cd3d0728abb, reifytimestampstest0invaluessucceeds-jenkins-0103201315-de6f1c9b, [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions}, 3]
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (15/16) (089f80b13d5b99a1f91be9a3c763a002) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (15/16) (089f80b13d5b99a1f91be9a3c763a002).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (15/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (15/16) (089f80b13d5b99a1f91be9a3c763a002) [FINISHED]
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (8/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (8/16) (faf6d70ec3f7d757cf7b84c690ce5d04) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (8/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (8/16) (faf6d70ec3f7d757cf7b84c690ce5d04).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (8/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (8/16) (faf6d70ec3f7d757cf7b84c690ce5d04) [FINISHED]
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 089f80b13d5b99a1f91be9a3c763a002.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} faf6d70ec3f7d757cf7b84c690ce5d04.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (15/16) (089f80b13d5b99a1f91be9a3c763a002) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (1/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (1/16) (fa500075a383dc38650fc3d51df5c8c8) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (1/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (1/16) (fa500075a383dc38650fc3d51df5c8c8).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (1/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (1/16) (fa500075a383dc38650fc3d51df5c8c8) [FINISHED]
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} fa500075a383dc38650fc3d51df5c8c8.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (8/16) (faf6d70ec3f7d757cf7b84c690ce5d04) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (10/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (10/16) (32b0765e294904da706e13e3861351a7) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (10/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (10/16) (32b0765e294904da706e13e3861351a7).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (10/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (10/16) (32b0765e294904da706e13e3861351a7) [FINISHED]
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 32b0765e294904da706e13e3861351a7.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (11/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (11/16) (e2f9ef2090397ecbe33adb6da4ad60d4) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (11/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (11/16) (e2f9ef2090397ecbe33adb6da4ad60d4).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (11/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (11/16) (e2f9ef2090397ecbe33adb6da4ad60d4) [FINISHED]
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (9/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (9/16) (13b46440e7cde182e0be18f20922a21b) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (1/16) (fa500075a383dc38650fc3d51df5c8c8) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (9/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (9/16) (13b46440e7cde182e0be18f20922a21b).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (9/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (9/16) (13b46440e7cde182e0be18f20922a21b) [FINISHED]
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} e2f9ef2090397ecbe33adb6da4ad60d4.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (2/16) (a93e8a1f7987f9f51b227995b66c6046) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (2/16) (a93e8a1f7987f9f51b227995b66c6046).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (2/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (2/16) (a93e8a1f7987f9f51b227995b66c6046) [FINISHED]
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 13b46440e7cde182e0be18f20922a21b.
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (10/16) (32b0765e294904da706e13e3861351a7) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (6/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (6/16) (62db8702296dbca39f78ec443f538608) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (6/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (6/16) (62db8702296dbca39f78ec443f538608).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (6/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (6/16) (62db8702296dbca39f78ec443f538608) [FINISHED]
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} a93e8a1f7987f9f51b227995b66c6046.
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (11/16) (e2f9ef2090397ecbe33adb6da4ad60d4) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 62db8702296dbca39f78ec443f538608.
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (9/16) (13b46440e7cde182e0be18f20922a21b) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (16/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (16/16) (e1ca1569bbdb22f77a39684eae29aae1) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (16/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (16/16) (e1ca1569bbdb22f77a39684eae29aae1).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (16/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (16/16) (e1ca1569bbdb22f77a39684eae29aae1) [FINISHED]
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (2/16) (a93e8a1f7987f9f51b227995b66c6046) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} e1ca1569bbdb22f77a39684eae29aae1.
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (6/16) (62db8702296dbca39f78ec443f538608) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (13/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (13/16) (953d283556f4acbbc424fe51bd4a5c5d) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (13/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (13/16) (953d283556f4acbbc424fe51bd4a5c5d).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (13/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (13/16) (953d283556f4acbbc424fe51bd4a5c5d) [FINISHED]
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 953d283556f4acbbc424fe51bd4a5c5d.
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (16/16) (e1ca1569bbdb22f77a39684eae29aae1) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (7/16) (dfc0db971f9755b61a9139301a8852ab) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (3/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (3/16) (94d0fbed95b54ea2e3e027bee2cab55f) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (3/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (3/16) (94d0fbed95b54ea2e3e027bee2cab55f).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (7/16) (dfc0db971f9755b61a9139301a8852ab).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (3/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (3/16) (94d0fbed95b54ea2e3e027bee2cab55f) [FINISHED]
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (7/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (7/16) (dfc0db971f9755b61a9139301a8852ab) [FINISHED]
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 94d0fbed95b54ea2e3e027bee2cab55f.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} dfc0db971f9755b61a9139301a8852ab.
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (13/16) (953d283556f4acbbc424fe51bd4a5c5d) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (14/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (14/16) (01447a08c964984ba8a122d3fb6fc2ba) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (14/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (14/16) (01447a08c964984ba8a122d3fb6fc2ba).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (14/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (14/16) (01447a08c964984ba8a122d3fb6fc2ba) [FINISHED]
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (5/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (5/16) (a1e34bd885215ae27e3b824c99447e41) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 01447a08c964984ba8a122d3fb6fc2ba.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (12/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (12/16) (73ab34443ebd13f2726cf190096a0546) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (5/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (5/16) (a1e34bd885215ae27e3b824c99447e41).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (12/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (12/16) (73ab34443ebd13f2726cf190096a0546).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (5/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (5/16) (a1e34bd885215ae27e3b824c99447e41) [FINISHED]
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (12/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (12/16) (73ab34443ebd13f2726cf190096a0546) [FINISHED]
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (3/16) (94d0fbed95b54ea2e3e027bee2cab55f) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} a1e34bd885215ae27e3b824c99447e41.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 73ab34443ebd13f2726cf190096a0546.
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (7/16) (dfc0db971f9755b61a9139301a8852ab) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (14/16) (01447a08c964984ba8a122d3fb6fc2ba) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (5/16) (a1e34bd885215ae27e3b824c99447e41) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (12/16) (73ab34443ebd13f2726cf190096a0546) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (4/16)] INFO org.apache.flink.runtime.taskmanager.Task - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (4/16) (61755655ff8a02573826e0f80735b863) switched from RUNNING to FINISHED.
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (4/16)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (4/16) (61755655ff8a02573826e0f80735b863).
    [PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (4/16)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (4/16) (61755655ff8a02573826e0f80735b863) [FINISHED]
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} 61755655ff8a02573826e0f80735b863.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - PAssert$132/GroupGlobally/GroupDummyAndContents -> [5]PAssert$132/{GroupGlobally, GetPane, RunChecks, VerifyAssertions} (4/16) (61755655ff8a02573826e0f80735b863) switched from RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Job reifytimestampstest0invaluessucceeds-jenkins-0103201315-de6f1c9b (f524bb9909e27a033c00d1ab25e1874f) switched from state RUNNING to FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.checkpoint.CheckpointCoordinator - Stopping checkpoint coordinator for job f524bb9909e27a033c00d1ab25e1874f.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore - Shutting down
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.dispatcher.StandaloneDispatcher - Job f524bb9909e27a033c00d1ab25e1874f reached globally terminal state FINISHED.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.jobmaster.JobMaster - Stopping the JobMaster for job reifytimestampstest0invaluessucceeds-jenkins-0103201315-de6f1c9b(f524bb9909e27a033c00d1ab25e1874f).
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Close JobManager connection for job f524bb9909e27a033c00d1ab25e1874f.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.jobmaster.JobMaster - Close ResourceManager connection c3a1ff53e99768c4ce02c3ce6d693a72: JobManager is shutting down..
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.jobmaster.slotpool.SlotPool - Suspending SlotPool.
    [flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.jobmaster.slotpool.SlotPool - Stopping SlotPool.
    [flink-runner-job-server] INFO org.apache.flink.runtime.minicluster.MiniCluster - Shutting down Flink Mini Cluster
    [flink-runner-job-server] INFO org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint - Shutting down rest endpoint.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.resourcemanager.StandaloneResourceManager - Disconnect job manager 91b61f8b456a0f64fb072b3ac8854884@akka://flink/user/jobmanager_231 for job f524bb9909e27a033c00d1ab25e1874f from the resource manager.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - JobManager for job f524bb9909e27a033c00d1ab25e1874f with leader id 91b61f8b456a0f64fb072b3ac8854884 lost leadership.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:15, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{ba482e3a9097f8d96503bbb03a56eef5}, jobId: f524bb9909e27a033c00d1ab25e1874f).
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager - Closing the SlotManager.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.dispatcher.StandaloneDispatcher - Stopping dispatcher akka://flink/user/dispatcher3332f569-eed6-416d-a400-2fcb20c6faf0.
    [flink-akka.actor.default-dispatcher-6] INFO org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager - Suspending the SlotManager.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.dispatcher.StandaloneDispatcher - Stopping all currently running jobs of dispatcher akka://flink/user/dispatcher3332f569-eed6-416d-a400-2fcb20c6faf0.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:4, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{558e6f0a99c779d28fe1f49dda411f76}, jobId: f524bb9909e27a033c00d1ab25e1874f).
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:14, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{fec8239e78004f181d482fba9adde19e}, jobId: f524bb9909e27a033c00d1ab25e1874f).
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:0, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{d77a6ea42763e8a59f4c89bb6c57650d}, jobId: f524bb9909e27a033c00d1ab25e1874f).
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:13, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{8a5838843c4f39429c166ca6c1ba049f}, jobId: f524bb9909e27a033c00d1ab25e1874f).
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:8, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{96c7deb6c72935016af63eb8c8b39d26}, jobId: f524bb9909e27a033c00d1ab25e1874f).
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:5, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{74bbe876832e21a98688594b33f350b3}, jobId: f524bb9909e27a033c00d1ab25e1874f).
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:1, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{249bcd94a1a3b4668e1d5e8ccd301920}, jobId: f524bb9909e27a033c00d1ab25e1874f).
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:7, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{e925520ae9fe6bef28f14b418d1d7928}, jobId: f524bb9909e27a033c00d1ab25e1874f).
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:12, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{3e93ab0e914eec31835cb87a00660a84}, jobId: f524bb9909e27a033c00d1ab25e1874f).
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:11, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{5dacbea6e103df960ce74bf462366e3b}, jobId: f524bb9909e27a033c00d1ab25e1874f).
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:10, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{4cb32206be6509122dbca578c6b8c98e}, jobId: f524bb9909e27a033c00d1ab25e1874f).
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:3, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{8dde681291d19bb5bd7ec4bcccef3fa3}, jobId: f524bb9909e27a033c00d1ab25e1874f).
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:6, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{ed4b8404ac745fe7dace4a0d41e40ef8}, jobId: f524bb9909e27a033c00d1ab25e1874f).
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:2, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{1d7bf494511aa275e58b0c67c600c155}, jobId: f524bb9909e27a033c00d1ab25e1874f).
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:9, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{3f154c8a0f52dd986851c53ef090fbdf}, jobId: f524bb9909e27a033c00d1ab25e1874f).
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.JobLeaderService - Remove job f524bb9909e27a033c00d1ab25e1874f from job leader monitoring.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Close JobManager connection for job f524bb9909e27a033c00d1ab25e1874f.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Stopping TaskExecutor akka://flink/user/taskmanager_230.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager - Shutting down TaskExecutorLocalStateStoresManager.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator - Shutting down stack trace sample coordinator.
    [flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.dispatcher.StandaloneDispatcher - Stopped dispatcher akka://flink/user/dispatcher3332f569-eed6-416d-a400-2fcb20c6faf0.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.io.disk.iomanager.IOManager - I/O manager removed spill file directory /tmp/flink-io-a852f7d2-302b-41e5-8227-92b2d50fe427
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.io.network.NetworkEnvironment - Shutting down the network environment and its components.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.JobLeaderService - Stop job leader service.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Stopped TaskExecutor akka://flink/user/taskmanager_230.
    [ForkJoinPool.commonPool-worker-2] INFO org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint - Removing cache directory /tmp/flink-web-ui
    [ForkJoinPool.commonPool-worker-2] INFO org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint - Shut down complete.
    [ForkJoinPool.commonPool-worker-2] INFO org.apache.flink.runtime.rpc.akka.AkkaRpcService - Stopping Akka RPC service.
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.blob.PermanentBlobCache - Shutting down BLOB cache
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.blob.TransientBlobCache - Shutting down BLOB cache
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:43095
    [flink-akka.actor.default-dispatcher-7] INFO org.apache.flink.runtime.rpc.akka.AkkaRpcService - Stopped Akka RPC service.
    [flink-runner-job-server] INFO org.apache.beam.runners.flink.FlinkRunner - Execution finished in 9835 msecs
    [flink-runner-job-server] INFO org.apache.beam.runners.flink.FlinkRunner - Final accumulator values:
    [flink-runner-job-server] INFO org.apache.beam.runners.flink.FlinkRunner - __metricscontainers : org.apache.beam.runners.core.metrics.MetricsContainerStepMap@60d8a67c
    [flink-runner-job-server] INFO org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService - Manifest at /tmp/beam-artifact-staging/reifytimestampstest0invaluessucceeds-jenkins-0103201315-de6f1c9b_87fd7a8d-bd31-4013-a91f-58488aaab88e/MANIFEST has 186 artifact locations
    [flink-runner-job-server] INFO org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactStagingService - Removed dir /tmp/beam-artifact-staging/reifytimestampstest0invaluessucceeds-jenkins-0103201315-de6f1c9b_87fd7a8d-bd31-4013-a91f-58488aaab88e/
    [Test worker] INFO org.apache.beam.runners.flink.FlinkJobServerDriver - JobServer stopped on localhost:44075
    [Test worker] INFO org.apache.beam.runners.flink.FlinkJobServerDriver - ArtifactStagingServer stopped on localhost:35825

Gradle Test Executor 1 finished executing tests.

> Task :beam-runners-flink_2.11-job-server:validatesPortableRunnerStreaming

196 tests completed, 3 failed, 2 skipped
Finished generating test XML results (1.455 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/ws/src/runners/flink/job-server/build/test-results/validatesPortableRunnerStreaming>
Generating HTML test report...
Finished generating test html results (0.942 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/ws/src/runners/flink/job-server/build/reports/tests/validatesPortableRunnerStreaming>

> Task :beam-runners-flink_2.11-job-server:validatesPortableRunnerStreaming FAILED
:beam-runners-flink_2.11-job-server:validatesPortableRunnerStreaming (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 37 mins 2.239 secs.

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':beam-runners-flink_2.11-job-server:validatesPortableRunnerStreaming'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/ws/src/runners/flink/job-server/build/reports/tests/validatesPortableRunnerStreaming/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --debug option to get more log output. Run with --scan to get full insights.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 39m 45s
75 actionable tasks: 70 executed, 4 from cache, 1 up-to-date

Publishing build scan...
https://gradle.com/s/qcjexrdn7tndc

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

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