You are viewing a plain text version of this content. The canonical link for it is here.
Posted to builds@beam.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2020/01/24 14:47:05 UTC

Build failed in Jenkins: beam_PostCommit_Python_Chicago_Taxi_Flink #4

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

Changes:

[echauchot] [BEAM-9065] Reset MetricsContainerStepMapAccumulator upon initialization

[github] Update release guide with extended information.

[github] Add link to mass comment script

[github] Fix typo

[github] Address comments

[github] Update twine install details.

[kirillkozlov] Create initial DataStoreV1Table

[kirillkozlov] Added tests

[kirillkozlov] Implement getTableStatistics

[kirillkozlov] buildIOWriter

[kirillkozlov] Read other types

[kirillkozlov] Better conversion, support complex types

[kirillkozlov] Store DataStore key as VARBINARY

[kirillkozlov] Wrap DoFns in PTransforms

[kirillkozlov] Table property for specifying key field

[kirillkozlov] JavaDoc

[kirillkozlov] Infer schema for RowToEntity

[kirillkozlov] Better conversion performance

[kirillkozlov] Mark Table as `Internal` and `Experimental`

[kirillkozlov] Review changes

[kirillkozlov] Add IT that does not rely on SQL

[kirillkozlov] fix style

[github] cleanup typo

[github] [BEAM-3419, BEAM-9173] Add TODO comment

[iemejia] [BEAM-9172] Add missing parameter to Nexmark CI execution for Flink

[github] Chnage dataflow container version

[hannahjiang] [BEAM-9084] cleaning up docker image tag

[iemejia] Make Spark use of batch based invocation in Nexmark CI jobs cleaner

[ehudm] Update beam website for 2.18.0

[apilloud] [BEAM-9027] Unparse LIKE as binary operator

[github] Blog post for release 2.18.0 (#10575)

[kcweaver] upgrade auto-value to version 1.7

[kcweaver] [BEAM-9149] Add SQL query parameters to public API and enable positional

[bhulette] [BEAM-9072] [SQL] Primitive types should fall through (#10681)

[iemejia] [BEAM-9170] Unify Jenkins job names related to Java 11 testing


------------------------------------------
[...truncated 158.66 KB...]
    severity: ERROR
    short_description: "Column dropped"
    reason {
      type: FEATURE_TYPE_LOW_FRACTION_PRESENT
      short_description: "Column dropped"
      description: "The feature was present in fewer examples than expected."
    }
    path {
      step: "tips"
    }
  }
}
anomaly_info {
  key: "trip_miles"
  value {
    description: "The feature was present in fewer examples than expected."
    severity: ERROR
    short_description: "Column dropped"
    reason {
      type: FEATURE_TYPE_LOW_FRACTION_PRESENT
      short_description: "Column dropped"
      description: "The feature was present in fewer examples than expected."
    }
    path {
      step: "trip_miles"
    }
  }
}
anomaly_info {
  key: "trip_seconds"
  value {
    description: "The feature was present in fewer examples than expected."
    severity: ERROR
    short_description: "Column dropped"
    reason {
      type: FEATURE_TYPE_LOW_FRACTION_PRESENT
      short_description: "Column dropped"
      description: "The feature was present in fewer examples than expected."
    }
    path {
      step: "trip_seconds"
    }
  }
}
anomaly_name_format: SERIALIZED_PATH

Writing anomalies to anomalies path.
Preprocessing train data...
<https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/apache_beam/__init__.py>:84: 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. '
WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/beam/common.py>:51: The name tf.ConfigProto is deprecated. Please use tf.compat.v1.ConfigProto instead.

WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/beam/impl.py>:283: The name tf.SparseTensorValue is deprecated. Please use tf.compat.v1.SparseTensorValue instead.

WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/tf_metadata/schema_utils.py>:313: The name tf.VarLenFeature is deprecated. Please use tf.io.VarLenFeature instead.

WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/tf_metadata/schema_utils.py>:63: The name tf.SparseFeature is deprecated. Please use tf.io.SparseFeature instead.

WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/tf_metadata/schema_utils.py>:110: The name tf.FixedLenFeature is deprecated. Please use tf.io.FixedLenFeature instead.

preprocess.py:149: FutureWarning: _ReadFromBigQuery is experimental.
  | 'Measure time: start' >> beam.ParDo(MeasureTime(namespace)))
<https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/apache_beam/io/gcp/bigquery.py>:1605: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
  temp_location = pcoll.pipeline.options.view_as(
WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/mappers.py>:207: where (from tensorflow.python.ops.array_ops) is deprecated and will be removed in a future version.
Instructions for updating:
Use tf.where in 2.0, which has the same broadcast rule as np.where
WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/mappers.py>:207: where (from tensorflow.python.ops.array_ops) is deprecated and will be removed in a future version.
Instructions for updating:
Use tf.where in 2.0, which has the same broadcast rule as np.where
WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/mappers.py>:1027: to_int64 (from tensorflow.python.ops.math_ops) is deprecated and will be removed in a future version.
Instructions for updating:
Use `tf.cast` instead.
WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/mappers.py>:1027: to_int64 (from tensorflow.python.ops.math_ops) is deprecated and will be removed in a future version.
Instructions for updating:
Use `tf.cast` instead.
WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/beam/impl.py>:240: The name tf.gfile.MakeDirs is deprecated. Please use tf.io.gfile.makedirs instead.

WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/beam/impl.py>:240: The name tf.gfile.MakeDirs is deprecated. Please use tf.io.gfile.makedirs instead.

2020-01-24 14:44:40.368638: I tensorflow/core/platform/cpu_feature_guard.cc:142] Your CPU supports instructions that this TensorFlow binary was not compiled to use: AVX2 FMA
2020-01-24 14:44:40.379968: I tensorflow/core/platform/profile_utils/cpu_utils.cc:94] CPU Frequency: 2300000000 Hz
2020-01-24 14:44:40.381483: I tensorflow/compiler/xla/service/service.cc:168] XLA service 0x8073c60 executing computations on platform Host. Devices:
2020-01-24 14:44:40.381526: I tensorflow/compiler/xla/service/service.cc:175]   StreamExecutor device (0): <undefined>, <undefined>
2020-01-24 14:44:40.397971: W tensorflow/compiler/jit/mark_for_compilation_pass.cc:1412] (One-time warning): Not using XLA:CPU for cluster because envvar TF_XLA_FLAGS=--tf_xla_cpu_global_jit was not set.  If you want XLA:CPU, either set that envvar, or use experimental_jit_scope to enable XLA:CPU.  To confirm that XLA is active, pass --vmodule=xla_compilation_cache=1 (as a proper command-line flag, not via TF_XLA_FLAGS) or set the envvar XLA_FLAGS=--xla_hlo_profile.
WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/saved/saved_transform_io.py>:378: The name tf.saved_model.signature_def_utils.predict_signature_def is deprecated. Please use tf.compat.v1.saved_model.signature_def_utils.predict_signature_def instead.

WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/saved/saved_transform_io.py>:378: The name tf.saved_model.signature_def_utils.predict_signature_def is deprecated. Please use tf.compat.v1.saved_model.signature_def_utils.predict_signature_def instead.

WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow/python/saved_model/signature_def_utils_impl.py>:201: build_tensor_info (from tensorflow.python.saved_model.utils_impl) is deprecated and will be removed in a future version.
Instructions for updating:
This function will only be available through the v1 compatibility library as tf.compat.v1.saved_model.utils.build_tensor_info or tf.compat.v1.saved_model.build_tensor_info.
WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow/python/saved_model/signature_def_utils_impl.py>:201: build_tensor_info (from tensorflow.python.saved_model.utils_impl) is deprecated and will be removed in a future version.
Instructions for updating:
This function will only be available through the v1 compatibility library as tf.compat.v1.saved_model.utils.build_tensor_info or tf.compat.v1.saved_model.build_tensor_info.
WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/saved/saved_transform_io.py>:380: The name tf.saved_model.builder.SavedModelBuilder is deprecated. Please use tf.compat.v1.saved_model.builder.SavedModelBuilder instead.

WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/saved/saved_transform_io.py>:380: The name tf.saved_model.builder.SavedModelBuilder is deprecated. Please use tf.compat.v1.saved_model.builder.SavedModelBuilder instead.

INFO:tensorflow:Assets added to graph.
INFO:tensorflow:Assets added to graph.
INFO:tensorflow:No assets to write.
INFO:tensorflow:No assets to write.
INFO:tensorflow:SavedModel written to: gs://temp-storage-for-perf-tests/chicago-taxi/chicago-taxi-tfdv-20200124-143531/chicago_taxi_output/tft_output/tftransform_tmp/6dc69ad129744da787ca68d172be2f65/saved_model.pb
INFO:tensorflow:SavedModel written to: gs://temp-storage-for-perf-tests/chicago-taxi/chicago-taxi-tfdv-20200124-143531/chicago_taxi_output/tft_output/tftransform_tmp/6dc69ad129744da787ca68d172be2f65/saved_model.pb
INFO:tensorflow:Assets added to graph.
INFO:tensorflow:Assets added to graph.
INFO:tensorflow:No assets to write.
INFO:tensorflow:No assets to write.
INFO:tensorflow:SavedModel written to: gs://temp-storage-for-perf-tests/chicago-taxi/chicago-taxi-tfdv-20200124-143531/chicago_taxi_output/tft_output/tftransform_tmp/0b25bffbf25e4e3fbb272a4010a3b8a1/saved_model.pb
INFO:tensorflow:SavedModel written to: gs://temp-storage-for-perf-tests/chicago-taxi/chicago-taxi-tfdv-20200124-143531/chicago_taxi_output/tft_output/tftransform_tmp/0b25bffbf25e4e3fbb272a4010a3b8a1/saved_model.pb
warning: sdist: standard file not found: should have one of README, README.rst, README.txt, README.md

warning: check: missing required meta-data: url

warning: check: missing meta-data: either (author and author_email) or (maintainer and maintainer_email) must be supplied

ERROR:root:java.lang.RuntimeException: Error received from SDK harness for instruction 61: Traceback (most recent call last):
  File "/usr/local/lib/python2.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 167, in _execute
    response = task()
  File "/usr/local/lib/python2.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 223, in <lambda>
    lambda: self.create_worker().do_instruction(request), request)
  File "/usr/local/lib/python2.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 352, in do_instruction
    request.instruction_id)
  File "/usr/local/lib/python2.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 386, in process_bundle
    bundle_processor.process_bundle(instruction_id))
  File "/usr/local/lib/python2.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 812, in process_bundle
    data.transform_id].process_encoded(data.data)
  File "/usr/local/lib/python2.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 205, in process_encoded
    self.output(decoded_value)
  File "apache_beam/runners/worker/operations.py", line 302, in apache_beam.runners.worker.operations.Operation.output
    def output(self, windowed_value, output_index=0):
  File "apache_beam/runners/worker/operations.py", line 304, in apache_beam.runners.worker.operations.Operation.output
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File "apache_beam/runners/worker/operations.py", line 178, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
    self.consumer.process(windowed_value)
  File "apache_beam/runners/worker/operations.py", line 657, in apache_beam.runners.worker.operations.DoOperation.process
    with self.scoped_process_state:
  File "apache_beam/runners/worker/operations.py", line 658, in apache_beam.runners.worker.operations.DoOperation.process
    delayed_application = self.dofn_receiver.receive(o)
  File "apache_beam/runners/common.py", line 878, in apache_beam.runners.common.DoFnRunner.receive
    self.process(windowed_value)
  File "apache_beam/runners/common.py", line 885, in apache_beam.runners.common.DoFnRunner.process
    self._reraise_augmented(exn)
  File "apache_beam/runners/common.py", line 956, in apache_beam.runners.common.DoFnRunner._reraise_augmented
    raise_with_traceback(new_exn)
  File "apache_beam/runners/common.py", line 883, in apache_beam.runners.common.DoFnRunner.process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "apache_beam/runners/common.py", line 667, in apache_beam.runners.common.PerWindowInvoker.invoke_process
    self._invoke_process_per_window(
  File "apache_beam/runners/common.py", line 748, in apache_beam.runners.common.PerWindowInvoker._invoke_process_per_window
    windowed_value, self.process_method(*args_for_process))
  File "/usr/local/lib/python2.7/site-packages/apache_beam/io/iobase.py", line 1083, in process
    return [window.TimestampedValue(writer.close(), timestamp.MAX_TIMESTAMP)]
  File "/usr/local/lib/python2.7/site-packages/apache_beam/io/filebasedsink.py", line 401, in close
    self.sink.close(self.temp_handle)
  File "/usr/local/lib/python2.7/site-packages/apache_beam/io/filebasedsink.py", line 157, in close
    file_handle.close()
  File "/usr/local/lib/python2.7/site-packages/apache_beam/io/filesystemio.py", line 219, in close
    self._uploader.finish()
  File "/usr/local/lib/python2.7/site-packages/apache_beam/io/gcp/gcsio.py", line 593, in finish
    raise self._upload_thread.last_error  # pylint: disable=raising-bad-type
AttributeError: 'module' object has no attribute '_strptime' [while running 'Analyze/VocabularyWrite[compute_and_apply_vocabulary/vocabulary]/WriteToFile/Write/WriteImpl/WriteBundles']

Traceback (most recent call last):
  File "preprocess.py", line 261, in <module>
    main()
  File "preprocess.py", line 256, in main
    project=known_args.metric_reporting_project
  File "preprocess.py", line 184, in transform_data
    result.wait_until_finish()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/apache_beam/runners/portability/portable_runner.py",> line 455, in wait_until_finish
    self._job_id, self._state, self._last_error_message()))
RuntimeError: Pipeline chicago-taxi-tfdv-20200124-143531_865998aa-81e1-4c52-aeeb-5494e916e7e9 failed in state FAILED: java.lang.RuntimeException: Error received from SDK harness for instruction 61: Traceback (most recent call last):
  File "/usr/local/lib/python2.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 167, in _execute
    response = task()
  File "/usr/local/lib/python2.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 223, in <lambda>
    lambda: self.create_worker().do_instruction(request), request)
  File "/usr/local/lib/python2.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 352, in do_instruction
    request.instruction_id)
  File "/usr/local/lib/python2.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 386, in process_bundle
    bundle_processor.process_bundle(instruction_id))
  File "/usr/local/lib/python2.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 812, in process_bundle
    data.transform_id].process_encoded(data.data)
  File "/usr/local/lib/python2.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 205, in process_encoded
    self.output(decoded_value)
  File "apache_beam/runners/worker/operations.py", line 302, in apache_beam.runners.worker.operations.Operation.output
    def output(self, windowed_value, output_index=0):
  File "apache_beam/runners/worker/operations.py", line 304, in apache_beam.runners.worker.operations.Operation.output
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File "apache_beam/runners/worker/operations.py", line 178, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
    self.consumer.process(windowed_value)
  File "apache_beam/runners/worker/operations.py", line 657, in apache_beam.runners.worker.operations.DoOperation.process
    with self.scoped_process_state:
  File "apache_beam/runners/worker/operations.py", line 658, in apache_beam.runners.worker.operations.DoOperation.process
    delayed_application = self.dofn_receiver.receive(o)
  File "apache_beam/runners/common.py", line 878, in apache_beam.runners.common.DoFnRunner.receive
    self.process(windowed_value)
  File "apache_beam/runners/common.py", line 885, in apache_beam.runners.common.DoFnRunner.process
    self._reraise_augmented(exn)
  File "apache_beam/runners/common.py", line 956, in apache_beam.runners.common.DoFnRunner._reraise_augmented
    raise_with_traceback(new_exn)
  File "apache_beam/runners/common.py", line 883, in apache_beam.runners.common.DoFnRunner.process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "apache_beam/runners/common.py", line 667, in apache_beam.runners.common.PerWindowInvoker.invoke_process
    self._invoke_process_per_window(
  File "apache_beam/runners/common.py", line 748, in apache_beam.runners.common.PerWindowInvoker._invoke_process_per_window
    windowed_value, self.process_method(*args_for_process))
  File "/usr/local/lib/python2.7/site-packages/apache_beam/io/iobase.py", line 1083, in process
    return [window.TimestampedValue(writer.close(), timestamp.MAX_TIMESTAMP)]
  File "/usr/local/lib/python2.7/site-packages/apache_beam/io/filebasedsink.py", line 401, in close
    self.sink.close(self.temp_handle)
  File "/usr/local/lib/python2.7/site-packages/apache_beam/io/filebasedsink.py", line 157, in close
    file_handle.close()
  File "/usr/local/lib/python2.7/site-packages/apache_beam/io/filesystemio.py", line 219, in close
    self._uploader.finish()
  File "/usr/local/lib/python2.7/site-packages/apache_beam/io/gcp/gcsio.py", line 593, in finish
    raise self._upload_thread.last_error  # pylint: disable=raising-bad-type
AttributeError: 'module' object has no attribute '_strptime' [while running 'Analyze/VocabularyWrite[compute_and_apply_vocabulary/vocabulary]/WriteToFile/Write/WriteImpl/WriteBundles']


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

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/sdks/python/test-suites/portable/py2/build.gradle'> line: 197

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py2:chicagoTaxiExample'.
> 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 13m 7s
6 actionable tasks: 5 executed, 1 up-to-date

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

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


Jenkins build is back to normal : beam_PostCommit_Python_Chicago_Taxi_Flink #6

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


---------------------------------------------------------------------
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_Chicago_Taxi_Flink #5

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

Changes:

[keijiy] Fix comments on bigquery.py * beam.io.gcp.WriteToBigQuery ->

[kirillkozlov] Use custom escape method

[kirillkozlov] Inline, link JIRA

[elias.djurfeldt] Added valueprovider support for Datastore query namespaces

[github] Add a minor comment.

[aaltay] Bump tensorflow from 1.14.0 to 1.15.0 in /sdks/python/container (#10392)

[github] [BEAM-9093] Log invalid overwrites in pipeline options (#10613)

[github] [BEAM-8492] Allow None, Optional return hints for DoFn.process and


------------------------------------------
[...truncated 153.96 KB...]
    type: BYTES
    int_domain {
    }
    presence {
      min_fraction: 1.0
      min_count: 1
    }
  }
  feature {
    name: "payment_type"
    value_count {
      min: 1
      max: 1
    }
    type: BYTES
    domain: "payment_type"
    presence {
      min_fraction: 1.0
      min_count: 1
    }
  }
  feature {
    name: "trip_seconds"
    value_count {
      min: 1
      max: 1
    }
    type: INT
    presence {
      min_count: 1
    }
  }
  feature {
    name: "trip_start_day"
    value_count {
      min: 1
      max: 1
    }
    type: INT
    presence {
      min_fraction: 1.0
      min_count: 1
    }
  }
  feature {
    name: "tips"
    value_count {
      min: 1
      max: 1
    }
    type: FLOAT
    presence {
      min_fraction: 1.0
      min_count: 1
    }
  }
  feature {
    name: "pickup_latitude"
    value_count {
      min: 1
      max: 1
    }
    type: FLOAT
    presence {
      min_fraction: 1.0
      min_count: 1
    }
  }
  feature {
    name: "dropoff_latitude"
    value_count {
      min: 1
      max: 1
    }
    type: FLOAT
    presence {
      min_fraction: 1.0
      min_count: 1
    }
  }
  string_domain {
    name: "payment_type"
    value: "Cash"
    value: "Credit Card"
    value: "Pcard"
    value: "Prcard"
  }
}
anomaly_info {
  key: "company"
  value {
    description: "New column (column in data but not in schema)"
    severity: ERROR
    short_description: "New column"
    reason {
      type: SCHEMA_NEW_COLUMN
      short_description: "New column"
      description: "New column (column in data but not in schema)"
    }
    path {
      step: "company"
    }
  }
}
anomaly_info {
  key: "fare"
  value {
    description: "The feature was present in fewer examples than expected."
    severity: ERROR
    short_description: "Column dropped"
    reason {
      type: FEATURE_TYPE_LOW_FRACTION_PRESENT
      short_description: "Column dropped"
      description: "The feature was present in fewer examples than expected."
    }
    path {
      step: "fare"
    }
  }
}
anomaly_info {
  key: "payment_type"
  value {
    description: "Examples contain values missing from the schema: Mobile (<1%), Split (<1%). "
    severity: ERROR
    short_description: "Unexpected string values"
    reason {
      type: ENUM_TYPE_UNEXPECTED_STRING_VALUES
      short_description: "Unexpected string values"
      description: "Examples contain values missing from the schema: Mobile (<1%), Split (<1%). "
    }
    path {
      step: "payment_type"
    }
  }
}
anomaly_info {
  key: "tips"
  value {
    description: "The feature was present in fewer examples than expected."
    severity: ERROR
    short_description: "Column dropped"
    reason {
      type: FEATURE_TYPE_LOW_FRACTION_PRESENT
      short_description: "Column dropped"
      description: "The feature was present in fewer examples than expected."
    }
    path {
      step: "tips"
    }
  }
}
anomaly_info {
  key: "trip_miles"
  value {
    description: "The feature was present in fewer examples than expected."
    severity: ERROR
    short_description: "Column dropped"
    reason {
      type: FEATURE_TYPE_LOW_FRACTION_PRESENT
      short_description: "Column dropped"
      description: "The feature was present in fewer examples than expected."
    }
    path {
      step: "trip_miles"
    }
  }
}
anomaly_name_format: SERIALIZED_PATH

Writing anomalies to anomalies path.
Preprocessing train data...
<https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/apache_beam/__init__.py>:84: 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. '
WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/beam/common.py>:51: The name tf.ConfigProto is deprecated. Please use tf.compat.v1.ConfigProto instead.

WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/beam/impl.py>:283: The name tf.SparseTensorValue is deprecated. Please use tf.compat.v1.SparseTensorValue instead.

WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/tf_metadata/schema_utils.py>:313: The name tf.VarLenFeature is deprecated. Please use tf.io.VarLenFeature instead.

WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/tf_metadata/schema_utils.py>:63: The name tf.SparseFeature is deprecated. Please use tf.io.SparseFeature instead.

WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/tf_metadata/schema_utils.py>:110: The name tf.FixedLenFeature is deprecated. Please use tf.io.FixedLenFeature instead.

preprocess.py:149: FutureWarning: _ReadFromBigQuery is experimental.
  | 'Measure time: start' >> beam.ParDo(MeasureTime(namespace)))
<https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/apache_beam/io/gcp/bigquery.py>:1605: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
  temp_location = pcoll.pipeline.options.view_as(
WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/mappers.py>:207: where (from tensorflow.python.ops.array_ops) is deprecated and will be removed in a future version.
Instructions for updating:
Use tf.where in 2.0, which has the same broadcast rule as np.where
WARNING:tensorflow:From <https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/mappers.py>:207: where (from tensorflow.python.ops.array_ops) is deprecated and will be removed in a future version.
Instructions for updating:
Use tf.where in 2.0, which has the same broadcast rule as np.where
Traceback (most recent call last):
  File "preprocess.py", line 261, in <module>
    main()
  File "preprocess.py", line 256, in main
    project=known_args.metric_reporting_project
  File "preprocess.py", line 157, in transform_data
    ('Analyze' >> tft_beam.AnalyzeDataset(preprocessing_fn)))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/apache_beam/transforms/ptransform.py",> line 989, in __ror__
    return self.transform.__ror__(pvalueish, self.label)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/apache_beam/transforms/ptransform.py",> line 549, in __ror__
    result = p.apply(self, pvalueish, label)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/apache_beam/pipeline.py",> line 537, in apply
    return self.apply(transform, pvalueish)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/apache_beam/pipeline.py",> line 578, in apply
    pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/apache_beam/runners/runner.py",> line 195, in apply
    return m(transform, input, options)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/apache_beam/runners/runner.py",> line 225, in apply_PTransform
    return transform.expand(input)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/beam/impl.py",> line 825, in expand
    input_metadata))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/tensorflow_transform/beam/impl.py",> line 716, in expand
    output_signature = self._preprocessing_fn(copied_inputs)
  File "preprocess.py", line 104, in preprocessing_fn
    _fill_in_missing(inputs[key]),
KeyError: 'company'

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

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_Chicago_Taxi_Flink/ws/src/sdks/python/test-suites/portable/py2/build.gradle'> line: 197

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py2:chicagoTaxiExample'.
> 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 15m 32s
6 actionable tasks: 5 executed, 1 up-to-date

Publishing build scan...
https://gradle.com/s/57xisyhbhk5y2

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