See
<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/4/display/redirect?page=changes>
Changes:
[Robert Bradshaw] [BEAM-9577] Migrate PortablePipelineJarCreator to new
artifact service.
[Robert Bradshaw] spotless
[noreply] [BEAM-10144] Update PipelineOptions snippets for best practices
(#11851)
------------------------------------------
[...truncated 727.18 KB...]
at
org.apache.beam.runners.spark.SparkPipelineRunner.run(SparkPipelineRunner.java:109)
at
org.apache.beam.runners.jobsubmission.JobInvocation.runPipeline(JobInvocation.java:83)
at
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask$TrustedFutureInterruptibleTask.runInterruptibly(TrustedListenableFutureTask.java:125)
at
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.InterruptibleTask.run(InterruptibleTask.java:57)
at
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask.run(TrustedListenableFutureTask.java:78)
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)
root: ERROR: org.apache.spark.SparkException: Only one SparkContext may be
running in this JVM (see SPARK-2243). To ignore this error, set
spark.driver.allowMultipleContexts = true. The currently running SparkContext
was created at:
org.apache.spark.api.java.JavaSparkContext.<init>(JavaSparkContext.scala:58)
org.apache.beam.runners.spark.translation.SparkContextFactory.createSparkContext(SparkContextFactory.java:98)
org.apache.beam.runners.spark.translation.SparkContextFactory.getSparkContext(SparkContextFactory.java:64)
org.apache.beam.runners.spark.SparkPipelineRunner.run(SparkPipelineRunner.java:109)
org.apache.beam.runners.jobsubmission.JobInvocation.runPipeline(JobInvocation.java:83)
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask$TrustedFutureInterruptibleTask.runInterruptibly(TrustedListenableFutureTask.java:125)
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.InterruptibleTask.run(InterruptibleTask.java:57)
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask.run(TrustedListenableFutureTask.java:78)
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
java.lang.Thread.run(Thread.java:748)
apache_beam.runners.portability.portable_runner: INFO: Job state changed to
FAILED
--------------------- >> end captured logging << ---------------------
======================================================================
ERROR: test_row (apache_beam.transforms.sql_test.SqlTransformTest)
----------------------------------------------------------------------
Traceback (most recent call last):
File
"<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/apache_beam/transforms/sql_test.py",>
line 147, in test_row
| SqlTransform("SELECT a*a as s, LENGTH(b) AS c FROM PCOLLECTION"))
File
"<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/apache_beam/pvalue.py",>
line 141, in __or__
return self.pipeline.apply(ptransform, self)
File
"<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/apache_beam/pipeline.py",>
line 655, in apply
pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
File
"<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/apache_beam/runners/runner.py",>
line 198, in apply
return m(transform, input, options)
File
"<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/apache_beam/runners/runner.py",>
line 228, in apply_PTransform
return transform.expand(input)
File
"<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/apache_beam/transforms/external.py",>
line 295, in expand
transform_proto.inputs[tag] = context.pcollections.get_id(pcoll)
File
"<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/apache_beam/runners/pipeline_context.py",>
line 92, in get_id
self._id_to_proto[id] = obj.to_runner_api(self._pipeline_context)
File
"<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/apache_beam/pvalue.py",>
line 190, in to_runner_api
coder_id=context.coder_id_from_element_type(self.element_type),
File
"<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/apache_beam/runners/pipeline_context.py",>
line 219, in coder_id_from_element_type
return self.coders.get_id(coders.registry.get_coder(element_type))
File
"<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/apache_beam/coders/typecoders.py",>
line 130, in get_coder
return coder.from_type_hint(typehint, self)
File
"<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/apache_beam/coders/row_coder.py",>
line 90, in from_type_hint
schema = named_fields_to_schema(type_hint._fields)
File
"<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/apache_beam/typehints/schemas.py",>
line 127, in named_fields_to_schema
for (name, type) in names_and_types
File
"<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/apache_beam/typehints/schemas.py",>
line 157, in typing_to_runner_api
"type 'str' is not supported in python 2. Please use 'unicode' or "
ValueError: type 'str' is not supported in python 2. Please use 'unicode' or
'typing.ByteString' instead to unambiguously indicate if this is a UTF-8 string
or a byte array.
-------------------- >> begin captured logging << --------------------
apache_beam.utils.subprocess_server: INFO: Using pre-built snapshot at
<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/java/extensions/sql/expansion-service/build/libs/beam-sdks-java-extensions-sql-expansion-service-2.23.0-SNAPSHOT.jar>
--------------------- >> end captured logging << ---------------------
======================================================================
ERROR: test_zetasql_generate_data
(apache_beam.transforms.sql_test.SqlTransformTest)
----------------------------------------------------------------------
Traceback (most recent call last):
File
"<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/apache_beam/transforms/sql_test.py",>
line 158, in test_zetasql_generate_data
assert_that(out, equal_to([(1, "foo", 3.14)]))
File
"<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/apache_beam/pipeline.py",>
line 547, in __exit__
self.run().wait_until_finish()
File
"<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",>
line 114, in run
state = result.wait_until_finish()
File
"<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/apache_beam/runners/portability/portable_runner.py",>
line 583, in wait_until_finish
raise self._runtime_exception
RuntimeError: Pipeline
BeamApp-jenkins-0610102526-f1554f82_ebf2ce70-93ea-4507-b304-1e3a2c4f16c9 failed
in state FAILED: org.apache.spark.SparkException: Only one SparkContext may be
running in this JVM (see SPARK-2243). To ignore this error, set
spark.driver.allowMultipleContexts = true. The currently running SparkContext
was created at:
org.apache.spark.api.java.JavaSparkContext.<init>(JavaSparkContext.scala:58)
org.apache.beam.runners.spark.translation.SparkContextFactory.createSparkContext(SparkContextFactory.java:98)
org.apache.beam.runners.spark.translation.SparkContextFactory.getSparkContext(SparkContextFactory.java:64)
org.apache.beam.runners.spark.SparkPipelineRunner.run(SparkPipelineRunner.java:109)
org.apache.beam.runners.jobsubmission.JobInvocation.runPipeline(JobInvocation.java:83)
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask$TrustedFutureInterruptibleTask.runInterruptibly(TrustedListenableFutureTask.java:125)
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.InterruptibleTask.run(InterruptibleTask.java:57)
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask.run(TrustedListenableFutureTask.java:78)
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
java.lang.Thread.run(Thread.java:748)
-------------------- >> begin captured logging << --------------------
apache_beam.utils.subprocess_server: INFO: Using pre-built snapshot at
<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/java/extensions/sql/expansion-service/build/libs/beam-sdks-java-extensions-sql-expansion-service-2.23.0-SNAPSHOT.jar>
apache_beam.utils.subprocess_server: INFO: Starting service with ['java' '-jar'
'<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/java/extensions/sql/expansion-service/build/libs/beam-sdks-java-extensions-sql-expansion-service-2.23.0-SNAPSHOT.jar'>
'57397']
apache_beam.utils.subprocess_server: INFO: Starting expansion service at
localhost:57397
root: DEBUG: Waiting for grpc channel to be ready at localhost:57397.
apache_beam.utils.subprocess_server: INFO: beam:external:java:sql:v1:
org.apache.beam.sdk.expansion.service.ExpansionService$ExternalTransformRegistrarLoader$$Lambda$1/1327763628@593634ad
apache_beam.utils.subprocess_server: INFO:
beam:external:java:generate_sequence:v1:
org.apache.beam.sdk.expansion.service.ExpansionService$ExternalTransformRegistrarLoader$$Lambda$1/1327763628@20fa23c1
root: DEBUG: Waiting for grpc channel to be ready at localhost:57397.
root: DEBUG: Waiting for grpc channel to be ready at localhost:57397.
root: DEBUG: Waiting for grpc channel to be ready at localhost:57397.
root: DEBUG: Waiting for grpc channel to be ready at localhost:57397.
root: DEBUG: Waiting for grpc channel to be ready at localhost:57397.
apache_beam.utils.subprocess_server: INFO: Jun 10, 2020 10:25:16 AM
org.apache.beam.sdk.expansion.service.ExpansionService expand
apache_beam.utils.subprocess_server: INFO: INFO: Expanding
'SqlTransform(beam:external:java:sql:v1)' with URN 'beam:external:java:sql:v1'
root: DEBUG: Sending SIGINT to job_server
root: WARNING: Make sure that locally built Python SDK docker image has Python
2.7 interpreter.
root: INFO: Using Python SDK docker image:
apache/beam_python2.7_sdk:2.23.0.dev. If the image is not available at local,
we will try to pull from hub.docker.com
root: WARNING: Make sure that locally built Python SDK docker image has Python
2.7 interpreter.
root: INFO: Using Python SDK docker image:
apache/beam_python2.7_sdk:2.23.0.dev. If the image is not available at local,
we will try to pull from hub.docker.com
apache_beam.runners.portability.fn_api_runner.translations: INFO:
==================== <function lift_combiners at 0x7feefb6bd398>
====================
apache_beam.runners.portability.fn_api_runner.translations: DEBUG: 16 [1, 1, 1,
1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1]
apache_beam.runners.portability.fn_api_runner.translations: DEBUG: Stages:
['external_7SqlTransform(beam:external:java:sql:v1)/BeamValuesRel_13/Create.Values/Read(CreateSource)/Impulse\n
SqlTransform(beam:external:java:sql:v1)/BeamValuesRel_13/Create.Values/Read(CreateSource)/Impulse:beam:transform:impulse:v1\n
must follow: \n downstream_side_inputs: <unknown>',
'external_7SqlTransform(beam:external:java:sql:v1)/BeamValuesRel_13/Create.Values/Read(CreateSource)/MapElements/Map/ParMultiDo(Anonymous)\n
SqlTransform(beam:external:java:sql:v1)/BeamValuesRel_13/Create.Values/Read(CreateSource)/MapElements/Map/ParMultiDo(Anonymous):beam:transform:pardo:v1\n
must follow: \n downstream_side_inputs: <unknown>',
'external_7SqlTransform(beam:external:java:sql:v1)/BeamValuesRel_13/Create.Values/Read(CreateSource)/ParDo(BoundedSourceAsSDFWrapper)/ParMultiDo(BoundedSourceAsSDFWrapper)\n
SqlTransform(beam:external:java:sql:v1)/BeamValuesRel_13/Create.Values/Read(CreateSource)/ParDo(BoundedSourceAsSDFWrapper)/ParMultiDo(BoundedSourceAsSDFWrapper):beam:transform:pardo:v1\n
must follow: \n downstream_side_inputs: <unknown>',
'external_7SqlTransform(beam:external:java:sql:v1)/BeamZetaSqlCalcRel_17/ParDo(Calc)/ParMultiDo(Calc)\n
SqlTransform(beam:external:java:sql:v1)/BeamZetaSqlCalcRel_17/ParDo(Calc)/ParMultiDo(Calc):beam:transform:pardo:v1\n
must follow: \n downstream_side_inputs: <unknown>',
'ref_AppliedPTransform_assert_that/Create/Impulse_5\n
assert_that/Create/Impulse:beam:transform:impulse:v1\n must follow: \n
downstream_side_inputs: <unknown>',
'ref_AppliedPTransform_assert_that/Create/FlatMap(<lambda at core.py:2623>)_6\n
assert_that/Create/FlatMap(<lambda at core.py:2623>):beam:transform:pardo:v1\n
must follow: \n downstream_side_inputs: <unknown>',
'ref_AppliedPTransform_assert_that/Create/Map(decode)_8\n
assert_that/Create/Map(decode):beam:transform:pardo:v1\n must follow: \n
downstream_side_inputs: <unknown>',
'ref_AppliedPTransform_assert_that/WindowInto(WindowIntoFn)_9\n
assert_that/WindowInto(WindowIntoFn):beam:transform:window_into:v1\n must
follow: \n downstream_side_inputs: <unknown>',
'ref_AppliedPTransform_assert_that/ToVoidKey_10\n
assert_that/ToVoidKey:beam:transform:pardo:v1\n must follow: \n
downstream_side_inputs: <unknown>',
'ref_AppliedPTransform_assert_that/Group/pair_with_0_12\n
assert_that/Group/pair_with_0:beam:transform:pardo:v1\n must follow: \n
downstream_side_inputs: <unknown>',
'ref_AppliedPTransform_assert_that/Group/pair_with_1_13\n
assert_that/Group/pair_with_1:beam:transform:pardo:v1\n must follow: \n
downstream_side_inputs: <unknown>',
'ref_AppliedPTransform_assert_that/Group/Flatten_14\n
assert_that/Group/Flatten:beam:transform:flatten:v1\n must follow: \n
downstream_side_inputs: <unknown>',
'ref_AppliedPTransform_assert_that/Group/GroupByKey_15\n
assert_that/Group/GroupByKey:beam:transform:group_by_key:v1\n must follow: \n
downstream_side_inputs: <unknown>',
'ref_AppliedPTransform_assert_that/Group/Map(_merge_tagged_vals_under_key)_16\n
assert_that/Group/Map(_merge_tagged_vals_under_key):beam:transform:pardo:v1\n
must follow: \n downstream_side_inputs: <unknown>',
'ref_AppliedPTransform_assert_that/Unkey_17\n
assert_that/Unkey:beam:transform:pardo:v1\n must follow: \n
downstream_side_inputs: <unknown>',
'ref_AppliedPTransform_assert_that/Match_18\n
assert_that/Match:beam:transform:pardo:v1\n must follow: \n
downstream_side_inputs: <unknown>']
apache_beam.runners.portability.portable_runner: DEBUG: Runner option
'job_name' was already added
apache_beam.runners.portability.portable_runner: DEBUG: Runner option 'runner'
was already added
apache_beam.runners.portability.portable_runner: DEBUG: Runner option
'temp_location' was already added
apache_beam.runners.portability.portable_runner: DEBUG: Runner option
'environment_cache_millis' was already added
apache_beam.runners.portability.portable_runner: DEBUG: Runner option
'job_endpoint' was already added
apache_beam.runners.portability.portable_runner: DEBUG: Runner option
'output_executable_path' was already added
apache_beam.runners.portability.portable_runner: DEBUG: Runner option
'sdk_worker_parallelism' was already added
apache_beam.runners.portability.portable_runner: DEBUG: Runner option
'dataflow_kms_key' was already added
apache_beam.runners.portability.portable_runner: DEBUG: Runner option
'enable_streaming_engine' was already added
apache_beam.runners.portability.portable_runner: DEBUG: Runner option 'project'
was already added
apache_beam.runners.portability.portable_runner: DEBUG: Runner option
'worker_region' was already added
apache_beam.runners.portability.portable_runner: DEBUG: Runner option
'worker_zone' was already added
apache_beam.runners.portability.portable_runner: DEBUG: Runner option 'zone'
was already added
apache_beam.runners.portability.portable_runner: DEBUG: Runner option
'files_to_stage' was already added
apache_beam.runners.portability.portable_runner: DEBUG: Runner option
'streaming' was already added
apache_beam.runners.portability.portable_runner: DEBUG: Runner option
'experiments' was already added
apache_beam.runners.portability.portable_runner: INFO: Job state changed to
STOPPED
apache_beam.runners.portability.portable_runner: INFO: Job state changed to
STARTING
apache_beam.runners.portability.portable_runner: INFO: Job state changed to
RUNNING
root: DEBUG: org.apache.spark.SparkException: Only one SparkContext may be
running in this JVM (see SPARK-2243). To ignore this error, set
spark.driver.allowMultipleContexts = true. The currently running SparkContext
was created at:
org.apache.spark.api.java.JavaSparkContext.<init>(JavaSparkContext.scala:58)
org.apache.beam.runners.spark.translation.SparkContextFactory.createSparkContext(SparkContextFactory.java:98)
org.apache.beam.runners.spark.translation.SparkContextFactory.getSparkContext(SparkContextFactory.java:64)
org.apache.beam.runners.spark.SparkPipelineRunner.run(SparkPipelineRunner.java:109)
org.apache.beam.runners.jobsubmission.JobInvocation.runPipeline(JobInvocation.java:83)
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask$TrustedFutureInterruptibleTask.runInterruptibly(TrustedListenableFutureTask.java:125)
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.InterruptibleTask.run(InterruptibleTask.java:57)
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask.run(TrustedListenableFutureTask.java:78)
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
java.lang.Thread.run(Thread.java:748)
at
org.apache.spark.SparkContext$$anonfun$assertNoOtherContextIsRunning$2.apply(SparkContext.scala:2483)
at
org.apache.spark.SparkContext$$anonfun$assertNoOtherContextIsRunning$2.apply(SparkContext.scala:2479)
at scala.Option.foreach(Option.scala:257)
at
org.apache.spark.SparkContext$.assertNoOtherContextIsRunning(SparkContext.scala:2479)
at
org.apache.spark.SparkContext$.markPartiallyConstructed(SparkContext.scala:2568)
at org.apache.spark.SparkContext.<init>(SparkContext.scala:85)
at
org.apache.spark.api.java.JavaSparkContext.<init>(JavaSparkContext.scala:58)
at
org.apache.beam.runners.spark.translation.SparkContextFactory.createSparkContext(SparkContextFactory.java:98)
at
org.apache.beam.runners.spark.translation.SparkContextFactory.getSparkContext(SparkContextFactory.java:64)
at
org.apache.beam.runners.spark.SparkPipelineRunner.run(SparkPipelineRunner.java:109)
at
org.apache.beam.runners.jobsubmission.JobInvocation.runPipeline(JobInvocation.java:83)
at
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask$TrustedFutureInterruptibleTask.runInterruptibly(TrustedListenableFutureTask.java:125)
at
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.InterruptibleTask.run(InterruptibleTask.java:57)
at
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask.run(TrustedListenableFutureTask.java:78)
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)
root: ERROR: org.apache.spark.SparkException: Only one SparkContext may be
running in this JVM (see SPARK-2243). To ignore this error, set
spark.driver.allowMultipleContexts = true. The currently running SparkContext
was created at:
org.apache.spark.api.java.JavaSparkContext.<init>(JavaSparkContext.scala:58)
org.apache.beam.runners.spark.translation.SparkContextFactory.createSparkContext(SparkContextFactory.java:98)
org.apache.beam.runners.spark.translation.SparkContextFactory.getSparkContext(SparkContextFactory.java:64)
org.apache.beam.runners.spark.SparkPipelineRunner.run(SparkPipelineRunner.java:109)
org.apache.beam.runners.jobsubmission.JobInvocation.runPipeline(JobInvocation.java:83)
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask$TrustedFutureInterruptibleTask.runInterruptibly(TrustedListenableFutureTask.java:125)
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.InterruptibleTask.run(InterruptibleTask.java:57)
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask.run(TrustedListenableFutureTask.java:78)
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
java.lang.Thread.run(Thread.java:748)
apache_beam.runners.portability.portable_runner: INFO: Job state changed to
FAILED
--------------------- >> end captured logging << ---------------------
----------------------------------------------------------------------
XML: nosetests-xlangSqlValidateRunner.xml
----------------------------------------------------------------------
XML:
<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 7 tests in 96.977s
FAILED (errors=4)
> Task :runners:spark:job-server:validatesCrossLanguageRunnerPythonUsingSql
> FAILED
> Task :runners:spark:job-server:sparkJobServerCleanup
Stopping job server pid: 2634.
FAILURE: Build completed with 5 failures.
1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task
':runners:spark:job-server:validatesCrossLanguageRunnerJavaUsingJava'.
> There were failing tests. See the report at:
> file://<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/runners/spark/job-server/build/reports/tests/validatesCrossLanguageRunnerJavaUsingJava/index.html>
* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug
option to get more log output. Run with --scan to get full insights.
==============================================================================
2: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task
':runners:spark:job-server:validatesCrossLanguageRunnerJavaUsingPython'.
> There were failing tests. See the report at:
> file://<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark/ws/src/runners/spark/job-server/build/reports/tests/validatesCrossLanguageRunnerJavaUsingPython/index.html>
* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug
option to get more log output. Run with --scan to get full insights.
==============================================================================
3: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task
':runners:spark:job-server:validatesCrossLanguageRunnerPythonUsingJava'.
> 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.
==============================================================================
4: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task
':runners:spark:job-server:validatesCrossLanguageRunnerPythonUsingPython'.
> 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.
==============================================================================
5: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task
':runners:spark:job-server:validatesCrossLanguageRunnerPythonUsingSql'.
> 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 21m 12s
134 actionable tasks: 100 executed, 32 from cache, 2 up-to-date
Publishing build scan...
https://gradle.com/s/iczhdd37sm7lg
Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
---------------------------------------------------------------------
To unsubscribe, e-mail: [email protected]
For additional commands, e-mail: [email protected]