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/06/20 13:24:06 UTC

Build failed in Jenkins: beam_sonarqube_report #450

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

Changes:

[github] [BEAM-7603] Adding support for ValueProvider in Custom GCS Temp Location

[github] Add link to gRPC.io on website portability page

[agoos] [BEAM7597] Fix Typo on website

------------------------------------------
[...truncated 513.23 KB...]
test_read (apache_beam.io.mongodbio_test.MongoSourceTest) ... ok
test_split (apache_beam.io.mongodbio_test.MongoSourceTest) ... ok
test_read_from_mongodb (apache_beam.io.mongodbio_test.ReadFromMongoDBTest) ... <https://builds.apache.org/job/beam_sonarqube_report/ws/src/sdks/python/build/srcs/sdks/python/apache_beam/io/mongodbio_test.py>:139: FutureWarning: ReadFromMongoDB is experimental.
  uri='mongodb://test', db='db', coll='collection')
ok
test_display_data (apache_beam.io.mongodbio_test.WriteMongoFnTest) ... ok
test_process (apache_beam.io.mongodbio_test.WriteMongoFnTest) ... ok
test_write_to_mongodb_with_existing_id (apache_beam.io.mongodbio_test.WriteToMongoDBTest) ... <https://builds.apache.org/job/beam_sonarqube_report/ws/src/sdks/python/build/srcs/sdks/python/apache_beam/io/mongodbio_test.py>:191: FutureWarning: WriteToMongoDB is experimental.
  | "Write" >> WriteToMongoDB(db='test', coll='test'))
ok
test_write_to_mongodb_with_generated_id (apache_beam.io.mongodbio_test.WriteToMongoDBTest) ... <https://builds.apache.org/job/beam_sonarqube_report/ws/src/sdks/python/build/srcs/sdks/python/apache_beam/io/mongodbio_test.py>:207: FutureWarning: WriteToMongoDB is experimental.
  | "Write" >> WriteToMongoDB(db='test', coll='test'))
ok
test_parquetio_it (apache_beam.io.parquetio_it_test.TestParquetIT) ... SKIP: IT is skipped because --test-pipeline-options is not specified
test_dynamic_work_rebalancing (apache_beam.io.parquetio_test.TestParquet) ... ok
test_int96_type_conversion (apache_beam.io.parquetio_test.TestParquet) ... ok
test_min_bundle_size (apache_beam.io.parquetio_test.TestParquet) ... ok
test_read_all_from_parquet_file_pattern (apache_beam.io.parquetio_test.TestParquet) ... ok
test_read_all_from_parquet_many_file_patterns (apache_beam.io.parquetio_test.TestParquet) ... ok
test_read_all_from_parquet_many_single_files (apache_beam.io.parquetio_test.TestParquet) ... ok
test_read_all_from_parquet_single_file (apache_beam.io.parquetio_test.TestParquet) ... ok
test_read_display_data (apache_beam.io.parquetio_test.TestParquet) ... ok
test_read_reentrant (apache_beam.io.parquetio_test.TestParquet) ... ok
test_read_with_splitting (apache_beam.io.parquetio_test.TestParquet) ... ok
test_read_with_splitting_multiple_row_group (apache_beam.io.parquetio_test.TestParquet) ... ok
test_read_without_splitting (apache_beam.io.parquetio_test.TestParquet) ... ok
test_read_without_splitting_multiple_row_group (apache_beam.io.parquetio_test.TestParquet) ... ok
test_selective_columns (apache_beam.io.parquetio_test.TestParquet) ... ok
test_sink_display_data (apache_beam.io.parquetio_test.TestParquet) ... ok
test_sink_transform (apache_beam.io.parquetio_test.TestParquet) ... ok
test_sink_transform_compressed_0 (apache_beam.io.parquetio_test.TestParquet) ... ok
test_sink_transform_compressed_1 (apache_beam.io.parquetio_test.TestParquet) ... ok
test_sink_transform_compressed_2 (apache_beam.io.parquetio_test.TestParquet) ... ok
test_sink_transform_compressed_3 (apache_beam.io.parquetio_test.TestParquet) ... ok
test_sink_transform_compressed_4 (apache_beam.io.parquetio_test.TestParquet) ... ok
test_sink_transform_int96 (apache_beam.io.parquetio_test.TestParquet) ... ok
test_sink_transform_multiple_row_group (apache_beam.io.parquetio_test.TestParquet) ... ok
test_source_display_data (apache_beam.io.parquetio_test.TestParquet) ... ok
test_split_points (apache_beam.io.parquetio_test.TestParquet) ... ok
test_write_display_data (apache_beam.io.parquetio_test.TestParquet) ... ok
test_good_prec (apache_beam.io.range_trackers_test.LexicographicKeyRangeTrackerTest) ... ok
test_key_to_fraction (apache_beam.io.range_trackers_test.LexicographicKeyRangeTrackerTest) ... ok
test_key_to_fraction_common_prefix (apache_beam.io.range_trackers_test.LexicographicKeyRangeTrackerTest) ... ok
test_key_to_fraction_no_endpoints (apache_beam.io.range_trackers_test.LexicographicKeyRangeTrackerTest) ... ok
test_lots (apache_beam.io.range_trackers_test.LexicographicKeyRangeTrackerTest) ... ok
test_tiny (apache_beam.io.range_trackers_test.LexicographicKeyRangeTrackerTest) ... ok
test_everything_with_unbounded_range (apache_beam.io.range_trackers_test.OffsetRangeTrackerTest) ... ok
test_get_fraction_consumed_dense (apache_beam.io.range_trackers_test.OffsetRangeTrackerTest) ... ok
test_get_fraction_consumed_sparse (apache_beam.io.range_trackers_test.OffsetRangeTrackerTest) ... ok
test_get_position_for_fraction_dense (apache_beam.io.range_trackers_test.OffsetRangeTrackerTest) ... ok
test_split_at_offset (apache_beam.io.range_trackers_test.OffsetRangeTrackerTest) ... ok
test_split_at_offset_fails_if_unstarted (apache_beam.io.range_trackers_test.OffsetRangeTrackerTest) ... ok
test_try_return_first_record_not_split_point (apache_beam.io.range_trackers_test.OffsetRangeTrackerTest) ... ok
test_try_return_record_continuous_until_split_point (apache_beam.io.range_trackers_test.OffsetRangeTrackerTest) ... ok
test_try_return_record_non_monotonic (apache_beam.io.range_trackers_test.OffsetRangeTrackerTest) ... ok
test_try_return_record_simple_dense (apache_beam.io.range_trackers_test.OffsetRangeTrackerTest) ... ok
test_try_return_record_simple_sparse (apache_beam.io.range_trackers_test.OffsetRangeTrackerTest) ... ok
test_try_split_points (apache_beam.io.range_trackers_test.OffsetRangeTrackerTest) ... ok
test_claim_order (apache_beam.io.range_trackers_test.OrderedPositionRangeTrackerTest) ... ok
test_fraction_consumed (apache_beam.io.range_trackers_test.OrderedPositionRangeTrackerTest) ... ok
test_out_of_range (apache_beam.io.range_trackers_test.OrderedPositionRangeTrackerTest) ... ok
test_try_claim (apache_beam.io.range_trackers_test.OrderedPositionRangeTrackerTest) ... ok
test_try_split (apache_beam.io.range_trackers_test.OrderedPositionRangeTrackerTest) ... ok
test_try_claim (apache_beam.io.range_trackers_test.UnsplittableRangeTrackerTest) ... ok
test_try_split_fails (apache_beam.io.range_trackers_test.UnsplittableRangeTrackerTest) ... ok
test_create (apache_beam.io.restriction_trackers_test.OffsetRangeTest) ... ok
test_split_no_small_split_at_end (apache_beam.io.restriction_trackers_test.OffsetRangeTest) ... ok
test_split_respects_desired_num_splits (apache_beam.io.restriction_trackers_test.OffsetRangeTest) ... ok
test_split_respects_min_num_splits (apache_beam.io.restriction_trackers_test.OffsetRangeTest) ... ok
test_check_done_after_try_claim_past_end_of_range (apache_beam.io.restriction_trackers_test.OffsetRestrictionTrackerTest) ... ok
test_check_done_after_try_claim_right_before_end_of_range (apache_beam.io.restriction_trackers_test.OffsetRestrictionTrackerTest) ... ok
test_check_done_when_not_done (apache_beam.io.restriction_trackers_test.OffsetRestrictionTrackerTest) ... ok
test_checkpoint_after_failed_claim (apache_beam.io.restriction_trackers_test.OffsetRestrictionTrackerTest) ... ok
test_checkpoint_claimed_last (apache_beam.io.restriction_trackers_test.OffsetRestrictionTrackerTest) ... ok
test_checkpoint_just_started (apache_beam.io.restriction_trackers_test.OffsetRestrictionTrackerTest) ... ok
test_checkpoint_regular (apache_beam.io.restriction_trackers_test.OffsetRestrictionTrackerTest) ... ok
test_checkpoint_unstarted (apache_beam.io.restriction_trackers_test.OffsetRestrictionTrackerTest) ... ok
test_claim_before_starting_range (apache_beam.io.restriction_trackers_test.OffsetRestrictionTrackerTest) ... ok
test_non_monotonic_claim (apache_beam.io.restriction_trackers_test.OffsetRestrictionTrackerTest) ... ok
test_try_claim (apache_beam.io.restriction_trackers_test.OffsetRestrictionTrackerTest) ... ok
test_read_from_source (apache_beam.io.source_test_utils_test.SourceTestUtilsTest) ... ok
test_source_equals_reference_source (apache_beam.io.source_test_utils_test.SourceTestUtilsTest) ... ok
test_split_at_fraction_binary (apache_beam.io.source_test_utils_test.SourceTestUtilsTest) ... ok
test_split_at_fraction_exhaustive (apache_beam.io.source_test_utils_test.SourceTestUtilsTest) ... ok
test_split_at_fraction_fails (apache_beam.io.source_test_utils_test.SourceTestUtilsTest) ... ok
test_split_at_fraction_successful (apache_beam.io.source_test_utils_test.SourceTestUtilsTest) ... ok
test_read_from_source (apache_beam.io.sources_test.SourcesTest) ... ok
test_run_direct (apache_beam.io.sources_test.SourcesTest) ... ok
test_write_bzip2_file (apache_beam.io.textio_test.TextSinkTest) ... ok
test_write_bzip2_file_auto (apache_beam.io.textio_test.TextSinkTest) ... ok
test_write_dataflow (apache_beam.io.textio_test.TextSinkTest) ... ok
test_write_dataflow_auto_compression (apache_beam.io.textio_test.TextSinkTest) ... ok
test_write_dataflow_auto_compression_unsharded (apache_beam.io.textio_test.TextSinkTest) ... ok
test_write_dataflow_header (apache_beam.io.textio_test.TextSinkTest) ... ok
test_write_deflate_file (apache_beam.io.textio_test.TextSinkTest) ... ok
test_write_deflate_file_auto (apache_beam.io.textio_test.TextSinkTest) ... ok
test_write_deflate_file_empty (apache_beam.io.textio_test.TextSinkTest) ... ok
test_write_gzip_file (apache_beam.io.textio_test.TextSinkTest) ... ok
test_write_gzip_file_auto (apache_beam.io.textio_test.TextSinkTest) ... ok
test_write_gzip_file_empty (apache_beam.io.textio_test.TextSinkTest) ... ok
test_write_text_file (apache_beam.io.textio_test.TextSinkTest) ... ok
test_write_text_file_empty (apache_beam.io.textio_test.TextSinkTest) ... ok
test_write_text_file_empty_with_header (apache_beam.io.textio_test.TextSinkTest) ... ok
test_write_text_file_with_header (apache_beam.io.textio_test.TextSinkTest) ... ok
test_dynamic_work_rebalancing (apache_beam.io.textio_test.TextSourceTest) ... ok
test_dynamic_work_rebalancing_mixed_eol (apache_beam.io.textio_test.TextSourceTest) ... ok
test_dynamic_work_rebalancing_windows_eol (apache_beam.io.textio_test.TextSourceTest) ... ok
test_header_processing (apache_beam.io.textio_test.TextSourceTest) ... ok
test_progress (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_after_splitting (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_after_splitting_skip_header (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_all_file_pattern (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_all_gzip (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_all_many_file_patterns (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_all_many_single_files (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_all_single_file (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_all_unavailable_files_ignored (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_auto_bzip2 (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_auto_deflate (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_auto_gzip (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_bzip2 (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_bzip2_concat (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_corrupted_bzip2_fails (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_corrupted_deflate_fails (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_corrupted_gzip_fails (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_deflate (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_deflate_concat (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_empty_single_file (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_empty_single_file_no_eol_gzip (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_file_pattern (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_file_pattern_with_empty_files (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_from_text_file_pattern (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_from_text_single_file (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_from_text_single_file_with_coder (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_from_text_with_file_name_file_pattern (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_from_text_with_file_name_single_file (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_gzip (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_gzip_concat (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_gzip_empty_file (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_gzip_large (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_gzip_large_after_splitting (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_gzip_with_skip_lines (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_reentrant_after_splitting (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_reentrant_without_splitting (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_single_file (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_single_file_larger_than_default_buffer (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_single_file_last_line_no_eol (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_single_file_last_line_no_eol_gzip (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_single_file_mixed_eol (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_single_file_single_line_no_eol (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_single_file_single_line_no_eol_gzip (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_single_file_smaller_than_default_buffer (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_single_file_windows_eol (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_single_file_with_empty_lines (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_single_file_without_striping_eol_crlf (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_single_file_without_striping_eol_lf (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_skip_header_pattern (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_skip_header_pattern_insufficient_lines (apache_beam.io.textio_test.TextSourceTest) ... ok
test_read_skip_header_single (apache_beam.io.textio_test.TextSourceTest) ... ok
test_end2end (apache_beam.io.tfrecordio_test.TestEnd2EndWriteAndRead) ... ok
test_end2end_auto_compression (apache_beam.io.tfrecordio_test.TestEnd2EndWriteAndRead) ... ok
test_end2end_auto_compression_unsharded (apache_beam.io.tfrecordio_test.TestEnd2EndWriteAndRead) ... ok
test_end2end_example_proto (apache_beam.io.tfrecordio_test.TestEnd2EndWriteAndRead) ... SKIP: tensorflow not installed.
test_end2end_read_write_read (apache_beam.io.tfrecordio_test.TestEnd2EndWriteAndRead) ... ok
test_process_auto (apache_beam.io.tfrecordio_test.TestReadAllFromTFRecord) ... ok
test_process_deflate (apache_beam.io.tfrecordio_test.TestReadAllFromTFRecord) ... ok
test_process_glob (apache_beam.io.tfrecordio_test.TestReadAllFromTFRecord) ... ok
test_process_gzip (apache_beam.io.tfrecordio_test.TestReadAllFromTFRecord) ... ok
test_process_multiple (apache_beam.io.tfrecordio_test.TestReadAllFromTFRecord) ... ok
test_process_multiple_globs (apache_beam.io.tfrecordio_test.TestReadAllFromTFRecord) ... ok
test_process_single (apache_beam.io.tfrecordio_test.TestReadAllFromTFRecord) ... ok
test_process_auto (apache_beam.io.tfrecordio_test.TestReadFromTFRecord) ... ok
test_process_deflate (apache_beam.io.tfrecordio_test.TestReadFromTFRecord) ... ok
test_process_gzip (apache_beam.io.tfrecordio_test.TestReadFromTFRecord) ... ok
test_process_gzip_auto (apache_beam.io.tfrecordio_test.TestReadFromTFRecord) ... ok
test_process_multiple (apache_beam.io.tfrecordio_test.TestReadFromTFRecord) ... ok
test_process_single (apache_beam.io.tfrecordio_test.TestReadFromTFRecord) ... ok
test_write_record_multiple (apache_beam.io.tfrecordio_test.TestTFRecordSink) ... ok
test_write_record_single (apache_beam.io.tfrecordio_test.TestTFRecordSink) ... ok
test_compatibility_read_write (apache_beam.io.tfrecordio_test.TestTFRecordUtil) ... ok
test_masked_crc32c (apache_beam.io.tfrecordio_test.TestTFRecordUtil) ... ok
test_masked_crc32c_crcmod (apache_beam.io.tfrecordio_test.TestTFRecordUtil) ... ok
test_read_record (apache_beam.io.tfrecordio_test.TestTFRecordUtil) ... ok
test_read_record_invalid_data_mask (apache_beam.io.tfrecordio_test.TestTFRecordUtil) ... ok
test_read_record_invalid_length_mask (apache_beam.io.tfrecordio_test.TestTFRecordUtil) ... ok
test_read_record_invalid_record (apache_beam.io.tfrecordio_test.TestTFRecordUtil) ... ok
test_write_record (apache_beam.io.tfrecordio_test.TestTFRecordUtil) ... ok
test_write_record_auto (apache_beam.io.tfrecordio_test.TestWriteToTFRecord) ... SKIP: tensorflow not installed.
test_write_record_gzip (apache_beam.io.tfrecordio_test.TestWriteToTFRecord) ... SKIP: tensorflow not installed.
test_write_record_multiple (apache_beam.io.tfrecordio_test.TestWriteToTFRecord) ... SKIP: tensorflow not installed.
test_write_record_single (apache_beam.io.tfrecordio_test.TestWriteToTFRecord) ... SKIP: tensorflow not installed.
test_allow_malformed_records (apache_beam.io.vcfio_test.VcfSourceTest) ... ok
test_custom_phaseset (apache_beam.io.vcfio_test.VcfSourceTest) ... ok
test_dynamic_work_rebalancing (apache_beam.io.vcfio_test.VcfSourceTest) ... ok
test_end_info_key (apache_beam.io.vcfio_test.VcfSourceTest) ... ok
test_file_pattern_verify_details (apache_beam.io.vcfio_test.VcfSourceTest) ... ok
test_format_numbers (apache_beam.io.vcfio_test.VcfSourceTest) ... ok
test_info_numbers_and_types (apache_beam.io.vcfio_test.VcfSourceTest) ... ok
test_invalid_file (apache_beam.io.vcfio_test.VcfSourceTest) ... ok
test_no_info (apache_beam.io.vcfio_test.VcfSourceTest) ... ok
test_no_samples (apache_beam.io.vcfio_test.VcfSourceTest) ... ok
test_pipeline_read_file_pattern_large (apache_beam.io.vcfio_test.VcfSourceTest) ... ok
test_pipeline_read_single_file (apache_beam.io.vcfio_test.VcfSourceTest) ... ok
test_pipeline_read_single_file_large (apache_beam.io.vcfio_test.VcfSourceTest) ... ok
test_read_after_splitting (apache_beam.io.vcfio_test.VcfSourceTest) ... ok
test_read_file_pattern_large (apache_beam.io.vcfio_test.VcfSourceTest) ... scripts/run_tox.sh: line 52:   435 Terminated              tox -c tox.ini --recreate -e $1 --installpkg $2

Daemon will be stopped at the end of the build after the daemon was no longer found in the daemon registry
The message received from the daemon indicates that the daemon has disappeared.
Build request sent: Build{id=14917dad-2a2e-4b4d-953e-2bcbd42e0a67, currentDir=<https://builds.apache.org/job/beam_sonarqube_report/ws/src}>
Attempting to read last messages from the daemon log...
Daemon pid: 1664
  log file: /home/jenkins/.gradle/daemon/5.2.1/daemon-1664.out.log
----- Last  20 lines from daemon log file - daemon-1664.out.log -----
	at org.gradle.process.internal.DefaultExecHandle.execExceptionFor(DefaultExecHandle.java:232)
	at org.gradle.process.internal.DefaultExecHandle.setEndStateInfo(DefaultExecHandle.java:209)
	at org.gradle.process.internal.DefaultExecHandle.failed(DefaultExecHandle.java:356)
	at org.gradle.process.internal.ExecHandleRunner.run(ExecHandleRunner.java:86)
	at org.gradle.internal.operations.CurrentBuildOperationPreservingRunnable.run(CurrentBuildOperationPreservingRunnable.java:42)
	at org.gradle.internal.concurrent.ExecutorPolicy$CatchAndRecordFailures.onExecute(ExecutorPolicy.java:63)
	at org.gradle.internal.concurrent.ManagedExecutorImpl$1.run(ManagedExecutorImpl.java:46)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
	at org.gradle.internal.concurrent.ThreadFactoryImpl$ManagedThreadRunnable.run(ThreadFactoryImpl.java:55)
	at java.lang.Thread.run(Thread.java:748)
Caused by: java.lang.IllegalStateException: Shutdown in progress
	at java.lang.ApplicationShutdownHooks.remove(ApplicationShutdownHooks.java:82)
	at java.lang.Runtime.removeShutdownHook(Runtime.java:239)
	at org.gradle.process.internal.shutdown.ShutdownHooks.removeShutdownHook(ShutdownHooks.java:33)
	at org.gradle.process.internal.DefaultExecHandle.setEndStateInfo(DefaultExecHandle.java:199)
	at org.gradle.process.internal.DefaultExecHandle.aborted(DefaultExecHandle.java:352)
	at org.gradle.process.internal.ExecHandleRunner.completed(ExecHandleRunner.java:107)
	at org.gradle.process.internal.ExecHandleRunner.run(ExecHandleRunner.java:83)
	... 7 more
----- End of the daemon log -----


FAILURE: Build failed with an exception.

* What went wrong:
Gradle build daemon disappeared unexpectedly (it may have been killed or may have crashed)

* 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
Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
WARN: Unable to locate 'report-task.txt' in the workspace. Did the SonarScanner succeeded?

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