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

Changes:

[apilloud] [BEAM-8630] Validate prepared expression on expand


------------------------------------------
[...truncated 3.74 MB...]
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 185, in _execute
    response = task()
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 242, in <lambda>
    lambda: self.create_worker().do_instruction(request), request)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 378, in do_instruction
    getattr(request, request_type), request.instruction_id)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 413, in process_bundle
    bundle_processor.process_bundle(instruction_id))
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py";,>
 line 839, in process_bundle
    input_op_by_transform_id[data.transform_id].process_encoded(data.data)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py";,>
 line 216, in process_encoded
    self.output(decoded_value)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/worker/operations.py";,>
 line 326, in output
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/worker/operations.py";,>
 line 190, in receive
    self.consumer.process(windowed_value)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/worker/operations.py";,>
 line 679, in process
    delayed_application = self.dofn_runner.process(o)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/common.py";,>
 line 907, in process
    self._reraise_augmented(exn)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/common.py";,>
 line 980, in _reraise_augmented
    raise_with_traceback(new_exn)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/common.py";,>
 line 905, in process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/common.py";,>
 line 680, in invoke_process
    windowed_value, additional_args, additional_kwargs)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/common.py";,>
 line 760, in _invoke_process_per_window
    windowed_value, self.process_method(*args_for_process))
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/io/iobase.py";,>
 line 1088, in _pre_finalize
    return sink.pre_finalize(init_result, write_results)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/io/filebasedsink.py";,>
 line 228, in pre_finalize
    FileSystems.delete(dst_glob_files)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/io/filesystems.py";,>
 line 343, in delete
    return filesystem.delete(paths)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/io/localfilesystem.py";,>
 line 355, in delete
    raise BeamIOError("Delete operation failed", exceptions)
BeamIOError: Delete operation failed with exceptions 
{'/tmp/py-wordcount-direct-00000-of-00002': IOError('No files found to delete 
under: /tmp/py-wordcount-direct-00000-of-00002',), 
'/tmp/py-wordcount-direct-00001-of-00002': IOError('No files found to delete 
under: /tmp/py-wordcount-direct-00001-of-00002',)} [while running 
'write/Write/WriteImpl/PreFinalize'] with exceptions None


> Task 
> :sdks:python:test-suites:portable:py2:portableWordCountFlinkRunnerStreaming 
> FAILED

> Task :sdks:python:test-suites:portable:py2:portableWordCountSparkRunnerBatch
<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/__init__.py>:82:
 UserWarning: You are using Apache Beam with Python 2. New releases of Apache 
Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
INFO:apache_beam.runners.portability.fn_api_runner_transforms:====================
 <function lift_combiners at 0x7f7c1ac59668> ====================
WARNING:apache_beam.utils.subprocess_server:Starting service with ['java' 
'-jar' 
'<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/runners/spark/job-server/build/libs/beam-runners-spark-job-server-2.20.0-SNAPSHOT.jar'>
 '--spark-master-url' 'local[4]' '--artifacts-dir' 
'/tmp/beam-tempMlbrwb/artifactsb7VSGC' '--job-port' '46467' '--artifact-port' 
'0' '--expansion-port' '0']
20/02/10 22:40:53 INFO 
org.apache.beam.runners.fnexecution.jobsubmission.JobServerDriver: 
ArtifactStagingService started on localhost:35101
20/02/10 22:40:53 INFO 
org.apache.beam.runners.fnexecution.jobsubmission.JobServerDriver: Java 
ExpansionService started on localhost:35049
20/02/10 22:40:53 INFO 
org.apache.beam.runners.fnexecution.jobsubmission.JobServerDriver: JobService 
started on localhost:46467
WARNING:apache_beam.options.pipeline_options:Discarding unparseable args: 
['--parallelism=2', '--shutdown_sources_on_final_watermark']
20/02/10 22:40:55 INFO org.apache.beam.runners.spark.SparkJobInvoker: Invoking 
job BeamApp-jenkins-0210224055-f4cfa6e0_f4efa309-e68b-4443-a531-9f8df37e900c
20/02/10 22:40:55 INFO 
org.apache.beam.runners.fnexecution.jobsubmission.JobInvocation: Starting job 
invocation 
BeamApp-jenkins-0210224055-f4cfa6e0_f4efa309-e68b-4443-a531-9f8df37e900c
INFO:root:Waiting until the pipeline has finished because the environment 
"LOOPBACK" has started a component necessary for the execution.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to 
STOPPED
INFO:apache_beam.runners.portability.portable_runner:Job state changed to 
STARTING
INFO:apache_beam.runners.portability.portable_runner:Job state changed to 
RUNNING
20/02/10 22:40:56 INFO org.apache.beam.runners.spark.SparkPipelineRunner: 
PipelineOptions.filesToStage was not specified. Defaulting to files from the 
classpath
20/02/10 22:40:56 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Will 
stage 1 files. (Enable logging at DEBUG level to see which files will be 
staged.)
20/02/10 22:40:56 INFO 
org.apache.beam.runners.spark.translation.SparkContextFactory: Creating a brand 
new Spark Context.
20/02/10 22:40:57 WARN org.apache.hadoop.util.NativeCodeLoader: Unable to load 
native-hadoop library for your platform... using builtin-java classes where 
applicable
20/02/10 22:40:57 INFO org.apache.beam.runners.spark.SparkPipelineRunner: 
Running job 
BeamApp-jenkins-0210224055-f4cfa6e0_f4efa309-e68b-4443-a531-9f8df37e900c on 
Spark master local[4]
20/02/10 22:40:57 INFO 
org.apache.beam.runners.spark.aggregators.AggregatorsAccumulator: Instantiated 
aggregators accumulator: 
20/02/10 22:40:57 INFO 
org.apache.beam.runners.spark.metrics.MetricsAccumulator: Instantiated metrics 
accumulator: MetricQueryResults()
INFO:apache_beam.runners.worker.statecache:Creating state cache with size 0
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure control channel 
for localhost:41895.
INFO:apache_beam.runners.worker.sdk_worker:Control channel established.
INFO:apache_beam.runners.worker.sdk_worker:Initializing SDKHarness with 
unbounded number of workers.
20/02/10 22:41:00 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: Beam 
Fn Control client connected with id 1-1
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure state channel for 
localhost:34903.
INFO:apache_beam.runners.worker.sdk_worker:State channel established.
INFO:apache_beam.runners.worker.data_plane:Creating client data channel for 
localhost:37129
20/02/10 22:41:00 INFO 
org.apache.beam.runners.fnexecution.data.GrpcDataService: Beam Fn Data client 
connected.
20/02/10 22:41:01 WARN 
org.apache.beam.runners.spark.translation.GroupNonMergingWindowsFunctions: 
Either coder LengthPrefixCoder(ByteArrayCoder) or GlobalWindow$Coder is not 
consistent with equals. That might cause issues on some runners.
WARNING:apache_beam.io.filebasedsink:Deleting 4 existing files in target path 
matching: -*-of-%(num_shards)05d
20/02/10 22:41:10 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job 
BeamApp-jenkins-0210224055-f4cfa6e0_f4efa309-e68b-4443-a531-9f8df37e900c: 
Pipeline translated successfully. Computing outputs
INFO:apache_beam.io.filebasedsink:Starting finalize_write threads with 
num_shards: 4 (skipped: 0), batches: 4, num_threads: 4
INFO:apache_beam.io.filebasedsink:Renamed 4 shards in 0.12 seconds.
20/02/10 22:41:17 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job 
BeamApp-jenkins-0210224055-f4cfa6e0_f4efa309-e68b-4443-a531-9f8df37e900c 
finished.
20/02/10 22:41:18 INFO 
org.apache.beam.runners.fnexecution.artifact.AbstractArtifactRetrievalService: 
Manifest at 
/tmp/beam-tempMlbrwb/artifactsb7VSGC/job_6a92e2a4-d9bc-4b80-9d4b-5e5273151c82/MANIFEST
 has 1 artifact locations
20/02/10 22:41:18 INFO 
org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactStagingService:
 Removed dir 
/tmp/beam-tempMlbrwb/artifactsb7VSGC/job_6a92e2a4-d9bc-4b80-9d4b-5e5273151c82/
INFO:apache_beam.runners.portability.portable_runner:Job state changed to DONE
20/02/10 22:41:18 INFO 
org.apache.beam.runners.fnexecution.jobsubmission.InMemoryJobService: Getting 
job metrics for 
BeamApp-jenkins-0210224055-f4cfa6e0_f4efa309-e68b-4443-a531-9f8df37e900c
20/02/10 22:41:18 INFO 
org.apache.beam.runners.fnexecution.jobsubmission.InMemoryJobService: Finished 
getting job metrics for 
BeamApp-jenkins-0210224055-f4cfa6e0_f4efa309-e68b-4443-a531-9f8df37e900c
INFO:root:number of empty lines: 2
INFO:root:average word length: 3
Exception in thread read_state:
Traceback (most recent call last):
  File "/usr/lib/python2.7/threading.py", line 801, in __bootstrap_inner
    self.run()
  File "/usr/lib/python2.7/threading.py", line 754, in run
    self.__target(*self.__args, **self.__kwargs)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 675, in pull_responses
    for response in responses:
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/grpc/_channel.py";,>
 line 413, in next
    return self._next()
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/grpc/_channel.py";,>
 line 706, in _next
    raise self
_MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
        status = StatusCode.UNAVAILABLE
        details = "Socket closed"
        debug_error_string = 
"{"created":"@1581374478.514344706","description":"Error received from peer 
ipv4:127.0.0.1:34903","file":"src/core/lib/surface/call.cc","file_line":1056,"grpc_message":"Socket
 closed","grpc_status":14}"
>

Exception in thread run_worker_1-1:
Traceback (most recent call last):
  File "/usr/lib/python2.7/threading.py", line 801, in __bootstrap_inner
    self.run()
  File "/usr/lib/python2.7/threading.py", line 754, in run
    self.__target(*self.__args, **self.__kwargs)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 153, in run
    for work_request in control_stub.Control(get_responses()):
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/grpc/_channel.py";,>
 line 413, in next
    return self._next()
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/grpc/_channel.py";,>
 line 706, in _next
    raise self
_MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
        status = StatusCode.UNAVAILABLE
        details = "Socket closed"
        debug_error_string = 
"{"created":"@1581374478.514476019","description":"Error received from peer 
ipv4:127.0.0.1:41895","file":"src/core/lib/surface/call.cc","file_line":1056,"grpc_message":"Socket
 closed","grpc_status":14}"
>

ERROR:apache_beam.runners.worker.data_plane:Failed to read inputs in the data 
plane.
Traceback (most recent call last):
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py";,>
 line 419, in _read_inputs
    for elements in elements_iterator:
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/grpc/_channel.py";,>
 line 413, in next
    return self._next()
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/grpc/_channel.py";,>
 line 706, in _next
    raise self
_MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
        status = StatusCode.UNAVAILABLE
        details = "Socket closed"
        debug_error_string = 
"{"created":"@1581374478.514306765","description":"Error received from peer 
ipv4:127.0.0.1:37129","file":"src/core/lib/surface/call.cc","file_line":1056,"grpc_message":"Socket
 closed","grpc_status":14}"
>
Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python2.7/threading.py", line 801, in __bootstrap_inner
    self.run()
  File "/usr/lib/python2.7/threading.py", line 754, in run
    self.__target(*self.__args, **self.__kwargs)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py";,>
 line 434, in <lambda>
    target=lambda: self._read_inputs(elements_iterator),
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py";,>
 line 419, in _read_inputs
    for elements in elements_iterator:
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/grpc/_channel.py";,>
 line 413, in next
    return self._next()
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/grpc/_channel.py";,>
 line 706, in _next
    raise self
_MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
        status = StatusCode.UNAVAILABLE
        details = "Socket closed"
        debug_error_string = 
"{"created":"@1581374478.514306765","description":"Error received from peer 
ipv4:127.0.0.1:37129","file":"src/core/lib/surface/call.cc","file_line":1056,"grpc_message":"Socket
 closed","grpc_status":14}"
>


> Task :sdks:python:test-suites:dataflow:py2:postCommitIT
test_streaming_data_only 
(apache_beam.io.gcp.pubsub_integration_test.PubSubIntegrationTest) ... ok
test_streaming_with_attributes 
(apache_beam.io.gcp.pubsub_integration_test.PubSubIntegrationTest) ... ok
Runs streaming Dataflow job and verifies that user metrics are reported ... ok
test_job_python_from_python_it 
(apache_beam.transforms.external_test_it.ExternalTransformIT) ... ok
test_metrics_fnapi_it 
(apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)
 ... ok
test_metrics_it 
(apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)
 ... ok
test_big_query_write 
(apache_beam.io.gcp.bigquery_write_it_test.BigQueryWriteIntegrationTests) ... ok
test_big_query_write_new_types 
(apache_beam.io.gcp.bigquery_write_it_test.BigQueryWriteIntegrationTests) ... ok
test_big_query_write_schema_autodetect 
(apache_beam.io.gcp.bigquery_write_it_test.BigQueryWriteIntegrationTests) ... 
SKIP: DataflowRunner does not support schema autodetection
test_big_query_write_without_schema 
(apache_beam.io.gcp.bigquery_write_it_test.BigQueryWriteIntegrationTests) ... ok
test_big_query_legacy_sql 
(apache_beam.io.gcp.big_query_query_to_table_it_test.BigQueryQueryToTableIT) 
... ok
test_big_query_new_types 
(apache_beam.io.gcp.big_query_query_to_table_it_test.BigQueryQueryToTableIT) 
... ok
test_big_query_new_types_native 
(apache_beam.io.gcp.big_query_query_to_table_it_test.BigQueryQueryToTableIT) 
... ok
test_big_query_standard_sql 
(apache_beam.io.gcp.big_query_query_to_table_it_test.BigQueryQueryToTableIT) 
... ok
test_big_query_standard_sql_kms_key_native 
(apache_beam.io.gcp.big_query_query_to_table_it_test.BigQueryQueryToTableIT) 
... ok
test_datastore_write_limit 
(apache_beam.io.gcp.datastore_write_it_test.DatastoreWriteIT) ... ok

----------------------------------------------------------------------
XML: nosetests-postCommitIT-df.xml
----------------------------------------------------------------------
XML: 
<https://builds.apache.org/job/beam_PostCommit_Python2/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 52 tests in 3375.472s

OK (SKIP=7)
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_02_09-13205543619408834127?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_20_27-8113323478428128954?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_27_00-14648379784851032316?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_32_42-6715258438591761381?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_39_24-8245132508180474121?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_45_42-4566783644022324328?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_51_45-3698537669155111498?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_02_18-9022439894146561091?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_16_09-6604704584626361513?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_23_52-4597952966346641599?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_30_33-7013007812675884693?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_37_21-17938760518277273365?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_02_09-735815622320280862?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_18_25-11560774936553649999?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_24_43-8769643975653906565?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_31_12-9733072577829970700?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_37_51-6435458581629046219?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_02_13-2187529118855607220?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_14_05-13704192562095956801?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_21_05-16768245472859232930?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_27_37-8144514189428104797?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_33_41-6694288719473715465?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_39_50-17367172005666690114?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_02_09-17807100845095194816?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_08_56-14975736060865435704?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_17_04-2632574440498648631?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_23_10-5163791897618507694?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_29_24-7039369779554247635?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_36_04-6755014046425830390?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_02_08-2914302522672789407?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_09_01-17843496082022292037?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_16_22-17785034663122424485?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_23_05-1701713652293968069?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_29_29-8964886827042266621?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_36_11-3352046089697342540?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_02_09-6358271815565367639?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_10_12-7667920328319741706?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_20_31-17297213201847265712?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_02_09-15922824749230504128?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_09_25-4325526228666946049?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_16_30-18441919892976076067?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_22_37-17652186746025541558?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_29_46-3899833831989799874?project=apache-beam-testing
Worker logs: 
https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2020-02-10_14_37_04-11621299414957116653?project=apache-beam-testing

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task 
':sdks:python:test-suites:portable:py2:portableWordCountFlinkRunnerStreaming'.
> 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 57m 30s
124 actionable tasks: 98 executed, 23 from cache, 3 up-to-date

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

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]

Reply via email to