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 2023/03/25 22:57:18 UTC

Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow_V2 #4690

See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/4690/display/redirect>

Changes:


------------------------------------------
[...truncated 167.85 KB...]

self = <grpc._channel._UnaryUnaryMultiCallable object at 0x7fe7a4211f90>
request = name: "projects/apache-beam-testing/subscriptions/exercise_streaming_metrics_subscription_input380eafea-7fd1-4cd8-9d1f...opic: "projects/apache-beam-testing/topics/exercise_streaming_metrics_topic_input380eafea-7fd1-4cd8-9d1f-afbe177fb2c4"

timeout = 60.0
metadata = [('x-goog-request-params', 'name=projects/apache-beam-testing/subscriptions/exercise_streaming_metrics_subscription_input380eafea-7fd1-4cd8-9d1f-afbe177fb2c4'), ('x-goog-api-client', 'gl-python/3.7.12 grpc/1.51.3 gax/2.11.0 gccl/2.15.2')]
credentials = None, wait_for_ready = None, compression = None

    def __call__(self,
                 request,
                 timeout=None,
                 metadata=None,
                 credentials=None,
                 wait_for_ready=None,
                 compression=None):
        state, call, = self._blocking(request, timeout, metadata, credentials,
                                      wait_for_ready, compression)
>       return _end_unary_response_blocking(state, call, False, None)

../../build/gradleenv/-1734967052/lib/python3.7/site-packages/grpc/_channel.py:946: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

state = <grpc._channel._RPCState object at 0x7fe7a4239510>
call = <grpc._cython.cygrpc.SegregatedCall object at 0x7fe7a423a730>
with_call = False, deadline = None

    def _end_unary_response_blocking(state, call, with_call, deadline):
        if state.code is grpc.StatusCode.OK:
            if with_call:
                rendezvous = _MultiThreadedRendezvous(state, call, None, deadline)
                return state.response, rendezvous
            else:
                return state.response
        else:
>           raise _InactiveRpcError(state)
E           grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
E           	status = StatusCode.DEADLINE_EXCEEDED
E           	details = "Deadline Exceeded"
E           	debug_error_string = "UNKNOWN:Deadline Exceeded {grpc_status:4, created_time:"2023-03-25T22:46:05.766337619+00:00"}"
E           >

../../build/gradleenv/-1734967052/lib/python3.7/site-packages/grpc/_channel.py:849: _InactiveRpcError

The above exception was the direct cause of the following exception:

self = <apache_beam.runners.dataflow.dataflow_exercise_streaming_metrics_pipeline_test.ExerciseStreamingMetricsPipelineTest testMethod=test_streaming_pipeline_returns_expected_user_metrics_fnapi_it>

    def setUp(self):
      """Creates all required topics and subs."""
      self.test_pipeline = TestPipeline(is_integration_test=True)
      self.project = self.test_pipeline.get_option('project')
      self.uuid = str(uuid.uuid4())
    
      # Set up PubSub environment.
      from google.cloud import pubsub
      self.pub_client = pubsub.PublisherClient()
      self.input_topic_name = INPUT_TOPIC + self.uuid
      self.input_topic = self.pub_client.create_topic(
          name=self.pub_client.topic_path(self.project, self.input_topic_name))
    
      self.output_topic_name = OUTPUT_TOPIC + self.uuid
      self.output_topic = self.pub_client.create_topic(
          name=self.pub_client.topic_path(self.project, self.output_topic_name))
    
      self.sub_client = pubsub.SubscriberClient()
      self.input_sub_name = INPUT_SUB + self.uuid
      self.input_sub = self.sub_client.create_subscription(
          name=self.sub_client.subscription_path(
              self.project, self.input_sub_name),
>         topic=self.input_topic.name)

apache_beam/runners/dataflow/dataflow_exercise_streaming_metrics_pipeline_test.py:88: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
../../build/gradleenv/-1734967052/lib/python3.7/site-packages/google/pubsub_v1/services/subscriber/client.py:682: in create_subscription
    metadata=metadata,
../../build/gradleenv/-1734967052/lib/python3.7/site-packages/google/api_core/gapic_v1/method.py:113: in __call__
    return wrapped_func(*args, **kwargs)
../../build/gradleenv/-1734967052/lib/python3.7/site-packages/google/api_core/retry.py:354: in retry_wrapped_func
    on_error=on_error,
../../build/gradleenv/-1734967052/lib/python3.7/site-packages/google/api_core/retry.py:191: in retry_target
    return target()
../../build/gradleenv/-1734967052/lib/python3.7/site-packages/google/api_core/timeout.py:120: in func_with_timeout
    return func(*args, **kwargs)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

args = (name: "projects/apache-beam-testing/subscriptions/exercise_streaming_metrics_subscription_input380eafea-7fd1-4cd8-9d1...ic: "projects/apache-beam-testing/topics/exercise_streaming_metrics_topic_input380eafea-7fd1-4cd8-9d1f-afbe177fb2c4"
,)
kwargs = {'metadata': [('x-goog-request-params', 'name=projects/apache-beam-testing/subscriptions/exercise_streaming_metrics_su...d8-9d1f-afbe177fb2c4'), ('x-goog-api-client', 'gl-python/3.7.12 grpc/1.51.3 gax/2.11.0 gccl/2.15.2')], 'timeout': 60.0}

    @functools.wraps(callable_)
    def error_remapped_callable(*args, **kwargs):
        try:
            return callable_(*args, **kwargs)
        except grpc.RpcError as exc:
>           raise exceptions.from_grpc_error(exc) from exc
E           google.api_core.exceptions.DeadlineExceeded: 504 Deadline Exceeded

../../build/gradleenv/-1734967052/lib/python3.7/site-packages/google/api_core/grpc_helpers.py:74: DeadlineExceeded
=============================== warnings summary ===============================
../../build/gradleenv/-1734967052/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/-1734967052/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

../../build/gradleenv/-1734967052/lib/python3.7/site-packages/pkg_resources/__init__.py:121
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/-1734967052/lib/python3.7/site-packages/pkg_resources/__init__.py>:121: DeprecationWarning: pkg_resources is deprecated as an API
    warnings.warn("pkg_resources is deprecated as an API", DeprecationWarning)

../../build/gradleenv/-1734967052/lib/python3.7/site-packages/pkg_resources/__init__.py:2870: 18 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/-1734967052/lib/python3.7/site-packages/pkg_resources/__init__.py>:2870: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/-1734967052/lib/python3.7/site-packages/pkg_resources/__init__.py:2870: 13 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/-1734967052/lib/python3.7/site-packages/pkg_resources/__init__.py>:2870: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.cloud')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/-1734967052/lib/python3.7/site-packages/pkg_resources/__init__.py:2349
../../build/gradleenv/-1734967052/lib/python3.7/site-packages/pkg_resources/__init__.py:2349
../../build/gradleenv/-1734967052/lib/python3.7/site-packages/pkg_resources/__init__.py:2349
../../build/gradleenv/-1734967052/lib/python3.7/site-packages/pkg_resources/__init__.py:2349
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/-1734967052/lib/python3.7/site-packages/pkg_resources/__init__.py>:2349: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(parent)

../../build/gradleenv/-1734967052/lib/python3.7/site-packages/pkg_resources/__init__.py:2870
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/-1734967052/lib/python3.7/site-packages/pkg_resources/__init__.py>:2870: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.logging')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/-1734967052/lib/python3.7/site-packages/pkg_resources/__init__.py:2870
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/-1734967052/lib/python3.7/site-packages/pkg_resources/__init__.py>:2870: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.iam')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/-1734967052/lib/python3.7/site-packages/google/rpc/__init__.py:20
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/-1734967052/lib/python3.7/site-packages/google/rpc/__init__.py>:20: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.rpc')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    pkg_resources.declare_namespace(__name__)

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py37-noxdist.xml> -
=========================== short test summary info ============================
FAILED apache_beam/runners/dataflow/dataflow_exercise_streaming_metrics_pipeline_test.py::ExerciseStreamingMetricsPipelineTest::test_streaming_pipeline_returns_expected_user_metrics_fnapi_it - google.api_core.exceptions.DeadlineExceeded: 504 Deadline Exceeded
==== 1 failed, 9 skipped, 6860 deselected, 40 warnings in 70.76s (0:01:10) =====

> Task :sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests FAILED

> Task :sdks:python:test-suites:dataflow:py310:validatesRunnerStreamingTests
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:238 2023-03-25T22:46:09.865Z: JOB_MESSAGE_BASIC: Your project already contains 100 Dataflow-created metric descriptors, so new user metrics of the form custom.googleapis.com/* will not be created. However, all user metrics are also available in the metric dataflow.googleapis.com/job/user_counter. If you rely on the custom metrics, you can delete old / unused metric descriptors. See https://developers.google.com/apis-explorer/#p/monitoring/v3/monitoring.projects.metricDescriptors.list and https://developers.google.com/apis-explorer/#p/monitoring/v3/monitoring.projects.metricDescriptors.delete
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:238 2023-03-25T22:46:37.871Z: JOB_MESSAGE_DETAILED: Autoscaling: Raised the number of workers to 1 so that the pipeline can catch up with its backlog and keep up with its input rate.
WARNING  apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:249 Timing out on waiting for job 2023-03-25_15_45_48-5541706705865552262 after 61 seconds
PASSED

=============================== warnings summary ===============================
../../build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib and slated for removal in Python 3.12; see the module's documentation for alternative uses
    from imp import load_source

../../build/gradleenv/2050596098/lib/python3.10/site-packages/pkg_resources/__init__.py:121
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/pkg_resources/__init__.py>:121: DeprecationWarning: pkg_resources is deprecated as an API
    warnings.warn("pkg_resources is deprecated as an API", DeprecationWarning)

../../build/gradleenv/2050596098/lib/python3.10/site-packages/pkg_resources/__init__.py:2870: 18 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/pkg_resources/__init__.py>:2870: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/2050596098/lib/python3.10/site-packages/pkg_resources/__init__.py:2870: 13 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/pkg_resources/__init__.py>:2870: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.cloud')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/2050596098/lib/python3.10/site-packages/pkg_resources/__init__.py:2349
../../build/gradleenv/2050596098/lib/python3.10/site-packages/pkg_resources/__init__.py:2349
../../build/gradleenv/2050596098/lib/python3.10/site-packages/pkg_resources/__init__.py:2349
../../build/gradleenv/2050596098/lib/python3.10/site-packages/pkg_resources/__init__.py:2349
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/pkg_resources/__init__.py>:2349: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(parent)

../../build/gradleenv/2050596098/lib/python3.10/site-packages/pkg_resources/__init__.py:2870
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/pkg_resources/__init__.py>:2870: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.logging')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/2050596098/lib/python3.10/site-packages/pkg_resources/__init__.py:2870
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/pkg_resources/__init__.py>:2870: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.iam')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/2050596098/lib/python3.10/site-packages/google/rpc/__init__.py:20
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/google/rpc/__init__.py>:20: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.rpc')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    pkg_resources.declare_namespace(__name__)

../../build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/operations_v1/abstract_operations_client.py:17
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/operations_v1/abstract_operations_client.py>:17: DeprecationWarning: The distutils package is deprecated and slated for removal in Python 3.12. Use setuptools or check PEP 632 for potential alternatives
    from distutils import util

../../build/gradleenv/2050596098/lib/python3.10/site-packages/tenacity/_asyncio.py:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

apache_beam/typehints/pandas_type_compatibility_test.py:67
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:67: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    }).set_index(pd.Int64Index(range(123, 223), name='an_index')),

apache_beam/typehints/pandas_type_compatibility_test.py:90
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:90: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    pd.Int64Index(range(123, 223), name='an_index'),

apache_beam/typehints/pandas_type_compatibility_test.py:91
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:91: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    pd.Int64Index(range(475, 575), name='another_index'),

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py310-noxdist.xml> -
==== 1 passed, 9 skipped, 6860 deselected, 45 warnings in 702.64s (0:11:42) ====

FAILURE: Build failed with an exception.

* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 259

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> 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.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 49m
20 actionable tasks: 14 executed, 4 from cache, 2 up-to-date

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

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_Py_VR_Dataflow_V2 #4691

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/4691/display/redirect>


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