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

Build failed in Jenkins: beam_PostCommit_PortableJar_Flink #3068

See <https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/3068/display/redirect?page=changes>

Changes:

[Boyuan Zhang] Cache UnboundedReader per CheckpointMark in SDF Wrapper DoFn.


------------------------------------------
[...truncated 1.99 MB...]
Dec 26, 2020 12:26:40 AM org.apache.flink.runtime.taskmanager.Task doRun
INFO: Ensuring all FileSystem streams are closed for task MapPartition (MapPartition at [3]assert_that/{Group, Unkey, Match}) (1/1) (98561593da4f70f900ad950911c15c31) [FINISHED]
Dec 26, 2020 12:26:40 AM org.apache.flink.runtime.executiongraph.Execution transitionState
INFO: DataSink (DiscardingOutput) (1/1) (745e672884fb6e4c48595cce0b9ecbc3) switched from SCHEDULED to DEPLOYING.
Dec 26, 2020 12:26:40 AM org.apache.flink.runtime.taskexecutor.TaskExecutor unregisterTaskAndNotifyFinalState
INFO: Un-registering task and sending final execution state FINISHED to JobManager for task MapPartition (MapPartition at [3]assert_that/{Group, Unkey, Match}) (1/1) 98561593da4f70f900ad950911c15c31.
Dec 26, 2020 12:26:40 AM org.apache.flink.runtime.executiongraph.Execution deploy
INFO: Deploying DataSink (DiscardingOutput) (1/1) (attempt #0) to 0e60af99-6e09-415d-938c-6d0811b196d5 @ localhost (dataPort=-1)
Dec 26, 2020 12:26:40 AM org.apache.flink.runtime.taskexecutor.TaskExecutor submitTask
INFO: Received task DataSink (DiscardingOutput) (1/1).
Dec 26, 2020 12:26:40 AM org.apache.flink.runtime.executiongraph.Execution transitionState
INFO: MapPartition (MapPartition at [3]assert_that/{Group, Unkey, Match}) (1/1) (98561593da4f70f900ad950911c15c31) switched from RUNNING to FINISHED.
Dec 26, 2020 12:26:40 AM org.apache.flink.runtime.taskmanager.Task transitionState
INFO: DataSink (DiscardingOutput) (1/1) (745e672884fb6e4c48595cce0b9ecbc3) switched from CREATED to DEPLOYING.
Dec 26, 2020 12:26:40 AM org.apache.flink.runtime.taskmanager.Task doRun
INFO: Creating FileSystem stream leak safety net for task DataSink (DiscardingOutput) (1/1) (745e672884fb6e4c48595cce0b9ecbc3) [DEPLOYING]
Dec 26, 2020 12:26:40 AM org.apache.flink.runtime.taskmanager.Task doRun
INFO: Loading JAR files for task DataSink (DiscardingOutput) (1/1) (745e672884fb6e4c48595cce0b9ecbc3) [DEPLOYING].
Dec 26, 2020 12:26:40 AM org.apache.flink.runtime.taskmanager.Task doRun
INFO: Registering task at network: DataSink (DiscardingOutput) (1/1) (745e672884fb6e4c48595cce0b9ecbc3) [DEPLOYING].
Dec 26, 2020 12:26:40 AM org.apache.flink.runtime.taskmanager.Task transitionState
INFO: DataSink (DiscardingOutput) (1/1) (745e672884fb6e4c48595cce0b9ecbc3) switched from DEPLOYING to RUNNING.
Dec 26, 2020 12:26:40 AM org.apache.flink.runtime.executiongraph.Execution transitionState
INFO: DataSink (DiscardingOutput) (1/1) (745e672884fb6e4c48595cce0b9ecbc3) switched from DEPLOYING to RUNNING.
Exception in thread "grpc-nio-worker-ELG-3-3" Exception in thread "grpc-nio-worker-ELG-3-1" Exception in thread "grpc-nio-worker-ELG-3-4" Exception in thread "grpc-nio-worker-ELG-3-6" Exception in thread "grpc-nio-worker-ELG-3-5" java.lang.IllegalAccessError: tried to access class org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena$1 from class org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena.freeChunk(PoolArena.java:296)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.freeEntry(PoolThreadCache.java:464)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.free(PoolThreadCache.java:430)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.free(PoolThreadCache.java:422)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:279)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:270)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:241)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PooledByteBufAllocator$PoolThreadLocalCache.onRemoval(PooledByteBufAllocator.java:477)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PooledByteBufAllocator$PoolThreadLocalCache.onRemoval(PooledByteBufAllocator.java:444)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocal.remove(FastThreadLocal.java:256)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocal.removeAll(FastThreadLocal.java:67)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.SingleThreadEventExecutor$6.run(SingleThreadEventExecutor.java:1081)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.internal.ThreadExecutorMap$2.run(ThreadExecutorMap.java:74)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocalRunnable.run(FastThreadLocalRunnable.java:30)
	at java.lang.Thread.run(Thread.java:748)
java.lang.IllegalAccessError: tried to access class org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena$1 from class org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena.freeChunk(PoolArena.java:296)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.freeEntry(PoolThreadCache.java:464)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.free(PoolThreadCache.java:430)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.free(PoolThreadCache.java:422)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:279)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:270)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:241)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PooledByteBufAllocator$PoolThreadLocalCache.onRemoval(PooledByteBufAllocator.java:477)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PooledByteBufAllocator$PoolThreadLocalCache.onRemoval(PooledByteBufAllocator.java:444)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocal.remove(FastThreadLocal.java:256)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocal.removeAll(FastThreadLocal.java:67)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.SingleThreadEventExecutor$6.run(SingleThreadEventExecutor.java:1081)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.internal.ThreadExecutorMap$2.run(ThreadExecutorMap.java:74)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocalRunnable.run(FastThreadLocalRunnable.java:30)
	at java.lang.Thread.run(Thread.java:748)
java.lang.IllegalAccessError: tried to access class org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena$1 from class org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena.freeChunk(PoolArena.java:296)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.freeEntry(PoolThreadCache.java:464)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.free(PoolThreadCache.java:430)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.free(PoolThreadCache.java:422)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:279)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:270)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:241)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PooledByteBufAllocator$PoolThreadLocalCache.onRemoval(PooledByteBufAllocator.java:477)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PooledByteBufAllocator$PoolThreadLocalCache.onRemoval(PooledByteBufAllocator.java:444)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocal.remove(FastThreadLocal.java:256)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocal.removeAll(FastThreadLocal.java:67)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.SingleThreadEventExecutor$6.run(SingleThreadEventExecutor.java:1081)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.internal.ThreadExecutorMap$2.run(ThreadExecutorMap.java:74)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocalRunnable.run(FastThreadLocalRunnable.java:30)
	at java.lang.Thread.run(Thread.java:748)
java.lang.IllegalAccessError: tried to access class org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena$1 from class org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena.freeChunk(PoolArena.java:296)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.freeEntry(PoolThreadCache.java:464)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.free(PoolThreadCache.java:430)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.free(PoolThreadCache.java:422)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:279)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:270)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:241)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PooledByteBufAllocator$PoolThreadLocalCache.onRemoval(PooledByteBufAllocator.java:477)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PooledByteBufAllocator$PoolThreadLocalCache.onRemoval(PooledByteBufAllocator.java:444)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocal.remove(FastThreadLocal.java:256)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocal.removeAll(FastThreadLocal.java:67)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.SingleThreadEventExecutor$6.run(SingleThreadEventExecutor.java:1081)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.internal.ThreadExecutorMap$2.run(ThreadExecutorMap.java:74)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocalRunnable.run(FastThreadLocalRunnable.java:30)
	at java.lang.Thread.run(Thread.java:748)
java.lang.IllegalAccessError: tried to access class org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena$1 from class org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena.freeChunk(PoolArena.java:296)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.freeEntry(PoolThreadCache.java:464)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.free(PoolThreadCache.java:430)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.free(PoolThreadCache.java:422)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:279)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:270)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:241)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PooledByteBufAllocator$PoolThreadLocalCache.onRemoval(PooledByteBufAllocator.java:477)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PooledByteBufAllocator$PoolThreadLocalCache.onRemoval(PooledByteBufAllocator.java:444)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocal.remove(FastThreadLocal.java:256)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocal.removeAll(FastThreadLocal.java:67)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.SingleThreadEventExecutor$6.run(SingleThreadEventExecutor.java:1081)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.internal.ThreadExecutorMap$2.run(ThreadExecutorMap.java:74)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocalRunnable.run(FastThreadLocalRunnable.java:30)
	at java.lang.Thread.run(Thread.java:748)
Exception in thread "grpc-nio-worker-ELG-3-2" java.lang.IllegalAccessError: tried to access class org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena$1 from class org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolArena.freeChunk(PoolArena.java:296)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.freeEntry(PoolThreadCache.java:464)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.free(PoolThreadCache.java:430)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache$MemoryRegionCache.free(PoolThreadCache.java:422)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:279)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:270)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PoolThreadCache.free(PoolThreadCache.java:241)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PooledByteBufAllocator$PoolThreadLocalCache.onRemoval(PooledByteBufAllocator.java:477)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.buffer.PooledByteBufAllocator$PoolThreadLocalCache.onRemoval(PooledByteBufAllocator.java:444)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocal.remove(FastThreadLocal.java:256)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocal.removeAll(FastThreadLocal.java:67)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.SingleThreadEventExecutor$6.run(SingleThreadEventExecutor.java:1081)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.internal.ThreadExecutorMap$2.run(ThreadExecutorMap.java:74)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocalRunnable.run(FastThreadLocalRunnable.java:30)
	at java.lang.Thread.run(Thread.java:748)
Dec 26, 2020 12:26:41 AM org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.DefaultPromise safeExecute
SEVERE: Failed to submit a listener notification task. Event loop shut down?
java.lang.IllegalAccessError: tried to access class org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.GlobalEventExecutor$2 from class org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.GlobalEventExecutor
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.GlobalEventExecutor.startThread(GlobalEventExecutor.java:227)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.GlobalEventExecutor.execute(GlobalEventExecutor.java:215)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.DefaultPromise.safeExecute(DefaultPromise.java:841)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.DefaultPromise.notifyListeners(DefaultPromise.java:498)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.DefaultPromise.setValue0(DefaultPromise.java:615)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.DefaultPromise.setSuccess0(DefaultPromise.java:604)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.DefaultPromise.setSuccess(DefaultPromise.java:96)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.SingleThreadEventExecutor$6.run(SingleThreadEventExecutor.java:1089)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.internal.ThreadExecutorMap$2.run(ThreadExecutorMap.java:74)
	at org.apache.beam.vendor.grpc.v1p26p0.io.netty.util.concurrent.FastThreadLocalRunnable.run(FastThreadLocalRunnable.java:30)
	at java.lang.Thread.run(Thread.java:748)

Dec 26, 2020 12:26:41 AM org.apache.flink.runtime.taskmanager.Task transitionState
INFO: DataSink (DiscardingOutput) (1/1) (745e672884fb6e4c48595cce0b9ecbc3) switched from RUNNING to FINISHED.
Dec 26, 2020 12:26:41 AM org.apache.flink.runtime.taskmanager.Task doRun
INFO: Freeing task resources for DataSink (DiscardingOutput) (1/1) (745e672884fb6e4c48595cce0b9ecbc3).
Dec 26, 2020 12:26:41 AM org.apache.flink.runtime.taskmanager.Task doRun
INFO: Ensuring all FileSystem streams are closed for task DataSink (DiscardingOutput) (1/1) (745e672884fb6e4c48595cce0b9ecbc3) [FINISHED]
Dec 26, 2020 12:26:41 AM org.apache.flink.runtime.taskexecutor.TaskExecutor unregisterTaskAndNotifyFinalState
INFO: Un-registering task and sending final execution state FINISHED to JobManager for task DataSink (DiscardingOutput) (1/1) 745e672884fb6e4c48595cce0b9ecbc3.
Dec 26, 2020 12:26:41 AM org.apache.flink.runtime.executiongraph.Execution transitionState
INFO: DataSink (DiscardingOutput) (1/1) (745e672884fb6e4c48595cce0b9ecbc3) switched from RUNNING to FINISHED.
Dec 26, 2020 12:26:41 AM org.apache.flink.runtime.executiongraph.ExecutionGraph transitionState
INFO: Job Flink Java Job at Sat Dec 26 00:26:09 UTC 2020 (05760e1ad54aa92739ded489d7638e0f) switched from state RUNNING to FINISHED.
Dec 26, 2020 12:26:42 AM org.apache.flink.runtime.dispatcher.Dispatcher jobReachedGloballyTerminalState
INFO: Job 05760e1ad54aa92739ded489d7638e0f reached globally terminal state FINISHED.
Dec 26, 2020 12:26:42 AM org.apache.flink.runtime.jobmaster.JobMaster onStop
INFO: Stopping the JobMaster for job Flink Java Job at Sat Dec 26 00:26:09 UTC 2020(05760e1ad54aa92739ded489d7638e0f).
Dec 26, 2020 12:26:42 AM org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl suspend
INFO: Suspending SlotPool.
Dec 26, 2020 12:26:42 AM org.apache.flink.runtime.jobmaster.JobMaster dissolveResourceManagerConnection
INFO: Close ResourceManager connection b1629fc028c8968da4a03586cf732954: JobManager is shutting down..
Dec 26, 2020 12:26:42 AM org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl close
INFO: Stopping SlotPool.
Dec 26, 2020 12:26:42 AM org.apache.flink.runtime.resourcemanager.ResourceManager closeJobManagerConnection
INFO: Disconnect job manager 99db4882c501c7fd55622f830d814e20@akka://flink/user/jobmanager_1 for job 05760e1ad54aa92739ded489d7638e0f from the resource manager.
Dec 26, 2020 12:26:42 AM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:0, state:ACTIVE, resource profile: ResourceProfile{managedMemory=128.000mb (134217728 bytes), networkMemory=64.000mb (67108864 bytes)}, allocationId: a7fa53ab3b3b3ef1b96d13bd1f09724e, jobId: 05760e1ad54aa92739ded489d7638e0f).
Dec 26, 2020 12:26:42 AM org.apache.flink.runtime.taskexecutor.TaskExecutor$JobLeaderListenerImpl jobManagerLostLeadership
INFO: JobManager for job 05760e1ad54aa92739ded489d7638e0f with leader id 99db4882c501c7fd55622f830d814e20 lost leadership.
Dec 26, 2020 12:26:42 AM org.apache.flink.runtime.taskexecutor.JobLeaderService removeJob
INFO: Remove job 05760e1ad54aa92739ded489d7638e0f from job leader monitoring.
Dec 26, 2020 12:26:42 AM org.apache.flink.runtime.taskexecutor.TaskExecutor closeJobManagerConnection
INFO: Close JobManager connection for job 05760e1ad54aa92739ded489d7638e0f.
Dec 26, 2020 12:26:42 AM org.apache.flink.runtime.taskexecutor.TaskExecutor closeJobManagerConnection
INFO: Close JobManager connection for job 05760e1ad54aa92739ded489d7638e0f.
Dec 26, 2020 12:26:42 AM org.apache.flink.runtime.taskexecutor.JobLeaderService reconnect
INFO: Cannot reconnect to job 05760e1ad54aa92739ded489d7638e0f because it is not registered.
Dec 26, 2020 12:26:42 AM org.apache.flink.runtime.taskexecutor.TaskExecutor closeJobManagerConnection
INFO: Close JobManager connection for job 05760e1ad54aa92739ded489d7638e0f.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to DONE

kill %1 || echo "Failed to shut down Flink mini cluster"

rm -rf "$ENV_DIR"
Dec 26, 2020 12:26:44 AM org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager shutdown
INFO: Shutting down TaskExecutorLocalStateStoresManager.

if [[ "$TEST_EXIT_CODE" -eq 0 ]]; then
  echo ">>> SUCCESS"
else
  echo ">>> FAILURE"
>>> SUCCESS
fi
exit $TEST_EXIT_CODE

> Task :sdks:python:test-suites:portable:py36:testUberJarFlinkRunnerSaveMainSession
INFO:apache_beam.runners.portability.portable_runner:Job state changed to DONE

kill %1 || echo "Failed to shut down Flink mini cluster"

rm -rf "$ENV_DIR"
Dec 26, 2020 12:26:50 AM org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager shutdown
INFO: Shutting down TaskExecutorLocalStateStoresManager.

>>> SUCCESS
if [[ "$TEST_EXIT_CODE" -eq 0 ]]; then
  echo ">>> SUCCESS"
else
  echo ">>> FAILURE"
fi
exit $TEST_EXIT_CODE

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 202

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:testJavaJarCreatorFlinkRunner'.
> Process 'command 'sh'' finished with non-zero exit value 1

* 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.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 202

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py36:testJavaJarCreatorFlinkRunner'.
> Process 'command 'sh'' finished with non-zero exit value 1

* 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 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.7.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 26m 27s
157 actionable tasks: 139 executed, 15 from cache, 3 up-to-date
Gradle was unable to watch the file system for changes. The inotify watches limit is too low.

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

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


Jenkins build is back to normal : beam_PostCommit_PortableJar_Flink #3069

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/3069/display/redirect>


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