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/04/18 00:38:32 UTC

Build failed in Jenkins: beam_PostCommit_Python35_VR_Flink #1871

See <https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/1871/display/redirect>

Changes:


------------------------------------------
[...truncated 8.13 MB...]
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$LocalLoadingCache.get(LocalCache.java:4958)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$LocalLoadingCache.getUnchecked(LocalCache.java:4964)
	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$SimpleStageBundleFactory.<init>(DefaultJobBundleFactory.java:445)
	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$SimpleStageBundleFactory.<init>(DefaultJobBundleFactory.java:430)
	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory.forStage(DefaultJobBundleFactory.java:297)
	at org.apache.beam.runners.fnexecution.control.DefaultExecutableStageContext.getStageBundleFactory(DefaultExecutableStageContext.java:38)
	at org.apache.beam.runners.fnexecution.control.ReferenceCountingExecutableStageContextFactory$WrappedContext.getStageBundleFactory(ReferenceCountingExecutableStageContextFactory.java:198)
	at org.apache.beam.runners.flink.translation.wrappers.streaming.ExecutableStageDoFnOperator.open(ExecutableStageDoFnOperator.java:204)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.initializeStateAndOpen(StreamTask.java:1007)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.lambda$beforeInvoke$0(StreamTask.java:454)
	at org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor$SynchronizedStreamTaskActionExecutor.runThrowing(StreamTaskActionExecutor.java:94)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.beforeInvoke(StreamTask.java:449)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:461)
	at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:707)
	at org.apache.flink.runtime.taskmanager.Task.run(Task.java:532)
	at java.lang.Thread.run(Thread.java:748)

INFO:apache_beam.runners.worker.statecache:Creating state cache with size 0
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure control channel for localhost:35959.
INFO:apache_beam.runners.worker.sdk_worker:Control channel established.
INFO:apache_beam.runners.worker.sdk_worker:Initializing SDKHarness with unbounded number of workers.
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure state channel for localhost:40039.
INFO:apache_beam.runners.worker.sdk_worker:State channel established.
INFO:apache_beam.runners.worker.data_plane:Creating client data channel for 
ERROR:apache_beam.runners.worker.data_plane:Failed to read inputs in the data plane.
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 528, in _read_inputs
    for elements in elements_iterator:
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 416, in __next__
    return self._next()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 689, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "DNS resolution failed"
	debug_error_string = "{"created":"@1587170306.479109662","description":"Failed to pick subchannel","file":"src/core/ext/filters/client_channel/client_channel.cc","file_line":3981,"referenced_errors":[{"created":"@1587170306.479104980","description":"Resolver transient failure","file":"src/core/ext/filters/client_channel/resolving_lb_policy.cc","file_line":214,"referenced_errors":[{"created":"@1587170306.479102842","description":"DNS resolution failed","file":"src/core/ext/filters/client_channel/resolver/dns/c_ares/dns_resolver_ares.cc","file_line":357,"grpc_status":14,"referenced_errors":[{"created":"@1587170306.479093848","description":"C-ares status is not ARES_SUCCESS: Misformatted domain name","file":"src/core/ext/filters/client_channel/resolver/dns/c_ares/grpc_ares_wrapper.cc","file_line":244,"referenced_errors":[{"created":"@1587170306.479068862","description":"C-ares status is not ARES_SUCCESS: Misformatted domain name","file":"src/core/ext/filters/client_channel/resolver/dns/c_ares/grpc_ares_wrapper.cc","file_line":244}]}]}]}]}"
>
INFO:apache_beam.runners.worker.data_plane:Creating client data channel for localhost:46429
[assert_that/Group/GroupByKey -> [3]assert_that/{Group, Unkey, Match} (1/2)] WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer - Hanged up for unknown endpoint.
Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.5/threading.py", line 914, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.5/threading.py", line 862, in run
    self._target(*self._args, **self._kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 545, in <lambda>
    target=lambda: self._read_inputs(elements_iterator),
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 528, in _read_inputs
    for elements in elements_iterator:
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 416, in __next__
    return self._next()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 689, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "DNS resolution failed"
	debug_error_string = "{"created":"@1587170306.479109662","description":"Failed to pick subchannel","file":"src/core/ext/filters/client_channel/client_channel.cc","file_line":3981,"referenced_errors":[{"created":"@1587170306.479104980","description":"Resolver transient failure","file":"src/core/ext/filters/client_channel/resolving_lb_policy.cc","file_line":214,"referenced_errors":[{"created":"@1587170306.479102842","description":"DNS resolution failed","file":"src/core/ext/filters/client_channel/resolver/dns/c_ares/dns_resolver_ares.cc","file_line":357,"grpc_status":14,"referenced_errors":[{"created":"@1587170306.479093848","description":"C-ares status is not ARES_SUCCESS: Misformatted domain name","file":"src/core/ext/filters/client_channel/resolver/dns/c_ares/grpc_ares_wrapper.cc","file_line":244,"referenced_errors":[{"created":"@1587170306.479068862","description":"C-ares status is not ARES_SUCCESS: Misformatted domain name","file":"src/core/ext/filters/client_channel/resolver/dns/c_ares/grpc_ares_wrapper.cc","file_line":244}]}]}]}]}"
>

INFO:apache_beam.runners.worker.sdk_worker:No more requests from control plane
INFO:apache_beam.runners.worker.sdk_worker:SDK Harness waiting for in-flight requests to complete
INFO:apache_beam.runners.worker.data_plane:Closing all cached grpc data channels.
INFO:apache_beam.runners.worker.sdk_worker:Closing all cached gRPC state handlers.
INFO:apache_beam.runners.worker.sdk_worker:Done consuming work.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to DONE
.INFO:apache_beam.runners.worker.worker_pool_main:Listening for workers at localhost:40949
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.5 interpreter.
INFO:root:Using Python SDK docker image: apache/beam_python3.5_sdk:2.22.0.dev. If the image is not available at local, we will try to pull from hub.docker.com
ERROR:grpc._channel:Exception iterating requests!
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 195, in consume_request_iterator
    request = next(request_iterator)
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/artifact_service.py",> line 316, in __next__
    raise self._queue.get()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner.py",> line 192, in stage
    return self._stage_via_portable_service(channel, staging_session_token)
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner.py",> line 210, in _stage_via_portable_service
    staging_session_token)
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/artifact_service.py",> line 506, in offer_artifacts
    for request in requests:
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 416, in __next__
    return self._next()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 706, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNIMPLEMENTED
	details = "Method not found: org.apache.beam.model.job_management.v1.ArtifactStagingService/ReverseArtifactRetrievalService"
	debug_error_string = "{"created":"@1587170307.497507225","description":"Error received from peer ipv4:127.0.0.1:40887","file":"src/core/lib/surface/call.cc","file_line":1056,"grpc_message":"Method not found: org.apache.beam.model.job_management.v1.ArtifactStagingService/ReverseArtifactRetrievalService","grpc_status":12}"
>
INFO:apache_beam.runners.portability.portable_runner:Waiting until the pipeline has finished because the environment "LOOPBACK" has started a component necessary for the execution.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to STOPPED
INFO:apache_beam.runners.portability.portable_runner:Job state changed to STARTING
INFO:apache_beam.runners.portability.portable_runner:Job state changed to RUNNING
[flink-runner-job-invoker] WARN org.apache.flink.runtime.webmonitor.WebMonitorUtils - Log file environment variable 'log.file' is not set.
[flink-runner-job-invoker] WARN org.apache.flink.runtime.webmonitor.WebMonitorUtils - JobManager log files are unavailable in the web dashboard. Log file location not found in environment variable 'log.file' or configuration key 'Key: 'web.log.path' , default: null (fallback keys: [{key=jobmanager.web.log.path, isDeprecated=true}])'.
Apr 18, 2020 12:38:27 AM org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.ManagedChannelOrphanWrapper$ManagedChannelReference cleanQueue
SEVERE: *~*~*~ Channel ManagedChannelImpl{logId=879, target=localhost:44727} was not shutdown properly!!! ~*~*~*
    Make sure to call shutdown()/shutdownNow() and wait until awaitTermination() returns true.
java.lang.RuntimeException: ManagedChannel allocation site
	at org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.ManagedChannelOrphanWrapper$ManagedChannelReference.<init>(ManagedChannelOrphanWrapper.java:94)
	at org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.ManagedChannelOrphanWrapper.<init>(ManagedChannelOrphanWrapper.java:52)
	at org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.ManagedChannelOrphanWrapper.<init>(ManagedChannelOrphanWrapper.java:43)
	at org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.AbstractManagedChannelImplBuilder.build(AbstractManagedChannelImplBuilder.java:524)
	at org.apache.beam.sdk.fn.channel.ManagedChannelFactory.forDescriptor(ManagedChannelFactory.java:44)
	at org.apache.beam.runners.fnexecution.environment.ExternalEnvironmentFactory$1.close(ExternalEnvironmentFactory.java:155)
	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$WrappedSdkHarnessClient.$closeResource(DefaultJobBundleFactory.java:622)
	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$WrappedSdkHarnessClient.close(DefaultJobBundleFactory.java:622)
	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$WrappedSdkHarnessClient.unref(DefaultJobBundleFactory.java:638)
	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$WrappedSdkHarnessClient.access$400(DefaultJobBundleFactory.java:569)
	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory.lambda$createEnvironmentCaches$3(DefaultJobBundleFactory.java:211)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache.processPendingNotifications(LocalCache.java:1809)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$Segment.runUnlockedCleanup(LocalCache.java:3462)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$Segment.postWriteCleanup(LocalCache.java:3438)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$Segment.clear(LocalCache.java:3215)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache.clear(LocalCache.java:4270)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$LocalManualCache.invalidateAll(LocalCache.java:4909)
	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory.close(DefaultJobBundleFactory.java:313)
	at org.apache.beam.runners.fnexecution.control.DefaultExecutableStageContext.close(DefaultExecutableStageContext.java:43)
	at org.apache.beam.runners.fnexecution.control.ReferenceCountingExecutableStageContextFactory$WrappedContext.closeActual(ReferenceCountingExecutableStageContextFactory.java:208)
	at org.apache.beam.runners.fnexecution.control.ReferenceCountingExecutableStageContextFactory$WrappedContext.access$200(ReferenceCountingExecutableStageContextFactory.java:184)
	at org.apache.beam.runners.fnexecution.control.ReferenceCountingExecutableStageContextFactory.release(ReferenceCountingExecutableStageContextFactory.java:173)
	at org.apache.beam.runners.fnexecution.control.ReferenceCountingExecutableStageContextFactory.scheduleRelease(ReferenceCountingExecutableStageContextFactory.java:132)
	at org.apache.beam.runners.fnexecution.control.ReferenceCountingExecutableStageContextFactory.access$300(ReferenceCountingExecutableStageContextFactory.java:44)
	at org.apache.beam.runners.fnexecution.control.ReferenceCountingExecutableStageContextFactory$WrappedContext.close(ReferenceCountingExecutableStageContextFactory.java:204)
	at org.apache.beam.runners.flink.translation.wrappers.streaming.ExecutableStageDoFnOperator.$closeResource(ExecutableStageDoFnOperator.java:459)
	at org.apache.beam.runners.flink.translation.wrappers.streaming.ExecutableStageDoFnOperator.dispose(ExecutableStageDoFnOperator.java:486)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.disposeAllOperators(StreamTask.java:664)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.afterInvoke(StreamTask.java:540)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:478)
	at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:707)
	at org.apache.flink.runtime.taskmanager.Task.run(Task.java:532)
	at java.lang.Thread.run(Thread.java:748)

Apr 18, 2020 12:38:27 AM org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.ManagedChannelOrphanWrapper$ManagedChannelReference cleanQueue
SEVERE: *~*~*~ Channel ManagedChannelImpl{logId=872, target=localhost:44727} was not shutdown properly!!! ~*~*~*
    Make sure to call shutdown()/shutdownNow() and wait until awaitTermination() returns true.
java.lang.RuntimeException: ManagedChannel allocation site
	at org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.ManagedChannelOrphanWrapper$ManagedChannelReference.<init>(ManagedChannelOrphanWrapper.java:94)
	at org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.ManagedChannelOrphanWrapper.<init>(ManagedChannelOrphanWrapper.java:52)
	at org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.ManagedChannelOrphanWrapper.<init>(ManagedChannelOrphanWrapper.java:43)
	at org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.AbstractManagedChannelImplBuilder.build(AbstractManagedChannelImplBuilder.java:524)
	at org.apache.beam.sdk.fn.channel.ManagedChannelFactory.forDescriptor(ManagedChannelFactory.java:44)
	at org.apache.beam.runners.fnexecution.environment.ExternalEnvironmentFactory.createEnvironment(ExternalEnvironmentFactory.java:112)
	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$1.load(DefaultJobBundleFactory.java:246)
	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$1.load(DefaultJobBundleFactory.java:230)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$LoadingValueReference.loadFuture(LocalCache.java:3528)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$Segment.loadSync(LocalCache.java:2277)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$Segment.lockedGetOrLoad(LocalCache.java:2154)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$Segment.get(LocalCache.java:2044)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache.get(LocalCache.java:3952)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache.getOrLoad(LocalCache.java:3974)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$LocalLoadingCache.get(LocalCache.java:4958)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$LocalLoadingCache.getUnchecked(LocalCache.java:4964)
	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$SimpleStageBundleFactory.<init>(DefaultJobBundleFactory.java:445)
	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$SimpleStageBundleFactory.<init>(DefaultJobBundleFactory.java:430)
	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory.forStage(DefaultJobBundleFactory.java:297)
	at org.apache.beam.runners.fnexecution.control.DefaultExecutableStageContext.getStageBundleFactory(DefaultExecutableStageContext.java:38)
	at org.apache.beam.runners.fnexecution.control.ReferenceCountingExecutableStageContextFactory$WrappedContext.getStageBundleFactory(ReferenceCountingExecutableStageContextFactory.java:198)
	at org.apache.beam.runners.flink.translation.wrappers.streaming.ExecutableStageDoFnOperator.open(ExecutableStageDoFnOperator.java:204)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.initializeStateAndOpen(StreamTask.java:1007)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.lambda$beforeInvoke$0(StreamTask.java:454)
	at org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor$SynchronizedStreamTaskActionExecutor.runThrowing(StreamTaskActionExecutor.java:94)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.beforeInvoke(StreamTask.java:449)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:461)
	at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:707)
	at org.apache.flink.runtime.taskmanager.Task.run(Task.java:532)
	at java.lang.Thread.run(Thread.java:748)

INFO:apache_beam.runners.worker.statecache:Creating state cache with size 0
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure control channel for localhost:34639.
INFO:apache_beam.runners.worker.sdk_worker:Control channel established.
INFO:apache_beam.runners.worker.sdk_worker:Initializing SDKHarness with unbounded number of workers.
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure state channel for localhost:35415.
INFO:apache_beam.runners.worker.sdk_worker:State channel established.
INFO:apache_beam.runners.worker.data_plane:Creating client data channel for 
ERROR:apache_beam.runners.worker.data_plane:Failed to read inputs in the data plane.
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 528, in _read_inputs
    for elements in elements_iterator:
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 416, in __next__
    return self._next()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 689, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "DNS resolution failed"
	debug_error_string = "{"created":"@1587170307.843885416","description":"Failed to pick subchannel","file":"src/core/ext/filters/client_channel/client_channel.cc","file_line":3981,"referenced_errors":[{"created":"@1587170307.843881654","description":"Resolver transient failure","file":"src/core/ext/filters/client_channel/resolving_lb_policy.cc","file_line":214,"referenced_errors":[{"created":"@1587170307.843880472","description":"DNS resolution failed","file":"src/core/ext/filters/client_channel/resolver/dns/c_ares/dns_resolver_ares.cc","file_line":357,"grpc_status":14,"referenced_errors":[{"created":"@1587170307.843873036","description":"C-ares status is not ARES_SUCCESS: Misformatted domain name","file":"src/core/ext/filters/client_channel/resolver/dns/c_ares/grpc_ares_wrapper.cc","file_line":244,"referenced_errors":[{"created":"@1587170307.843855540","description":"C-ares status is not ARES_SUCCESS: Misformatted domain name","file":"src/core/ext/filters/client_channel/resolver/dns/c_ares/grpc_ares_wrapper.cc","file_line":244}]}]}]}]}"
>
INFO:apache_beam.runners.worker.data_plane:Creating client data channel for localhost:46517
Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.5/threading.py", line 914, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.5/threading.py", line 862, in run
    self._target(*self._args, **self._kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 545, in <lambda>
    target=lambda: self._read_inputs(elements_iterator),
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 528, in _read_inputs
    for elements in elements_iterator:
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 416, in __next__
    return self._next()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 689, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "DNS resolution failed"
	debug_error_string = "{"created":"@1587170307.843885416","description":"Failed to pick subchannel","file":"src/core/ext/filters/client_channel/client_channel.cc","file_line":3981,"referenced_errors":[{"created":"@1587170307.843881654","description":"Resolver transient failure","file":"src/core/ext/filters/client_channel/resolving_lb_policy.cc","file_line":214,"referenced_errors":[{"created":"@1587170307.843880472","description":"DNS resolution failed","file":"src/core/ext/filters/client_channel/resolver/dns/c_ares/dns_resolver_ares.cc","file_line":357,"grpc_status":14,"referenced_errors":[{"created":"@1587170307.843873036","description":"C-ares status is not ARES_SUCCESS: Misformatted domain name","file":"src/core/ext/filters/client_channel/resolver/dns/c_ares/grpc_ares_wrapper.cc","file_line":244,"referenced_errors":[{"created":"@1587170307.843855540","description":"C-ares status is not ARES_SUCCESS: Misformatted domain name","file":"src/core/ext/filters/client_channel/resolver/dns/c_ares/grpc_ares_wrapper.cc","file_line":244}]}]}]}]}"
>

INFO:apache_beam.runners.worker.sdk_worker:No more requests from control plane
[assert_that/Group/GroupByKey -> [3]assert_that/{Group, Unkey, Match} (1/2)] WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer - Hanged up for unknown endpoint.
INFO:apache_beam.runners.worker.sdk_worker:SDK Harness waiting for in-flight requests to complete
INFO:apache_beam.runners.worker.data_plane:Closing all cached grpc data channels.
INFO:apache_beam.runners.worker.sdk_worker:Closing all cached gRPC state handlers.
INFO:apache_beam.runners.worker.sdk_worker:Done consuming work.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to DONE
.INFO:__main__:removing conf dir: /tmp/flinktest-confc2mumlzb

----------------------------------------------------------------------
Ran 78 tests in 109.965s

OK (skipped=16)

FAILURE: Build failed with an exception.

* Where:
Script '<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 55

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py35:flinkCompatibilityMatrixStreamingLOOPBACK'.
> 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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.2.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 14m 25s
77 actionable tasks: 58 executed, 18 from cache, 1 up-to-date

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

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_Python35_VR_Flink #1873

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


---------------------------------------------------------------------
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_Python35_VR_Flink #1872

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

Changes:

[github] [BEAM-3836] Enable dynamic splitting/checkpointing within the Java SDK


------------------------------------------
[...truncated 204.31 KB...]
Successfully pulled java_third_party_licenses/javassist-3.20.0-GA.jar/LICENSE from http://www.mozilla.org/MPL/MPL-1.1.html
Successfully pulled java_third_party_licenses/javassist-3.20.0-GA.jar/javassist-3.20.0-GA-sources.jar from https://repo1.maven.org/maven2/org/javassist/javassist/3.20.0-GA/javassist-3.20.0-GA-sources.jar
Successfully pulled java_third_party_licenses/javassist-3.20.0-GA.jar/javassist-3.20.0-GA.jar from https://repo1.maven.org/maven2/org/javassist/javassist/3.20.0-GA/javassist-3.20.0-GA.jar
Successfully pulled java_third_party_licenses/javassist-3.24.0-GA.jar/LICENSE from http://www.mozilla.org/MPL/MPL-1.1.html
Successfully pulled java_third_party_licenses/javassist-3.24.0-GA.jar/javassist-3.24.0-GA-sources.jar from https://repo1.maven.org/maven2/org/javassist/javassist/3.24.0-GA/javassist-3.24.0-GA-sources.jar
Successfully pulled java_third_party_licenses/javassist-3.24.0-GA.jar/javassist-3.24.0-GA.jar from https://repo1.maven.org/maven2/org/javassist/javassist/3.24.0-GA/javassist-3.24.0-GA.jar
License/notice for jboss-logging-3.1.0.CR2 were pulled automatically.
Successfully pulled java_third_party_licenses/jboss-logging-3.1.0.CR2.jar/jboss-logging-3.1.0.CR2-sources.jar from https://repo1.maven.org/maven2/org/jboss/logging/jboss-logging/3.1.0.CR2/jboss-logging-3.1.0.CR2-sources.jar
Successfully pulled java_third_party_licenses/jboss-logging-3.1.0.CR2.jar/jboss-logging-3.1.0.CR2.jar from https://repo1.maven.org/maven2/org/jboss/logging/jboss-logging/3.1.0.CR2/jboss-logging-3.1.0.CR2.jar
Successfully pulled java_third_party_licenses/jboss-marshalling-1.4.11.Final.jar/LICENSE from http://repository.jboss.org/licenses/cc0-1.0.txt
Successfully pulled java_third_party_licenses/jboss-modules-1.1.0.Beta1.jar/LICENSE from http://repository.jboss.org/licenses/lgpl-2.1.txt
Successfully pulled java_third_party_licenses/jboss-modules-1.1.0.Beta1.jar/jboss-modules-1.1.0.Beta1-sources.jar from https://repo1.maven.org/maven2/org/jboss/modules/jboss-modules/1.1.0.Beta1/jboss-modules-1.1.0.Beta1-sources.jar
Successfully pulled java_third_party_licenses/jboss-modules-1.1.0.Beta1.jar/jboss-modules-1.1.0.Beta1.jar from https://repo1.maven.org/maven2/org/jboss/modules/jboss-modules/1.1.0.Beta1/jboss-modules-1.1.0.Beta1.jar
Successfully pulled java_third_party_licenses/jctools-core-1.2.1.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
License/notice for jdom2-2.0.6 were pulled automatically.
Successfully pulled java_third_party_licenses/trove4j-1.0.20181211.jar/LICENSE from https://www.gnu.org/licenses/old-licenses/lgpl-2.1.en.html
Successfully pulled java_third_party_licenses/kotlin-compiler-embeddable-1.3.21.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/kotlin-reflect-1.3.21.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/kotlin-script-runtime-1.3.21.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/kotlin-scripting-compiler-embeddable-1.3.21.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/kotlin-stdlib-1.3.21.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/kotlin-stdlib-common-1.3.21.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/kotlin-stdlib-jdk7-1.3.21.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/kotlin-stdlib-jdk8-1.3.21.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/annotations-13.0.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/annotations-16.0.3.jar/LICENSE from https://raw.githubusercontent.com/doctrine/annotations/master/LICENSE
Successfully pulled java_third_party_licenses/annotations-17.0.0.jar/LICENSE from https://www.apache.org/licenses/LICENSE-2.0.txt
License/notice for joda-convert-1.2 were pulled automatically.
License/notice for joda-convert-2.1 were pulled automatically.
Successfully pulled java_third_party_licenses/jcodings-1.0.8.jar/LICENSE from http://www.opensource.org/licenses/mit-license.php
Successfully pulled java_third_party_licenses/joni-2.1.2.jar/LICENSE from http://www.opensource.org/licenses/mit-license.php
Successfully pulled java_third_party_licenses/json4s-ast_2.11-3.5.3.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0
Successfully pulled java_third_party_licenses/json4s-core_2.11-3.5.3.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0
Successfully pulled java_third_party_licenses/json4s-jackson_2.11-3.5.3.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0
Successfully pulled java_third_party_licenses/json4s-scalap_2.11-3.5.3.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0
Successfully pulled java_third_party_licenses/json-20090211.jar/LICENSE from http://www.json.org/license.html
License/notice for jsoup-1.13.1 were pulled automatically.
License/notice for stax-ex-1.8.1 were pulled automatically.
License/notice for lmdbjava-0.6.1 were pulled automatically.
Successfully pulled java_third_party_licenses/lz4-java-1.4.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/lz4-java-1.4.0.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/lz4-java-1.5.0.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/jbcrypt-0.3m.jar/LICENSE from http://www.mindrot.org/files/jBCrypt/LICENSE
License/notice for mockito-core-3.0.0 were pulled automatically.
Successfully pulled java_third_party_licenses/mongo-java-driver-3.9.1.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/jetty-6.1.26.jar/LICENSE from http://www.eclipse.org/org/documents/epl-v10.php
Successfully pulled java_third_party_licenses/jetty-sslengine-6.1.26.jar/LICENSE from http://www.eclipse.org/org/documents/epl-v10.php
Successfully pulled java_third_party_licenses/jetty-util-6.1.26.jar/LICENSE from http://www.eclipse.org/org/documents/epl-v10.php
Successfully pulled java_third_party_licenses/jsp-2.1-6.1.14.jar/LICENSE from https://raw.githubusercontent.com/javaee/glassfish/master/LICENSE
Successfully pulled java_third_party_licenses/jsp-2.1-6.1.14.jar/jsp-2.1-6.1.14-sources.jar from https://repo1.maven.org/maven2/org/mortbay/jetty/jsp-2.1/6.1.14/jsp-2.1-6.1.14-sources.jar
Successfully pulled java_third_party_licenses/jsp-2.1-6.1.14.jar/jsp-2.1-6.1.14.jar from https://repo1.maven.org/maven2/org/mortbay/jetty/jsp-2.1/6.1.14/jsp-2.1-6.1.14.jar
Successfully pulled java_third_party_licenses/jsp-api-2.1-6.1.14.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0
Successfully pulled java_third_party_licenses/servlet-api-2.5-20081211.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0
Successfully pulled java_third_party_licenses/servlet-api-2.5-6.1.14.jar/LICENSE from https://www.oracle.com/downloads/licenses/javase-license1.html
Successfully pulled java_third_party_licenses/servlet-api-2.5-6.1.14.jar/servlet-api-2.5-6.1.14-sources.jar from https://repo1.maven.org/maven2/org/mortbay/jetty/servlet-api-2.5/6.1.14/servlet-api-2.5-6.1.14-sources.jar
Successfully pulled java_third_party_licenses/servlet-api-2.5-6.1.14.jar/servlet-api-2.5-6.1.14.jar from https://repo1.maven.org/maven2/org/mortbay/jetty/servlet-api-2.5/6.1.14/servlet-api-2.5-6.1.14.jar
Successfully pulled java_third_party_licenses/noggit-0.6.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
License/notice for objenesis-2.1 were pulled automatically.
License/notice for objenesis-2.5.1 were pulled automatically.
License/notice for objenesis-2.6 were pulled automatically.
License/notice for objenesis-3.0.1 were pulled automatically.
Successfully pulled java_third_party_licenses/geoapi-3.0.1.jar/LICENSE from https://raw.githubusercontent.com/opengeospatial/geoapi/master/LICENSE.txt
Successfully pulled java_third_party_licenses/asm-4.0.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-5.0.3.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-5.0.4.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-6.2.1.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-7.0.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-7.3.1.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-all-5.0.2.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-analysis-5.0.3.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-analysis-6.2.1.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-analysis-7.0.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-commons-5.0.3.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-commons-5.0.4.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-commons-6.2.1.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-commons-7.0.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-tree-5.0.3.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-tree-6.2.1.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-tree-7.0.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-util-5.0.3.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/asm-util-7.0.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/pcollections-2.1.2.jar/LICENSE from http://www.opensource.org/licenses/mit-license.php
Successfully pulled java_third_party_licenses/pentaho-aggdesigner-algorithm-5.1.5-jhyde.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.html
Successfully pulled java_third_party_licenses/plume-util-1.0.6.jar/LICENSE from https://opensource.org/licenses/MIT
Successfully pulled java_third_party_licenses/reflection-util-0.0.2.jar/LICENSE from https://opensource.org/licenses/MIT
Successfully pulled java_third_party_licenses/require-javadoc-0.1.0.jar/LICENSE from https://opensource.org/licenses/MIT
License/notice for postgresql-42.2.2 were pulled automatically.
License/notice for powermock-api-mockito2-2.0.2 were pulled automatically.
License/notice for powermock-api-support-2.0.2 were pulled automatically.
License/notice for powermock-core-2.0.2 were pulled automatically.
License/notice for powermock-module-junit4-2.0.2 were pulled automatically.
License/notice for powermock-module-junit4-common-2.0.2 were pulled automatically.
License/notice for powermock-reflect-2.0.2 were pulled automatically.
Successfully pulled java_third_party_licenses/quartz-2.3.2.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/reactive-streams-1.0.0.jar/LICENSE from https://raw.githubusercontent.com/reactive-streams/reactive-streams-jvm/master/LICENSE
Successfully pulled java_third_party_licenses/reactive-streams-1.0.2.jar/LICENSE from https://raw.githubusercontent.com/reactive-streams/reactive-streams-jvm/master/LICENSE
Successfully pulled java_third_party_licenses/reactive-streams-1.0.3.jar/LICENSE from https://raw.githubusercontent.com/reactive-streams/reactive-streams-jvm/master/LICENSE
Successfully pulled java_third_party_licenses/org.restlet-2.3.0.jar/LICENSE from http://www.opensource.org/licenses/lgpl-3.0
Successfully pulled java_third_party_licenses/org.restlet-2.3.0.jar/org.restlet-2.3.0-sources.jar from https://repo.spring.io/plugins-release/org/restlet/jee/org.restlet/2.3.0/org.restlet-2.3.0-sources.jar
Successfully pulled java_third_party_licenses/org.restlet-2.3.0.jar/org.restlet-2.3.0.jar from https://repo.spring.io/plugins-release/org/restlet/jee/org.restlet/2.3.0/org.restlet-2.3.0.jar
Successfully pulled java_third_party_licenses/org.restlet.ext.servlet-2.3.0.jar/LICENSE from http://www.opensource.org/licenses/lgpl-3.0
Successfully pulled java_third_party_licenses/org.restlet.ext.servlet-2.3.0.jar/org.restlet.ext.servlet-2.3.0-sources.jar from https://repo.spring.io/plugins-release/org/restlet/jee/org.restlet.ext.servlet/2.3.0/org.restlet.ext.servlet-2.3.0-sources.jar
Successfully pulled java_third_party_licenses/org.restlet.ext.servlet-2.3.0.jar/org.restlet.ext.servlet-2.3.0.jar from https://repo.spring.io/plugins-release/org/restlet/jee/org.restlet.ext.servlet/2.3.0/org.restlet.ext.servlet-2.3.0.jar
Successfully pulled java_third_party_licenses/duct-tape-1.0.7.jar/LICENSE from http://opensource.org/licenses/MIT
Successfully pulled java_third_party_licenses/visible-assertions-2.1.2.jar/LICENSE from http://opensource.org/licenses/MIT
Successfully pulled java_third_party_licenses/tcp-unix-socket-proxy-1.0.2.jar/LICENSE from http://opensource.org/licenses/MIT
Successfully pulled java_third_party_licenses/roaringbitmap-0.7.45.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/shims-0.7.45.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/rocksdbjni-5.7.3.jar/LICENSE from http://www.gnu.org/licenses/gpl-2.0.html
Successfully pulled java_third_party_licenses/scala-async_2.12-0.9.7.jar/LICENSE from http://opensource.org/licenses/BSD-3-Clause
Successfully pulled java_third_party_licenses/scala-java8-compat_2.11-0.7.0.jar/LICENSE from http://opensource.org/licenses/BSD-3-Clause
Successfully pulled java_third_party_licenses/scala-java8-compat_2.12-0.8.0.jar/LICENSE from http://opensource.org/licenses/BSD-3-Clause
Successfully pulled java_third_party_licenses/scala-parser-combinators_2.11-1.0.4.jar/LICENSE from http://opensource.org/licenses/BSD-3-Clause
Successfully pulled java_third_party_licenses/scala-parser-combinators_2.11-1.1.0.jar/LICENSE from http://opensource.org/licenses/BSD-3-Clause
Successfully pulled java_third_party_licenses/scala-parser-combinators_2.11-1.1.1.jar/LICENSE from http://opensource.org/licenses/BSD-3-Clause
Successfully pulled java_third_party_licenses/scala-parser-combinators_2.12-1.1.0.jar/LICENSE from http://opensource.org/licenses/BSD-3-Clause
Successfully pulled java_third_party_licenses/scala-parser-combinators_2.12-1.1.1.jar/LICENSE from http://opensource.org/licenses/BSD-3-Clause
Successfully pulled java_third_party_licenses/scala-xml_2.11-1.0.6.jar/LICENSE from http://opensource.org/licenses/BSD-3-Clause
Successfully pulled java_third_party_licenses/scala-xml_2.12-1.1.0.jar/LICENSE from http://opensource.org/licenses/BSD-3-Clause
Successfully pulled java_third_party_licenses/scala-compiler-2.11.8.jar/LICENSE from http://www.scala-lang.org/license.html
Successfully pulled java_third_party_licenses/scala-library-2.11.11.jar/LICENSE from http://www.scala-lang.org/license.html
Successfully pulled java_third_party_licenses/scala-library-2.11.12.jar/LICENSE from http://www.scala-lang.org/license.html
Successfully pulled java_third_party_licenses/scala-library-2.12.6.jar/LICENSE from http://www.scala-lang.org/license.html
Successfully pulled java_third_party_licenses/scala-library-2.12.7.jar/LICENSE from http://www.scala-lang.org/license.html
Successfully pulled java_third_party_licenses/scala-reflect-2.11.12.jar/LICENSE from http://www.scala-lang.org/license.html
Successfully pulled java_third_party_licenses/scala-reflect-2.11.8.jar/LICENSE from http://www.scala-lang.org/license.html
Successfully pulled java_third_party_licenses/scala-reflect-2.12.4.jar/LICENSE from http://www.scala-lang.org/license.html
Successfully pulled java_third_party_licenses/scala-reflect-2.12.7.jar/LICENSE from http://www.scala-lang.org/license.html
Successfully pulled java_third_party_licenses/scala-stm_2.12-0.8.jar/LICENSE from https://github.com/nbronson/scala-stm/blob/master/LICENSE.txt
Successfully pulled java_third_party_licenses/scalate-core_2.11-1.8.0.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0
Successfully pulled java_third_party_licenses/scalate-util_2.11-1.8.0.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0
Successfully pulled java_third_party_licenses/scalatra-common_2.11-2.5.0.jar/LICENSE from http://github.com/scalatra/scalatra/raw/HEAD/LICENSE
Successfully pulled java_third_party_licenses/scalatra-scalate_2.11-2.5.0.jar/LICENSE from http://github.com/scalatra/scalatra/raw/HEAD/LICENSE
Successfully pulled java_third_party_licenses/scalatra_2.11-2.5.0.jar/LICENSE from http://github.com/scalatra/scalatra/raw/HEAD/LICENSE
Successfully pulled java_third_party_licenses/native-lib-loader-2.0.2.jar/LICENSE from https://raw.githubusercontent.com/scijava/native-lib-loader/master/LICENSE.txt
Successfully pulled java_third_party_licenses/native-lib-loader-2.0.2.jar/NOTICE from https://raw.githubusercontent.com/scijava/native-lib-loader/master/NOTICE.txt
Successfully pulled java_third_party_licenses/jsonassert-1.5.0.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/jcl-over-slf4j-1.7.16.jar/LICENSE from http://www.opensource.org/licenses/mit-license.php
Successfully pulled java_third_party_licenses/jcl-over-slf4j-1.7.25.jar/LICENSE from http://www.opensource.org/licenses/mit-license.php
Successfully pulled java_third_party_licenses/jcl-over-slf4j-1.7.28.jar/LICENSE from http://www.opensource.org/licenses/mit-license.php
Successfully pulled java_third_party_licenses/jcl-over-slf4j-1.7.7.jar/LICENSE from http://www.opensource.org/licenses/mit-license.php
Successfully pulled java_third_party_licenses/jul-to-slf4j-1.7.16.jar/LICENSE from http://www.opensource.org/licenses/mit-license.php
Successfully pulled java_third_party_licenses/jul-to-slf4j-1.7.28.jar/LICENSE from http://www.opensource.org/licenses/mit-license.php
Successfully pulled java_third_party_licenses/log4j-over-slf4j-1.7.7.jar/LICENSE from http://www.opensource.org/licenses/mit-license.php
Successfully pulled java_third_party_licenses/slf4j-api-1.7.21.jar/LICENSE from http://www.opensource.org/licenses/mit-license.php
Successfully pulled java_third_party_licenses/slf4j-api-1.7.25.jar/LICENSE from http://www.opensource.org/licenses/mit-license.php
Successfully pulled java_third_party_licenses/slf4j-api-1.7.26.jar/LICENSE from http://www.opensource.org/licenses/mit-license.php
Successfully pulled java_third_party_licenses/slf4j-jdk14-1.7.25.jar/LICENSE from http://www.opensource.org/licenses/mit-license.php
Successfully pulled java_third_party_licenses/slf4j-log4j12-1.7.25.jar/LICENSE from http://www.opensource.org/licenses/mit-license.php
Successfully pulled java_third_party_licenses/slf4j-simple-1.7.25.jar/LICENSE from http://www.opensource.org/licenses/mit-license.php
License/notice for cglib-2.2.1-v20090111 were pulled automatically.
Successfully pulled java_third_party_licenses/model-builder-1.3.jar/LICENSE from https://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/unused-1.0.0.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
License/notice for spring-core-4.3.18.RELEASE were pulled automatically.
License/notice for spring-expression-4.3.18.RELEASE were pulled automatically.
License/notice for xmpcore-shaded-6.1.10 were pulled automatically.
Successfully pulled java_third_party_licenses/jmatio-1.5.jar/LICENSE from http://www.linfo.org/bsdlicense.html
Successfully pulled java_third_party_licenses/metadata-extractor-2.13.0.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/clickhouse-1.10.5.jar/LICENSE from http://opensource.org/licenses/MIT
Successfully pulled java_third_party_licenses/database-commons-1.10.5.jar/LICENSE from http://opensource.org/licenses/MIT
Successfully pulled java_third_party_licenses/jdbc-1.10.5.jar/LICENSE from http://opensource.org/licenses/MIT
Successfully pulled java_third_party_licenses/localstack-1.11.2.jar/LICENSE from http://opensource.org/licenses/MIT
Successfully pulled java_third_party_licenses/testcontainers-1.10.5.jar/LICENSE from http://opensource.org/licenses/MIT
Successfully pulled java_third_party_licenses/testcontainers-1.11.2.jar/LICENSE from http://opensource.org/licenses/MIT
Successfully pulled java_third_party_licenses/testcontainers-1.11.3.jar/LICENSE from http://opensource.org/licenses/MIT
License/notice for threetenbp-1.4.1 were pulled automatically.
Successfully pulled java_third_party_licenses/xz-1.5.jar/LICENSE from https://git.tukaani.org/?p=xz-java.git;a=blob_plain;f=COPYING;h=c1d404dc7a6f06a0437bf1055fedaa4a4c89d728;hb=HEAD
Successfully pulled java_third_party_licenses/xz-1.8.jar/LICENSE from https://git.tukaani.org/?p=xz-java.git;a=blob_plain;f=COPYING;h=c1d404dc7a6f06a0437bf1055fedaa4a4c89d728;hb=HEAD
License/notice for snappy-java-1.1.4 were pulled automatically.
Successfully pulled java_third_party_licenses/snakeyaml-1.12.jar/LICENSE from https://bitbucket.org/asomov/snakeyaml/raw/3d49667ece57d564668b9a155c55ccfe26aaca00/LICENSE.txt
Successfully pulled java_third_party_licenses/snakeyaml-1.15.jar/LICENSE from https://bitbucket.org/asomov/snakeyaml/raw/3d49667ece57d564668b9a155c55ccfe26aaca00/LICENSE.txt
Successfully pulled java_third_party_licenses/snakeyaml-1.17.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/snakeyaml-1.23.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/snakeyaml-1.24.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
License/notice for oro-2.0.8 were pulled automatically.
Successfully pulled java_third_party_licenses/jedis-3.0.1.jar/LICENSE from http://github.com/xetorthio/jedis/raw/master/LICENSE.txt
Successfully pulled java_third_party_licenses/generics-resolver-2.0.1.jar/LICENSE from https://raw.githubusercontent.com/xvik/generics-resolver/master/LICENSE
Successfully pulled java_third_party_licenses/clickhouse-jdbc-0.1.47.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0
Successfully pulled java_third_party_licenses/annotations-2.10.61.jar/LICENSE from https://aws.amazon.com/apache2.0
Successfully pulled java_third_party_licenses/apache-client-2.10.61.jar/LICENSE from https://aws.amazon.com/apache2.0
Successfully pulled java_third_party_licenses/auth-2.10.61.jar/LICENSE from https://aws.amazon.com/apache2.0
Successfully pulled java_third_party_licenses/aws-core-2.10.61.jar/LICENSE from https://aws.amazon.com/apache2.0
Successfully pulled java_third_party_licenses/aws-json-protocol-2.10.61.jar/LICENSE from https://aws.amazon.com/apache2.0
Successfully pulled java_third_party_licenses/aws-query-protocol-2.10.61.jar/LICENSE from https://aws.amazon.com/apache2.0
Successfully pulled java_third_party_licenses/cloudwatch-2.10.61.jar/LICENSE from https://aws.amazon.com/apache2.0
Traceback (most recent call last):
  File "sdks/java/container/license_scripts/pull_licenses_java.py", line 225, in <module>
Successfully pulled java_third_party_licenses/dynamodb-2.10.61.jar/LICENSE from https://aws.amazon.com/apache2.0
    error_msg)
Successfully pulled java_third_party_licenses/http-client-spi-2.10.61.jar/LICENSE from https://aws.amazon.com/apache2.0
Successfully pulled java_third_party_licenses/netty-nio-client-2.10.61.jar/LICENSE from https://aws.amazon.com/apache2.0
Successfully pulled java_third_party_licenses/profiles-2.10.61.jar/LICENSE from https://aws.amazon.com/apache2.0
Successfully pulled java_third_party_licenses/protocol-core-2.10.61.jar/LICENSE from https://aws.amazon.com/apache2.0
RuntimeError: ('1 error(s) occurred.', ['**************************************** Licenses were not able to be pulled automatically for some dependencies. Please search source code of the dependencies on the internet and add "license" and "notice" (if available) field to sdks/java/container/license_scripts/dep_urls_java.yaml for each missing license. Dependency List: [servlet-api-2.5]'])
Successfully pulled java_third_party_licenses/regions-2.10.61.jar/LICENSE from https://aws.amazon.com/apache2.0
Successfully pulled java_third_party_licenses/sdk-core-2.10.61.jar/LICENSE from https://aws.amazon.com/apache2.0
Successfully pulled java_third_party_licenses/sns-2.10.61.jar/LICENSE from https://aws.amazon.com/apache2.0
Successfully pulled java_third_party_licenses/sqs-2.10.61.jar/LICENSE from https://aws.amazon.com/apache2.0
Successfully pulled java_third_party_licenses/utils-2.10.61.jar/LICENSE from https://aws.amazon.com/apache2.0
Successfully pulled java_third_party_licenses/eventstream-1.0.1.jar/LICENSE from https://aws.amazon.com/apache2.0
Successfully pulled java_third_party_licenses/ion-java-1.0.2.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/sqlline-1.4.0.jar/LICENSE from http://opensource.org/licenses/BSD-3-Clause
Successfully pulled java_third_party_licenses/stax-api-1.0.1.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/jasper-compiler-5.5.23.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/jasper-runtime-5.5.23.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/xercesimpl-2.12.0.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/xercesimpl-2.9.1.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
License/notice for xml-apis-1.3.04 were pulled automatically.
License/notice for xml-apis-1.4.01 were pulled automatically.
Successfully pulled java_third_party_licenses/xml-resolver-1.2.jar/LICENSE from http://www.apache.org/licenses/LICENSE-2.0.txt
Successfully pulled java_third_party_licenses/xmlenc-0.52.jar/LICENSE from http://www.opensource.org/licenses/bsd-license.php

> Task :sdks:java:container:generateThirdPartyLicenses FAILED
> Task :sdks:java:container:copyDockerfileDependencies
> Task :sdks:java:container:dockerClean UP-TO-DATE

> Task :sdks:java:container:goPrepare
Use project GOPATH: <https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/java/container/.gogradle/project_gopath>

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

> Task :sdks:java:container:installDependencies
> Task :sdks:java:container:buildLinuxAmd64
> Task :sdks:java:container:goBuild

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:java:container:generateThirdPartyLicenses'.
> Process 'command './sdks/java/container/license_scripts/license_script.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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.2.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 6m 28s
71 actionable tasks: 52 executed, 18 from cache, 1 up-to-date

Publishing build scan...
https://gradle.com/s/42w4vckfavwae

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