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/04 15:20:33 UTC

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2311 - Aborted!

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2311 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2311/ to view the results.

Jenkins build is back to normal : beam_PostCommit_Py_VR_Dataflow_V2 #2361

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


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

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

Changes:

[Luke Cwik] [BEAM-12619] Swap LinkedBlockingQueue to ArrayBlockingQueue for minor

[Luke Cwik] fixup! Fix spotbugs warning

[Andrew Pilloud] [BEAM-12759] ORDER BY then SELECT


------------------------------------------
[...truncated 102.87 KB...]
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.344Z: JOB_MESSAGE_DETAILED: Fusing consumer dump_to_pub/Write/NativeWrite into dump_to_pub/ToProtobuf
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.413Z: JOB_MESSAGE_DEBUG: Workflow config is missing a default resource spec.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.452Z: JOB_MESSAGE_DEBUG: Adding StepResource setup and teardown to workflow graph.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.486Z: JOB_MESSAGE_DEBUG: Adding workflow start and stop steps.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.508Z: JOB_MESSAGE_DEBUG: Assigning stage ids.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.563Z: JOB_MESSAGE_DEBUG: Starting worker pool setup.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.592Z: JOB_MESSAGE_BASIC: Starting 1 workers in us-central1-a...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.628Z: JOB_MESSAGE_DEBUG: Starting worker pool setup.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:44:05.034Z: 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:236 2021-08-16T19:44:21.835Z: 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:247 Timing out on waiting for job 2021-08-16_12_43_31-18407839813004771892 after 60 seconds
FAILED

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

args = (subscription: "projects/apache-beam-testing/subscriptions/exercise_streaming_metrics_subscription_output80c1562f-d9b7-4d51-aadc-4db424bb3ec5"
return_immediately: true
max_messages: 50
,)
kwargs = {'metadata': [('x-goog-request-params', 'subscription=projects/apache-beam-testing/subscriptions/exercise_streaming_me...d51-aadc-4db424bb3ec5'), ('x-goog-api-client', 'gl-python/3.8.5 grpc/1.39.0 gax/1.31.1 gapic/1.7.0')], 'timeout': 30.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 0x7f73286984c0>
request = subscription: "projects/apache-beam-testing/subscriptions/exercise_streaming_metrics_subscription_output80c1562f-d9b7-4d51-aadc-4db424bb3ec5"
return_immediately: true
max_messages: 50

timeout = 30.0
metadata = [('x-goog-request-params', 'subscription=projects/apache-beam-testing/subscriptions/exercise_streaming_metrics_subscri...put80c1562f-d9b7-4d51-aadc-4db424bb3ec5'), ('x-goog-api-client', 'gl-python/3.8.5 grpc/1.39.0 gax/1.31.1 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 0x7f7328700730>
call = <grpc._cython.cygrpc.SegregatedCall object at 0x7f7328703380>
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":"@1629143310.584039575","description":"Error received from peer ipv4:64.233.191.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>

    @pytest.mark.it_validatesrunner
    @pytest.mark.no_sickbay_batch
    @pytest.mark.no_xdist
    def test_streaming_pipeline_returns_expected_user_metrics_fnapi_it(self):
      """
      Runs streaming Dataflow job and verifies that user metrics are reported
      correctly.
      """
      self._inject_words(self.input_topic, MESSAGES_TO_PUBLISH)
>     result = self.run_pipeline()

apache_beam/runners/dataflow/dataflow_exercise_streaming_metrics_pipeline_test.py:125: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/runners/dataflow/dataflow_exercise_streaming_metrics_pipeline_test.py:113: in run_pipeline
    return dataflow_exercise_streaming_metrics_pipeline.run(argv)
apache_beam/runners/dataflow/dataflow_exercise_streaming_metrics_pipeline.py:99: in run
    result = pipeline.run()
apache_beam/pipeline.py:565: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/dataflow/test_dataflow_runner.py:69: in run_pipeline
    hc_assert_that(self.result, pickler.loads(on_success_matcher))
../../build/gradleenv/-1734967051/lib/python3.8/site-packages/hamcrest/core/core/allof.py:19: in matches
    if not matcher.matches(item):
../../build/gradleenv/-1734967051/lib/python3.8/site-packages/hamcrest/core/base_matcher.py:28: in matches
    match_result = self._matches(item)
apache_beam/io/gcp/tests/pubsub_matcher.py:115: in _matches
    self.messages = self._wait_for_messages(
apache_beam/io/gcp/tests/pubsub_matcher.py:129: in _wait_for_messages
    response = sub_client.pull(
../../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:1110: in pull
    return self._inner_api_calls["pull"](
../../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:102: 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
------------------------------ Captured log call -------------------------------
INFO     apache_beam.runners.portability.stager:stager.py:644 Executing command: ['<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/build/gradleenv/-1734967051/bin/python3.8',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', 'postcommit_requirements.txt', '--exists-action', 'i', '--no-binary', ':all:']
INFO     apache_beam.runners.portability.stager:stager.py:300 Copying Beam SDK "<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/ws/src/sdks/python/build/apache-beam.tar.gz"> to staging location.
WARNING  root:environments.py:371 Make sure that locally built Python SDK docker image has Python 3.8 interpreter.
INFO     root:environments.py:380 Default Python SDK image for environment is apache/beam_python3.8_sdk:2.33.0.dev
INFO     root:environments.py:295 Using provided Python SDK container image: gcr.io/cloud-dataflow/v1beta3/python38-fnapi:beam-master-20210809
INFO     root:environments.py:302 Python SDK container image set to "gcr.io/cloud-dataflow/v1beta3/python38-fnapi:beam-master-20210809" for Docker environment
INFO     apache_beam.internal.gcp.auth:auth.py:106 Setting socket default timeout to 60 seconds.
INFO     apache_beam.internal.gcp.auth:auth.py:108 socket default timeout is 60.0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/requirements.txt...
INFO     oauth2client.transport:transport.py:157 Attempting refresh to obtain initial access_token
INFO     oauth2client.transport:transport.py:157 Attempting refresh to obtain initial access_token
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:647 Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/requirements.txt in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/pickled_main_session...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:647 Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/pickled_main_session in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/pbr-5.6.0.tar.gz...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:647 Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/pbr-5.6.0.tar.gz in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/mock-2.0.0.tar.gz...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:647 Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/mock-2.0.0.tar.gz in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/six-1.16.0.tar.gz...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:647 Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/six-1.16.0.tar.gz in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/soupsieve-2.2.1.tar.gz...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:647 Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/soupsieve-2.2.1.tar.gz in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/PyHamcrest-1.10.1.tar.gz...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:647 Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/PyHamcrest-1.10.1.tar.gz in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/parameterized-0.7.5.tar.gz...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:647 Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/parameterized-0.7.5.tar.gz in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/beautifulsoup4-4.9.3.tar.gz...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:647 Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/beautifulsoup4-4.9.3.tar.gz in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/dataflow_python_sdk.tar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:647 Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/dataflow_python_sdk.tar in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/dataflow-worker.jar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:647 Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/dataflow-worker.jar in 5 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/pipeline.pb...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:647 Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0816194324-567265.1629143004.567416/pipeline.pb in 0 seconds.
WARNING  apache_beam.options.pipeline_options:pipeline_options.py:309 Discarding unparseable args: ['--sleep_secs=20']
WARNING  apache_beam.options.pipeline_options:pipeline_options.py:309 Discarding unparseable args: ['--sleep_secs=20']
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:797 Create job: <Job
                                                                           createTime: '2021-08-16T19:43:32.271426Z'
                                                                           currentStateTime: '1970-01-01T00:00:00Z'
                                                                           id: '2021-08-16_12_43_31-18407839813004771892'
                                                                           location: 'us-central1'
                                                                           name: 'beamapp-jenkins-0816194324-567265'
                                                                           projectId: 'apache-beam-testing'
                                                                           stageStates: []
                                                                           startTime: '2021-08-16T19:43:32.271426Z'
                                                                           steps: []
                                                                           tempFiles: []
                                                                           type: TypeValueValuesEnum(JOB_TYPE_STREAMING, 2)>
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:799 Created job with id: [2021-08-16_12_43_31-18407839813004771892]
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:800 Submitted job: 2021-08-16_12_43_31-18407839813004771892
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:801 To access the Dataflow monitoring console, please navigate to https://console.cloud.google.com/dataflow/jobs/us-central1/2021-08-16_12_43_31-18407839813004771892?project=apache-beam-testing
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-08-16_12_43_31-18407839813004771892 is in state JOB_STATE_RUNNING
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:34.984Z: JOB_MESSAGE_WARNING: Autoscaling is enabled for Dataflow Streaming Engine. Workers will scale between 1 and 100 unless maxNumWorkers is specified.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:35.104Z: JOB_MESSAGE_DETAILED: Autoscaling is enabled for job 2021-08-16_12_43_31-18407839813004771892. The number of workers will be between 1 and 100.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:35.153Z: JOB_MESSAGE_DETAILED: Autoscaling was automatically enabled for job 2021-08-16_12_43_31-18407839813004771892.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:38.399Z: JOB_MESSAGE_BASIC: Worker configuration: e2-standard-2 in us-central1-a.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:38.962Z: JOB_MESSAGE_DETAILED: Expanding SplittableParDo operations into optimizable parts.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.001Z: JOB_MESSAGE_DETAILED: Expanding CollectionToSingleton operations into optimizable parts.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.059Z: JOB_MESSAGE_DETAILED: Expanding CoGroupByKey operations into optimizable parts.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.093Z: JOB_MESSAGE_DETAILED: Expanding SplittableProcessKeyed operations into optimizable parts.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.126Z: JOB_MESSAGE_DETAILED: Expanding GroupByKey operations into streaming Read/Write steps
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.155Z: JOB_MESSAGE_DETAILED: Lifting ValueCombiningMappingFns into MergeBucketsMappingFns
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.190Z: JOB_MESSAGE_DEBUG: Annotating graph with Autotuner information.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.235Z: JOB_MESSAGE_DETAILED: Fusing adjacent ParDo, Read, Write, and Flatten operations
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.283Z: JOB_MESSAGE_DETAILED: Fusing consumer generate_metrics into ReadFromPubSub/Read
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.317Z: JOB_MESSAGE_DETAILED: Fusing consumer dump_to_pub/ToProtobuf into generate_metrics
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.344Z: JOB_MESSAGE_DETAILED: Fusing consumer dump_to_pub/Write/NativeWrite into dump_to_pub/ToProtobuf
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.413Z: JOB_MESSAGE_DEBUG: Workflow config is missing a default resource spec.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.452Z: JOB_MESSAGE_DEBUG: Adding StepResource setup and teardown to workflow graph.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.486Z: JOB_MESSAGE_DEBUG: Adding workflow start and stop steps.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.508Z: JOB_MESSAGE_DEBUG: Assigning stage ids.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.563Z: JOB_MESSAGE_DEBUG: Starting worker pool setup.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.592Z: JOB_MESSAGE_BASIC: Starting 1 workers in us-central1-a...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:43:39.628Z: JOB_MESSAGE_DEBUG: Starting worker pool setup.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-16T19:44:05.034Z: 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:236 2021-08-16T19:44:21.835Z: 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:247 Timing out on waiting for job 2021-08-16_12_43_31-18407839813004771892 after 60 seconds
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/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_V2/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_V2/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-noxdist.xml> -
=========== 1 failed, 4976 deselected, 1 warnings in 492.68 seconds ============

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

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: 209

* 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 37m 41s
84 actionable tasks: 54 executed, 30 from cache

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

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


beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2359 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2359 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2359/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2358 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2358 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2358/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2357 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2357 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2357/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2356 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2356 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2356/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2355 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2355 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2355/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2354 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2354 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2354/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2353 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2353 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2353/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2352 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2352 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2352/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2351 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2351 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2351/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2350 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2350 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2350/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2349 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2349 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2349/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2348 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2348 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2348/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2347 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2347 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2347/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2346 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2346 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2346/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2345 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2345 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2345/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2344 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2344 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2344/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2343 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2343 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2343/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2342 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2342 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2342/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2341 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2341 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2341/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2340 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2340 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2340/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2339 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2339 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2339/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2338 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2338 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2338/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2337 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2337 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2337/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2336 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2336 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2336/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2335 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2335 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2335/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2334 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2334 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2334/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2333 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2333 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2333/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2332 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2332 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2332/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2331 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2331 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2331/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2330 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2330 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2330/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2329 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2329 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2329/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2328 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2328 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2328/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2327 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2327 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2327/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2326 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2326 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2326/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2325 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2325 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2325/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2324 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2324 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2324/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2323 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2323 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2323/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2322 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2322 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2322/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2321 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2321 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2321/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2320 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2320 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2320/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2319 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2319 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2319/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2318 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2318 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2318/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2317 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2317 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2317/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2316 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2316 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2316/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2315 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2315 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2315/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2314 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2314 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2314/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2313 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2313 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2313/ to view the results.

beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2312 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Py_VR_Dataflow_V2 - Build # 2312 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow_V2/2312/ to view the results.