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/03/19 15:51:03 UTC

Build failed in Jenkins: beam_PostCommit_Python_PVR_Reference #330

See <https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/330/display/redirect?page=changes>

Changes:

[lukasz.gajowy] [BEAM-6848] Fix incorrectly passed args to job

------------------------------------------
[...truncated 307.01 KB...]
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_18:0 
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_1:0 
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/write/ref_PCollection_PCollection_12:0 
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_7:0 
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/write/ref_PCollection_PCollection_25:0:0 
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_15:0 
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_28:0 
[grpc-default-executor-1] INFO sdk_worker.run - No more requests from control plane
[grpc-default-executor-1] INFO sdk_worker.run - SDK Harness waiting for in-flight requests to complete
[grpc-default-executor-1] INFO data_plane.close - Closing all cached grpc data channels.
[grpc-default-executor-1] WARN org.apache.beam.repackaged.beam_runners_direct_java.sdk.fn.data.BeamFnDataGrpcMultiplexer - Hanged up for unknown endpoint.
[grpc-default-executor-1] INFO sdk_worker.close - Closing all cached gRPC state handlers.
[grpc-default-executor-1] INFO sdk_worker.run - Done consuming work.
[grpc-default-executor-1] INFO sdk_worker_main.main - Python sdk harness exiting.
[grpc-default-executor-3] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.logging.GrpcLoggingService - Logging client hanged up.
[reference-runner-pipeline-1] WARN org.apache.beam.repackaged.beam_runners_direct_java.sdk.fn.data.BeamFnDataGrpcMultiplexer - Hanged up for unknown endpoint.
[reference-runner-pipeline-1] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService - Manifest at /tmp/beam-artifact-staging/job-2090870867/MANIFEST has 0 artifact locations
[reference-runner-pipeline-1] INFO org.apache.beam.sdk.io.LocalFileSystem - Ignoring failed deletion of file /tmp/beam-artifact-staging/job-2090870867/artifacts/ which already does not exist: {}
java.nio.file.NoSuchFileException: /tmp/beam-artifact-staging/job-2090870867/artifacts
	at sun.nio.fs.UnixException.translateToIOException(UnixException.java:86)
	at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:102)
	at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:107)
	at sun.nio.fs.UnixFileSystemProvider.implDelete(UnixFileSystemProvider.java:244)
	at sun.nio.fs.AbstractFileSystemProvider.delete(AbstractFileSystemProvider.java:103)
	at java.nio.file.Files.delete(Files.java:1126)
	at org.apache.beam.sdk.io.LocalFileSystem.delete(LocalFileSystem.java:185)
	at org.apache.beam.sdk.io.FileSystems.delete(FileSystems.java:379)
	at org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.artifact.BeamFileSystemArtifactStagingService.removeArtifacts(BeamFileSystemArtifactStagingService.java:168)
	at org.apache.beam.runners.direct.portable.job.ReferenceRunnerJobService.lambda$run$3(ReferenceRunnerJobService.java:194)
	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
	at java.lang.Thread.run(Thread.java:748)
[reference-runner-pipeline-1] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.artifact.BeamFileSystemArtifactStagingService - Removed dir /tmp/beam-artifact-staging/job-2090870867/
.sINFO:root:Using latest locally built Python SDK docker image.
INFO:root:==================== <function lift_combiners at 0x7ff0bb622de8> ====================
[grpc-default-executor-2] ERROR org.apache.beam.runners.direct.portable.job.ReferenceRunnerJobService - Encountered Unexpected Exception for Invocation job-449499344
java.lang.IllegalArgumentException: Can't get the number of an unknown enum value.
	at org.apache.beam.model.jobmanagement.v1.JobApi$JobState$Enum.getNumber(JobApi.java:8585)
	at org.apache.beam.model.jobmanagement.v1.JobApi$GetJobStateResponse$Builder.setState(JobApi.java:5768)
	at org.apache.beam.runners.direct.portable.job.ReferenceRunnerJobService.getStateStream(ReferenceRunnerJobService.java:237)
	at org.apache.beam.model.jobmanagement.v1.JobServiceGrpc$MethodHandlers.invoke(JobServiceGrpc.java:770)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:171)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.PartialForwardingServerCallListener.onHalfClose(PartialForwardingServerCallListener.java:35)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.ForwardingServerCallListener.onHalfClose(ForwardingServerCallListener.java:23)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.ForwardingServerCallListener$SimpleForwardingServerCallListener.onHalfClose(ForwardingServerCallListener.java:40)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.Contexts$ContextualizedServerCallListener.onHalfClose(Contexts.java:86)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:283)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:707)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
	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)
Mar 19, 2019 3:50:34 PM org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.SerializingExecutor run
SEVERE: Exception while executing runnable org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed@108ae49
java.lang.IllegalStateException: call already closed
	at org.apache.beam.vendor.grpc.v1p13p1.com.google.common.base.Preconditions.checkState(Preconditions.java:444)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.ServerCallImpl.close(ServerCallImpl.java:172)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.stub.ServerCalls$ServerCallStreamObserverImpl.onCompleted(ServerCalls.java:358)
	at org.apache.beam.runners.direct.portable.job.ReferenceRunnerJobService.getStateStream(ReferenceRunnerJobService.java:249)
	at org.apache.beam.model.jobmanagement.v1.JobServiceGrpc$MethodHandlers.invoke(JobServiceGrpc.java:770)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:171)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.PartialForwardingServerCallListener.onHalfClose(PartialForwardingServerCallListener.java:35)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.ForwardingServerCallListener.onHalfClose(ForwardingServerCallListener.java:23)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.ForwardingServerCallListener$SimpleForwardingServerCallListener.onHalfClose(ForwardingServerCallListener.java:40)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.Contexts$ContextualizedServerCallListener.onHalfClose(Contexts.java:86)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:283)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:707)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
	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)

[direct-runner-worker] WARN org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.environment.DockerCommand - Unable to pull docker image jenkins-docker-apache.bintray.io/beam/python:latest, cause: Received exit code 1 for command 'docker pull jenkins-docker-apache.bintray.io/beam/python:latest'. stderr: Error response from daemon: unknown: Repo 'apache' was not found
[grpc-default-executor-3] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService - GetManifest for /tmp/beam-artifact-staging/job-449499344/MANIFEST
[grpc-default-executor-3] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService - Loading manifest for retrieval token /tmp/beam-artifact-staging/job-449499344/MANIFEST
[grpc-default-executor-3] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService - Manifest at /tmp/beam-artifact-staging/job-449499344/MANIFEST has 0 artifact locations
[grpc-default-executor-3] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService - GetManifest for /tmp/beam-artifact-staging/job-449499344/MANIFEST -> 0 artifacts
[grpc-default-executor-3] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.logging.GrpcLoggingService - Beam Fn Logging client connected.
[grpc-default-executor-3] INFO sdk_worker_main.main - Logging handler created.
[grpc-default-executor-3] INFO sdk_worker_main.start - Status HTTP server running at localhost:41519
[grpc-default-executor-3] INFO sdk_worker_main.main - semi_persistent_directory: /tmp
[grpc-default-executor-3] WARN sdk_worker_main._load_main_session - No session file found: /tmp/staged/pickled_main_session. Functions defined in __main__ (interactive session) may fail. 
[grpc-default-executor-3] WARN pipeline_options.get_all_options - Discarding unparseable args: [u'--enforce_encodability', u'--direct_runner_use_stacked_bundle', u'--enforce_immutability', u'--pipeline_type_check', u'--block_on_run'] 
[grpc-default-executor-3] INFO sdk_worker_main.main - Python sdk harness started with pipeline_options: {'experiments': [u'beam_fn_api'], 'environment_type': u'DOCKER', 'sdk_location': u'container', 'job_name': u'test_windowed_pardo_state_timers_1553010632.71', 'job_endpoint': u'localhost:53261'}
[grpc-default-executor-3] INFO sdk_worker.__init__ - Creating insecure control channel for localhost:36553.
[grpc-default-executor-3] INFO sdk_worker.__init__ - Control channel established.
[grpc-default-executor-3] INFO sdk_worker.__init__ - Initializing SDKHarness with 12 workers.
[grpc-default-executor-3] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.control.FnApiControlClientPoolService - Beam Fn Control client connected with id 1
[grpc-default-executor-3] INFO sdk_worker.create_state_handler - Creating insecure state channel for localhost:33805.
[grpc-default-executor-3] INFO sdk_worker.create_state_handler - State channel established.
[grpc-default-executor-3] WARN bundle_processor.create_operation - No unique name set for transform fn/write/ref_PCollection_PCollection_22:0:0 
[grpc-default-executor-3] WARN bundle_processor.create_operation - No unique name set for transform fn/write/ref_PCollection_PCollection_4:0 
[grpc-default-executor-3] INFO data_plane.create_data_channel - Creating channel for localhost:43879
[grpc-default-executor-3] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.data.GrpcDataService - Beam Fn Data client connected.
[grpc-default-executor-3] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_15:0 
[grpc-default-executor-3] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_1:0 
[grpc-default-executor-3] WARN bundle_processor.create_operation - No unique name set for transform fn/write/ref_PCollection_PCollection_13:0 
[grpc-default-executor-3] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_7:0 
[direct-runner-worker] ERROR org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.control.FnApiControlClient - FnApiControlClient closed, clearing outstanding requests {11=java.util.concurrent.CompletableFuture@189ebbd[Not completed, 1 dependents], 12=java.util.concurrent.CompletableFuture@f4e15fc[Not completed, 1 dependents], 13=java.util.concurrent.CompletableFuture@b7180cd[Not completed, 1 dependents], 14=java.util.concurrent.CompletableFuture@4e731fc7[Not completed, 1 dependents], 15=java.util.concurrent.CompletableFuture@e9d1b7[Not completed, 1 dependents], 16=java.util.concurrent.CompletableFuture@7ff7d5a3[Not completed, 1 dependents], 17=java.util.concurrent.CompletableFuture@78874578[Not completed, 1 dependents], 19=java.util.concurrent.CompletableFuture@2e5ce088[Not completed, 1 dependents]}
[reference-runner-pipeline-1] WARN org.apache.beam.repackaged.beam_runners_direct_java.sdk.fn.data.BeamFnDataGrpcMultiplexer - Hanged up for unknown endpoint.
[reference-runner-pipeline-1] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.logging.GrpcLoggingService - 1 Beam Fn Logging clients still connected during shutdown.
EINFO:root:Using latest locally built Python SDK docker image.
INFO:root:==================== <function lift_combiners at 0x7ff0bb622de8> ====================
[grpc-default-executor-2] ERROR org.apache.beam.runners.direct.portable.job.ReferenceRunnerJobService - Encountered Unexpected Exception for Invocation job2081823835
java.lang.IllegalArgumentException: Can't get the number of an unknown enum value.
	at org.apache.beam.model.jobmanagement.v1.JobApi$JobState$Enum.getNumber(JobApi.java:8585)
	at org.apache.beam.model.jobmanagement.v1.JobApi$GetJobStateResponse$Builder.setState(JobApi.java:5768)
	at org.apache.beam.runners.direct.portable.job.ReferenceRunnerJobService.getStateStream(ReferenceRunnerJobService.java:237)
	at org.apache.beam.model.jobmanagement.v1.JobServiceGrpc$MethodHandlers.invoke(JobServiceGrpc.java:770)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:171)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.PartialForwardingServerCallListener.onHalfClose(PartialForwardingServerCallListener.java:35)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.ForwardingServerCallListener.onHalfClose(ForwardingServerCallListener.java:23)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.ForwardingServerCallListener$SimpleForwardingServerCallListener.onHalfClose(ForwardingServerCallListener.java:40)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.Contexts$ContextualizedServerCallListener.onHalfClose(Contexts.java:86)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:283)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:707)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
	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)
Mar 19, 2019 3:50:48 PM org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.SerializingExecutor run
SEVERE: Exception while executing runnable org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed@2cc85cf6
java.lang.IllegalStateException: call already closed
	at org.apache.beam.vendor.grpc.v1p13p1.com.google.common.base.Preconditions.checkState(Preconditions.java:444)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.ServerCallImpl.close(ServerCallImpl.java:172)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.stub.ServerCalls$ServerCallStreamObserverImpl.onCompleted(ServerCalls.java:358)
	at org.apache.beam.runners.direct.portable.job.ReferenceRunnerJobService.getStateStream(ReferenceRunnerJobService.java:249)
	at org.apache.beam.model.jobmanagement.v1.JobServiceGrpc$MethodHandlers.invoke(JobServiceGrpc.java:770)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:171)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.PartialForwardingServerCallListener.onHalfClose(PartialForwardingServerCallListener.java:35)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.ForwardingServerCallListener.onHalfClose(ForwardingServerCallListener.java:23)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.ForwardingServerCallListener$SimpleForwardingServerCallListener.onHalfClose(ForwardingServerCallListener.java:40)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.Contexts$ContextualizedServerCallListener.onHalfClose(Contexts.java:86)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:283)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:707)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p13p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
	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)

[direct-runner-worker] WARN org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.environment.DockerCommand - Unable to pull docker image jenkins-docker-apache.bintray.io/beam/python:latest, cause: Received exit code 1 for command 'docker pull jenkins-docker-apache.bintray.io/beam/python:latest'. stderr: Error response from daemon: unknown: Repo 'apache' was not found
[grpc-default-executor-1] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService - GetManifest for /tmp/beam-artifact-staging/job2081823835/MANIFEST
[grpc-default-executor-1] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService - Loading manifest for retrieval token /tmp/beam-artifact-staging/job2081823835/MANIFEST
[grpc-default-executor-1] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService - Manifest at /tmp/beam-artifact-staging/job2081823835/MANIFEST has 0 artifact locations
[grpc-default-executor-1] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService - GetManifest for /tmp/beam-artifact-staging/job2081823835/MANIFEST -> 0 artifacts
[grpc-default-executor-1] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.logging.GrpcLoggingService - Beam Fn Logging client connected.
[grpc-default-executor-1] INFO sdk_worker_main.main - Logging handler created.
[grpc-default-executor-1] INFO sdk_worker_main.start - Status HTTP server running at localhost:44267
[grpc-default-executor-1] INFO sdk_worker_main.main - semi_persistent_directory: /tmp
[grpc-default-executor-1] WARN sdk_worker_main._load_main_session - No session file found: /tmp/staged/pickled_main_session. Functions defined in __main__ (interactive session) may fail. 
[grpc-default-executor-1] WARN pipeline_options.get_all_options - Discarding unparseable args: [u'--enforce_encodability', u'--direct_runner_use_stacked_bundle', u'--enforce_immutability', u'--pipeline_type_check', u'--block_on_run'] 
[grpc-default-executor-1] INFO sdk_worker_main.main - Python sdk harness started with pipeline_options: {'experiments': [u'beam_fn_api'], 'environment_type': u'DOCKER', 'sdk_location': u'container', 'job_name': u'test_windowing_1553010647.08', 'job_endpoint': u'localhost:53261'}
[grpc-default-executor-1] INFO sdk_worker.__init__ - Creating insecure control channel for localhost:35071.
[grpc-default-executor-1] INFO sdk_worker.__init__ - Control channel established.
[grpc-default-executor-1] INFO sdk_worker.__init__ - Initializing SDKHarness with 12 workers.
[grpc-default-executor-1] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.control.FnApiControlClientPoolService - Beam Fn Control client connected with id 1
[grpc-default-executor-1] INFO sdk_worker.create_state_handler - Creating insecure state channel for localhost:40111.
[grpc-default-executor-1] INFO sdk_worker.create_state_handler - State channel established.
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/write/ref_PCollection_PCollection_4:0 
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/write/ref_PCollection_PCollection_24:0:0 
[grpc-default-executor-1] INFO data_plane.create_data_channel - Creating channel for localhost:34671
[grpc-default-executor-1] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.data.GrpcDataService - Beam Fn Data client connected.
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_1:0 
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_17:0 
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/write/ref_PCollection_PCollection_12:0 
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_7:0 
[grpc-default-executor-3] WARN bundle_processor.create_operation - No unique name set for transform fn/write/ref_PCollection_PCollection_24:1:0 
[grpc-default-executor-3] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_15:0 
[grpc-default-executor-3] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_27:0 
[grpc-default-executor-1] INFO sdk_worker.run - No more requests from control plane
[grpc-default-executor-1] INFO sdk_worker.run - SDK Harness waiting for in-flight requests to complete
[grpc-default-executor-1] WARN org.apache.beam.repackaged.beam_runners_direct_java.sdk.fn.data.BeamFnDataGrpcMultiplexer - Hanged up for unknown endpoint.
[grpc-default-executor-3] INFO data_plane.close - Closing all cached grpc data channels.
[grpc-default-executor-3] INFO sdk_worker.close - Closing all cached gRPC state handlers.
[grpc-default-executor-3] INFO sdk_worker.run - Done consuming work.
[grpc-default-executor-3] INFO sdk_worker_main.main - Python sdk harness exiting.
[grpc-default-executor-3] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.logging.GrpcLoggingService - Logging client hanged up.
[reference-runner-pipeline-1] WARN org.apache.beam.repackaged.beam_runners_direct_java.sdk.fn.data.BeamFnDataGrpcMultiplexer - Hanged up for unknown endpoint.
[reference-runner-pipeline-1] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService - Manifest at /tmp/beam-artifact-staging/job2081823835/MANIFEST has 0 artifact locations
[reference-runner-pipeline-1] INFO org.apache.beam.sdk.io.LocalFileSystem - Ignoring failed deletion of file /tmp/beam-artifact-staging/job2081823835/artifacts/ which already does not exist: {}
java.nio.file.NoSuchFileException: /tmp/beam-artifact-staging/job2081823835/artifacts
	at sun.nio.fs.UnixException.translateToIOException(UnixException.java:86)
	at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:102)
	at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:107)
	at sun.nio.fs.UnixFileSystemProvider.implDelete(UnixFileSystemProvider.java:244)
	at sun.nio.fs.AbstractFileSystemProvider.delete(AbstractFileSystemProvider.java:103)
	at java.nio.file.Files.delete(Files.java:1126)
	at org.apache.beam.sdk.io.LocalFileSystem.delete(LocalFileSystem.java:185)
	at org.apache.beam.sdk.io.FileSystems.delete(FileSystems.java:379)
	at org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.artifact.BeamFileSystemArtifactStagingService.removeArtifacts(BeamFileSystemArtifactStagingService.java:168)
	at org.apache.beam.runners.direct.portable.job.ReferenceRunnerJobService.lambda$run$3(ReferenceRunnerJobService.java:194)
	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
	at java.lang.Thread.run(Thread.java:748)
[reference-runner-pipeline-1] INFO org.apache.beam.repackaged.beam_runners_direct_java.runners.fnexecution.artifact.BeamFileSystemArtifactStagingService - Removed dir /tmp/beam-artifact-staging/job2081823835/
.
======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 361, in _run_pardo_state_timers
    assert_that(actual, is_buffered_correctly)
  File "apache_beam/pipeline.py", line 426, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 428, in wait_until_finish
    self._job_id, self._state, self._last_error_message()))
RuntimeError: Pipeline job--2103757121 failed in state FAILED: unknown error

----------------------------------------------------------------------
Ran 31 tests in 194.144s

FAILED (errors=1, skipped=18)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 9m 7s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

Publishing build scan...
https://gradle.com/s/563uz6vgr66ii

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_Python_PVR_Reference #355

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

Changes:

[migryz] Fix pyhamcrest import missing

------------------------------------------
[...truncated 172.44 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 530, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 76, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 103, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 141, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 130, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_register_finalizations (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 838, in test_register_finalizations
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 420, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 305, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 351, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 457, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 33 tests in 0.133s

FAILED (errors=16, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 5m 57s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

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

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_Python_PVR_Reference #354

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

Changes:

[iemejia] Revert "Review: Add some comments & tests"

[iemejia] Revert "[BEAM-6292] PasswordDecrypter: Delay decryption / Avoid

------------------------------------------
[...truncated 172.87 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 530, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 76, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 103, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 141, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 130, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_register_finalizations (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 838, in test_register_finalizations
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 420, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 305, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 351, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 457, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 33 tests in 0.123s

FAILED (errors=16, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 5m 50s
61 actionable tasks: 48 executed, 12 from cache, 1 up-to-date

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

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_Python_PVR_Reference #353

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

Changes:

[jeff] [BEAM-5638] Exception handling for Java MapElements and FlatMapElements

------------------------------------------
[...truncated 211.89 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 530, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 76, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 103, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 141, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 130, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_register_finalizations (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 838, in test_register_finalizations
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 420, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 305, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 351, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 457, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 33 tests in 0.122s

FAILED (errors=16, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 6m 15s
61 actionable tasks: 56 executed, 4 from cache, 1 up-to-date

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

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_Python_PVR_Reference #352

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

Changes:

[github] Correct spark version used by the spark runner in the website

------------------------------------------
[...truncated 172.72 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 530, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 76, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 103, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 141, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 130, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_register_finalizations (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 838, in test_register_finalizations
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 420, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 305, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 351, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 457, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 33 tests in 0.121s

FAILED (errors=16, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 6m 1s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

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

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_Python_PVR_Reference #351

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

------------------------------------------
[...truncated 173.35 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 530, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 76, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 103, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 141, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 130, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_register_finalizations (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 838, in test_register_finalizations
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 420, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 305, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 351, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 457, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 33 tests in 0.192s

FAILED (errors=16, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 5m 57s
61 actionable tasks: 47 executed, 13 from cache, 1 up-to-date

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

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_Python_PVR_Reference #350

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

Changes:

[kcweaver] [BEAM-6865] DefaultJobBundleFactory: create using default

------------------------------------------
[...truncated 174.72 KB...]
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 530, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 76, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 103, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 141, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 130, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_register_finalizations (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 838, in test_register_finalizations
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 420, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 305, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 351, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 457, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 33 tests in 0.116s

FAILED (errors=16, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 5m 29s
61 actionable tasks: 48 executed, 12 from cache, 1 up-to-date

Publishing build scan...

Publishing failed.

The response from https://scans-in.gradle.com/in/5.2.1/2.1 was not from the build scan server.
Your network environment may be interfering, or the service may be unavailable.

If you believe this to be in error, please report this problem via https://gradle.com/scans/help/plugin and include the following via copy/paste:

----------
Gradle version: 5.2.1
Plugin version: 2.1
Request URL: https://scans-in.gradle.com/in/5.2.1/2.1
Request ID: ca20dbe4-2ac6-442d-9002-2b2160d7a22c
Response status code: 503
Response content type: text/html; charset=utf-8
Response server type: cloudflare
----------

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_Python_PVR_Reference #349

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

Changes:

[robertwb] [BEAM-6778] Enable Bundle Finalization in Python SDK harness over FnApi

------------------------------------------
[...truncated 172.70 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 530, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 76, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 103, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 141, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 130, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_register_finalizations (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 838, in test_register_finalizations
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 420, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 305, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 351, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 457, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 33 tests in 0.120s

FAILED (errors=16, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 5m 48s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

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

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_Python_PVR_Reference #348

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

------------------------------------------
[...truncated 169.12 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.116s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 5m 7s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

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

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_Python_PVR_Reference #347

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

------------------------------------------
[...truncated 169.81 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.109s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 5m 35s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

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

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_Python_PVR_Reference #346

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

Changes:

[boyuanz] Reset Datasource counter to 0 in FinishBundle

[boyuanz] Reset count to 0 after all operations have finished bundle

------------------------------------------
[...truncated 170.05 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.201s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 6m 30s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

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

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_Python_PVR_Reference #345

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

Changes:

[ajhalaria] Create a custom hash paritioner that deals with arrays during combines

------------------------------------------
[...truncated 169.44 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.124s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 6m 1s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

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

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_Python_PVR_Reference #344

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

Changes:

[tweise] [flink] debug logging for state access

[github] [BEAM-6866]: SamzaRunner: support timers in ParDo (#8092)

------------------------------------------
[...truncated 169.68 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.119s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 5m 52s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

Publishing build scan...
https://gradle.com/s/75m4uiikcqkba

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_Python_PVR_Reference #343

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

------------------------------------------
[...truncated 169.41 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.120s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 5m 27s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

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

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_Python_PVR_Reference #342

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

Changes:

[iemejia] [BEAM-6854] Update amazon-web-services aws-sdk dependency to version

------------------------------------------
[...truncated 169.83 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.113s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 5m 31s
61 actionable tasks: 48 executed, 12 from cache, 1 up-to-date

Publishing build scan...
https://gradle.com/s/2c7p56rddxuj6

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_Python_PVR_Reference #341

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

------------------------------------------
[...truncated 169.85 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.113s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 5m 23s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

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

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_Python_PVR_Reference #340

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

Changes:

[michal.walenia] [BEAM-6627] Refactor metric gathering mechanism to be more flexible

[michal.walenia] [BEAM-6627] Added metrics to ParquetIOIT

[michal.walenia] [BEAM-6627] Added metrics to AvroIOIT

[michal.walenia] [BEAM-6627] Added metrics to TFRecordIOIT, refactored namespace names

[michal.walenia] [BEAM-6627] Added metrics to XmlIOIT

[michal.walenia] [BEAM-6627] Added metric reporting to all file based test jobs

------------------------------------------
[...truncated 169.39 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.113s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 7m 2s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

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

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_Python_PVR_Reference #339

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

Changes:

[kcweaver] [BEAM-6864] Pass JobInfo to PortablePipelineRunner.run

------------------------------------------
[...truncated 169.87 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.112s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 5m 33s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

Publishing build scan...
https://gradle.com/s/2psbeoqbaew42

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_Python_PVR_Reference #338

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

Changes:

[jeff] [BEAM-6770] Correct zstd-jni dependency scope to tests only

------------------------------------------
[...truncated 169.87 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.213s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 7m 24s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

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

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_Python_PVR_Reference #337

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

------------------------------------------
[...truncated 169.61 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.131s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 7m 27s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

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

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_Python_PVR_Reference #336

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

Changes:

[katarzyna.kucharczyk] [BEAM-6175] Extract reader and publisher from MetricsMonitor in Python

[katarzyna.kucharczyk] [BEAM-6175] Extracted common class for all load tests

------------------------------------------
[...truncated 169.40 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.136s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 5m 46s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

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

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_Python_PVR_Reference #335

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

------------------------------------------
[...truncated 169.63 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.115s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 5m 32s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

Publishing build scan...
https://gradle.com/s/6ri3ljrnysjte

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_Python_PVR_Reference #334

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

Changes:

[juta.staes] [BEAM-6619] [BEAM-6593] fix autocomplete it test

------------------------------------------
[...truncated 169.18 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.117s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 5m 42s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

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

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_Python_PVR_Reference #333

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

------------------------------------------
[...truncated 170.03 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.116s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 5m 50s
61 actionable tasks: 48 executed, 12 from cache, 1 up-to-date

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

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_Python_PVR_Reference #332

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

Changes:

[kyle.winkelman] [BEAM-6851] Support recursive globs in HadoopFileSystem.

------------------------------------------
[...truncated 169.69 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.146s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 6m 11s
61 actionable tasks: 46 executed, 14 from cache, 1 up-to-date

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

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_Python_PVR_Reference #331

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

Changes:

[mxm] [BEAM-6730] Expose Java SDK's GenerateSequence to Python

[mxm] [BEAM-6730] Support Read translation in streaming portable Flink Runner

[mxm] [BEAM-6730] Support Read translation in batch portable Flink Runner

[mxm] [BEAM-6730] Add portable Read translation test

[mxm] [BEAM-6730] Use generic payload to configure external transforms

[mxm] [BEAM-6730] Add Java GenerateSequence expansion test

[mxm] [BEAM-6730] Add Python GenerateSequence integration test

[mxm] [BEAM-6730] Add test for GenerateSequence's external builder

------------------------------------------
[...truncated 171.09 KB...]
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_group_by_key (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 410, in test_group_by_key
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_no_subtransform_composite (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 529, in test_no_subtransform_composite
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 75, in test_pardo
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_metrics (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 102, in test_pardo_metrics
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 140, in test_pardo_side_and_main_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_pardo_side_outputs (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 129, in test_pardo_side_outputs
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_read (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 136, in test_read
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_reshuffle (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 419, in test_reshuffle
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 304, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 350, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

======================================================================
ERROR: test_windowing (__main__.JavaReferenceRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 456, in test_windowing
    with self.create_pipeline() as p:
  File "apache_beam/runners/portability/portable_runner_test.py", line 182, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/apache_beam/runners/portability/java_reference_runner_test.py",> line 79, in create_options
    options = super(JavaReferenceRunnerTest, self).create_options()
  File "apache_beam/runners/portability/portable_runner_test.py", line 175, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 139, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "apache_beam/runners/portability/portable_runner_test.py", line 145, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "apache_beam/runners/portability/portable_runner_test.py", line 108, in _start_local_runner_subprocess_job_service
    cls._subprocess_command(job_port, expansion_port))
TypeError: _subprocess_command() takes exactly 2 arguments (3 given)

----------------------------------------------------------------------
Ran 31 tests in 0.117s

FAILED (errors=14, skipped=16)

> Task :beam-sdks-python:javaReferenceRunnerValidatesRunner FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_PVR_Reference/ws/src/sdks/python/build.gradle'> line: 391

* What went wrong:
Execution failed for task ':beam-sdks-python:javaReferenceRunnerValidatesRunner'.
> 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 5m 36s
61 actionable tasks: 51 executed, 9 from cache, 1 up-to-date

Publishing build scan...
https://gradle.com/s/4e5km6yco53ew

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