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 2021/08/31 19:30:14 UTC

Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8332

See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8332/display/redirect?page=changes>

Changes:

[Luke Cwik] [BEAM-12802] Refactor DataStreamsDecoder so that it becomes aware of the

[ajamato] [BEAM-11994] Instantiate a new ServiceCallMetric before each request to

[Ankur Goenka] Remove duplicate 2.33.0 section

[noreply] add python spark example in documentation (#15426)


------------------------------------------
[...truncated 206.21 KB...]

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(
          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(
          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(
          self.sub_client.subscription_path(self.project, self.input_sub_name),
          self.input_topic.name)
      self.output_sub_name = OUTPUT_SUB + self.uuid
      self.output_sub = self.sub_client.create_subscription(
          self.sub_client.subscription_path(self.project, self.output_sub_name),
          self.output_topic.name,
>         ack_deadline_seconds=60)

apache_beam/runners/dataflow/dataflow_exercise_streaming_metrics_pipeline_test.py:79: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
../../build/gradleenv/-1734967053/lib/python3.6/site-packages/google/cloud/pubsub_v1/_gapic.py:40: in <lambda>
    fx = lambda self, *a, **kw: wrapped_fx(self.api, *a, **kw)  # noqa
../../build/gradleenv/-1734967053/lib/python3.6/site-packages/google/cloud/pubsub_v1/gapic/subscriber_client.py:439: in create_subscription
    request, retry=retry, timeout=timeout, metadata=metadata
../../build/gradleenv/-1734967053/lib/python3.6/site-packages/google/api_core/gapic_v1/method.py:145: in __call__
    return wrapped_func(*args, **kwargs)
../../build/gradleenv/-1734967053/lib/python3.6/site-packages/google/api_core/retry.py:291: in retry_wrapped_func
    on_error=on_error,
../../build/gradleenv/-1734967053/lib/python3.6/site-packages/google/api_core/retry.py:189: in retry_target
    return target()
../../build/gradleenv/-1734967053/lib/python3.6/site-packages/google/api_core/timeout.py:214: in func_with_timeout
    return func(*args, **kwargs)
../../build/gradleenv/-1734967053/lib/python3.6/site-packages/google/api_core/grpc_helpers.py:69: in error_remapped_callable
    six.raise_from(exceptions.from_grpc_error(exc), exc)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

value = None
from_value = <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.DEADLINE_EXCEEDED
	details = "Deadline Exceeded"
...4.95:443","file":"src/core/lib/surface/call.cc","file_line":1069,"grpc_message":"Deadline Exceeded","grpc_status":4}"
>

>   ???
E   google.api_core.exceptions.DeadlineExceeded: 504 Deadline Exceeded

<string>:3: DeadlineExceeded
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py36-noxdist.xml> -
================== 1 failed, 4991 deselected in 84.99 seconds ==================

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

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

=================================== FAILURES ===================================
_ ExerciseStreamingMetricsPipelineTest.test_streaming_pipeline_returns_expected_user_metrics_fnapi_it _

args = (name: "projects/apache-beam-testing/subscriptions/exercise_streaming_metrics_subscription_input1f007ebe-eb19-4904-bd4...ic: "projects/apache-beam-testing/topics/exercise_streaming_metrics_topic_input1f007ebe-eb19-4904-bd46-ba3c12b5bda9"
,)
kwargs = {'metadata': [('x-goog-request-params', 'name=projects/apache-beam-testing/subscriptions/exercise_streaming_metrics_su...904-bd46-ba3c12b5bda9'), ('x-goog-api-client', 'gl-python/3.8.5 grpc/1.39.0 gax/1.31.2 gapic/1.7.0')], 'timeout': 60.0}

    @six.wraps(callable_)
    def error_remapped_callable(*args, **kwargs):
        try:
>           return callable_(*args, **kwargs)

../../build/gradleenv/-1734967051/lib/python3.8/site-packages/google/api_core/grpc_helpers.py:67: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <grpc._channel._UnaryUnaryMultiCallable object at 0x7fefaa74cd30>
request = name: "projects/apache-beam-testing/subscriptions/exercise_streaming_metrics_subscription_input1f007ebe-eb19-4904-bd46...opic: "projects/apache-beam-testing/topics/exercise_streaming_metrics_topic_input1f007ebe-eb19-4904-bd46-ba3c12b5bda9"

timeout = 60.0
metadata = [('x-goog-request-params', 'name=projects/apache-beam-testing/subscriptions/exercise_streaming_metrics_subscription_input1f007ebe-eb19-4904-bd46-ba3c12b5bda9'), ('x-goog-api-client', 'gl-python/3.8.5 grpc/1.39.0 gax/1.31.2 gapic/1.7.0')]
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/-1734967051/lib/python3.8/site-packages/grpc/_channel.py:946: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

state = <grpc._channel._RPCState object at 0x7fefaa777e50>
call = <grpc._cython.cygrpc.SegregatedCall object at 0x7fefaa778700>
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 = "{"created":"@1630438212.000400714","description":"Error received from peer ipv4:108.177.121.95:443","file":"src/core/lib/surface/call.cc","file_line":1069,"grpc_message":"Deadline Exceeded","grpc_status":4}"
E           >

../../build/gradleenv/-1734967051/lib/python3.8/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(
          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(
          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(
          self.sub_client.subscription_path(self.project, self.input_sub_name),
          self.input_topic.name)

apache_beam/runners/dataflow/dataflow_exercise_streaming_metrics_pipeline_test.py:72: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
../../build/gradleenv/-1734967051/lib/python3.8/site-packages/google/cloud/pubsub_v1/_gapic.py:40: in <lambda>
    fx = lambda self, *a, **kw: wrapped_fx(self.api, *a, **kw)  # noqa
../../build/gradleenv/-1734967051/lib/python3.8/site-packages/google/cloud/pubsub_v1/gapic/subscriber_client.py:438: in create_subscription
    return self._inner_api_calls["create_subscription"](
../../build/gradleenv/-1734967051/lib/python3.8/site-packages/google/api_core/gapic_v1/method.py:145: in __call__
    return wrapped_func(*args, **kwargs)
../../build/gradleenv/-1734967051/lib/python3.8/site-packages/google/api_core/retry.py:286: in retry_wrapped_func
    return retry_target(
../../build/gradleenv/-1734967051/lib/python3.8/site-packages/google/api_core/retry.py:189: in retry_target
    return target()
../../build/gradleenv/-1734967051/lib/python3.8/site-packages/google/api_core/timeout.py:214: in func_with_timeout
    return func(*args, **kwargs)
../../build/gradleenv/-1734967051/lib/python3.8/site-packages/google/api_core/grpc_helpers.py:69: in error_remapped_callable
    six.raise_from(exceptions.from_grpc_error(exc), exc)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

value = None
from_value = <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.DEADLINE_EXCEEDED
	details = "Deadline Exceeded"
...1.95:443","file":"src/core/lib/surface/call.cc","file_line":1069,"grpc_message":"Deadline Exceeded","grpc_status":4}"
>

>   ???
E   google.api_core.exceptions.DeadlineExceeded: 504 Deadline Exceeded

<string>:3: DeadlineExceeded
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/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):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-noxdist.xml> -
============ 1 failed, 4991 deselected, 1 warnings in 69.97 seconds ============

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

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 204

* 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. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 204

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36: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. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 204

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38: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. 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 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.8.3/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 27m 35s
92 actionable tasks: 71 executed, 21 from cache

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

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 #8333

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8333/display/redirect?page=changes>


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