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 2022/01/03 19:28:11 UTC

Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #1846

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

Changes:

[mmack] [BEAM-13509] Stop sharing SQS client between readers of same source.

[mmack] [BEAM-13587] Attempt to load AWS region from default provider chain in


------------------------------------------
[...truncated 613.49 KB...]
        if self._options.view_as(TypeOptions).runtime_type_check:
          from apache_beam.typehints import typecheck
          self.visit(typecheck.TypeCheckVisitor())
    
        if self._options.view_as(TypeOptions).performance_runtime_type_check:
          from apache_beam.typehints import typecheck
          self.visit(typecheck.PerformanceTypeCheckVisitor())
    
        if self._options.view_as(SetupOptions).save_main_session:
          # If this option is chosen, verify we can pickle the main session early.
          tmpdir = tempfile.mkdtemp()
          try:
            pickler.dump_session(os.path.join(tmpdir, 'main_session.pickle'))
          finally:
            shutil.rmtree(tmpdir)
>       return self.runner.run_pipeline(self, self._options)

apache_beam/pipeline.py:573: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.portability.portable_runner.PortableRunner object at 0x7ff37c7c6850>
pipeline = <apache_beam.pipeline.Pipeline object at 0x7ff37b81f210>
options = <apache_beam.options.pipeline_options.PipelineOptions object at 0x7ff37c3b1090>

    def run_pipeline(self, pipeline, options):
      # type: (Pipeline, PipelineOptions) -> PipelineResult
      portable_options = options.view_as(PortableOptions)
    
      # TODO: https://issues.apache.org/jira/browse/BEAM-5525
      # portable runner specific default
      if options.view_as(SetupOptions).sdk_location == 'default':
        options.view_as(SetupOptions).sdk_location = 'container'
    
      experiments = options.view_as(DebugOptions).experiments or []
    
      # This is needed as we start a worker server if one is requested
      # but none is provided.
      if portable_options.environment_type == 'LOOPBACK':
        use_loopback_process_worker = options.view_as(
            DebugOptions).lookup_experiment('use_loopback_process_worker', False)
        portable_options.environment_config, server = (
            worker_pool_main.BeamFnExternalWorkerPoolServicer.start(
                state_cache_size=
                sdk_worker_main._get_state_cache_size(experiments),
                data_buffer_time_limit_ms=
                sdk_worker_main._get_data_buffer_time_limit_ms(experiments),
                use_process=use_loopback_process_worker))
        cleanup_callbacks = [functools.partial(server.stop, 1)]
      else:
        cleanup_callbacks = []
    
      proto_pipeline = self.get_proto_pipeline(pipeline, options)
>     job_service_handle = self.create_job_service(options)

apache_beam/runners/portability/portable_runner.py:438: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.portability.portable_runner.PortableRunner object at 0x7ff37c7c6850>
options = <apache_beam.options.pipeline_options.PipelineOptions object at 0x7ff37c3b1090>

    def create_job_service(self, options):
      # type: (PipelineOptions) -> JobServiceHandle
    
      """
      Start the job service and return a `JobServiceHandle`
      """
      job_endpoint = options.view_as(PortableOptions).job_endpoint
      if job_endpoint:
        if job_endpoint == 'embed':
          server = job_server.EmbeddedJobServer()  # type: job_server.JobServer
        else:
          job_server_timeout = options.view_as(PortableOptions).job_server_timeout
          server = job_server.ExternalJobServer(job_endpoint, job_server_timeout)
      else:
        server = self.default_job_server(options)
>     return self.create_job_service_handle(server.start(), options)

apache_beam/runners/portability/portable_runner.py:317: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.portability.job_server.ExternalJobServer object at 0x7ff37c505910>

    def start(self):
      # type: () -> beam_job_api_pb2_grpc.JobServiceStub
      channel = grpc.insecure_channel(self._endpoint)
>     grpc.channel_ready_future(channel).result(timeout=self._timeout)

apache_beam/runners/portability/job_server.py:54: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <grpc._utilities._ChannelReadyFuture object at 0x7ff37c3a9450>
timeout = 60

    def result(self, timeout=None):
>       self._block(timeout)

target/.tox-flink-runner-test/flink-runner-test/lib/python3.7/site-packages/grpc/_utilities.py:139: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <grpc._utilities._ChannelReadyFuture object at 0x7ff37c3a9450>
timeout = 60

    def _block(self, timeout):
        until = None if timeout is None else time.time() + timeout
        with self._condition:
            while True:
                if self._cancelled:
                    raise grpc.FutureCancelledError()
                elif self._matured:
                    return
                else:
                    if until is None:
                        self._condition.wait()
                    else:
                        remaining = until - time.time()
                        if remaining < 0:
>                           raise grpc.FutureTimeoutError()
E                           grpc.FutureTimeoutError

target/.tox-flink-runner-test/flink-runner-test/lib/python3.7/site-packages/grpc/_utilities.py:85: FutureTimeoutError

The above exception was the direct cause of the following exception:
target/.tox-flink-runner-test/flink-runner-test/lib/python3.7/site-packages/tenacity/__init__.py:293: in wrapped_f
    return self.call(f, *args, **kw)
target/.tox-flink-runner-test/flink-runner-test/lib/python3.7/site-packages/tenacity/__init__.py:359: in call
    do = self.iter(retry_state=retry_state)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <Retrying object at 0x7ff380644b10 (stop=<tenacity.stop.stop_after_attempt object at 0x7ff380644810>, wait=<tenacity.w...0x7ff34ebe6190>, before=<function before_nothing at 0x7ff34ebe2560>, after=<function after_nothing at 0x7ff34ebd7b90>)>
retry_state = <tenacity.RetryCallState object at 0x7ff37b929890>

    def iter(self, retry_state):  # noqa
        fut = retry_state.outcome
        if fut is None:
            if self.before is not None:
                self.before(retry_state)
            return DoAttempt()
    
        is_explicit_retry = retry_state.outcome.failed \
            and isinstance(retry_state.outcome.exception(), TryAgain)
        if not (is_explicit_retry or self.retry(retry_state=retry_state)):
            return fut.result()
    
        if self.after is not None:
            self.after(retry_state=retry_state)
    
        self.statistics['delay_since_first_attempt'] = \
            retry_state.seconds_since_start
        if self.stop(retry_state=retry_state):
            if self.retry_error_callback:
                return self.retry_error_callback(retry_state=retry_state)
            retry_exc = self.retry_error_cls(fut)
            if self.reraise:
                raise retry_exc.reraise()
>           six.raise_from(retry_exc, fut.exception())
E           tenacity.RetryError: RetryError[<Future at 0x7ff37c663b10 state=finished raised FutureTimeoutError>]

target/.tox-flink-runner-test/flink-runner-test/lib/python3.7/site-packages/tenacity/__init__.py:333: RetryError
----------------------------- Captured stderr call -----------------------------
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.7 interpreter.
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.7 interpreter.
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.7 interpreter.
------------------------------ Captured log call -------------------------------
WARNING  root:environments.py:374 Make sure that locally built Python SDK docker image has Python 3.7 interpreter.
WARNING  root:environments.py:374 Make sure that locally built Python SDK docker image has Python 3.7 interpreter.
WARNING  root:environments.py:374 Make sure that locally built Python SDK docker image has Python 3.7 interpreter.
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/test-suites/portable/py37/build/srcs/sdks/python/pytest_flink-runner-test.xml> -
============= 11 failed, 120 passed, 40 skipped in 2899.43 seconds =============
ERROR: InvocationError for command <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/test-suites/portable/py37/build/srcs/sdks/python/scripts/pytest_validates_runner.sh> flink-runner-test apache_beam/runners/portability/flink_runner_test.py '--flink_job_server_jar=<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/runners/flink/1.13/job-server/build/libs/beam-runners-flink-1.13-job-server-2.36.0-SNAPSHOT.jar> --environment_type=LOOPBACK' (exited with code 1)
flink-runner-test run-test-post: commands[0] | bash <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/test-suites/portable/py37/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
ERROR:   flink-runner-test: commands failed

> Task :sdks:python:test-suites:portable:py37:flinkCompatibilityMatrixLOOPBACK FAILED

> Task :sdks:python:test-suites:portable:py38:flinkCompatibilityMatrixLOOPBACK
flink-runner-test create: <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-flink-runner-test/flink-runner-test>
flink-runner-test installdeps: -rbuild-requirements.txt
flink-runner-test inst: <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-flink-runner-test/.tmp/package/1/apache-beam.tar.gz>
flink-runner-test installed: apache-beam @ file://<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-flink-runner-test/.tmp/package/1/apache-beam.tar.gz,atomicwrites==1.4.0,attrs==21.4.0,certifi==2021.10.8,charset-normalizer==2.0.9,cloudpickle==2.0.0,crcmod==1.7,deprecation==2.1.0,dill==0.3.1.1,distlib==0.3.1,docker==5.0.3,docopt==0.6.2,execnet==1.9.0,fastavro==1.4.8,freezegun==1.1.0,greenlet==1.1.2,grpcio==1.43.0,grpcio-tools==1.37.0,hdfs==2.6.0,httplib2==0.19.1,idna==3.3,mock==2.0.0,more-itertools==8.12.0,mypy-protobuf==1.18,numpy==1.21.5,oauth2client==4.1.3,orjson==3.6.5,packaging==21.3,pandas==1.3.5,parameterized==0.7.5,pbr==5.8.0,pluggy==0.13.1,proto-plus==1.19.8,protobuf==3.19.1,psycopg2-binary==2.9.3,py==1.11.0,pyarrow==6.0.1,pyasn1==0.4.8,pyasn1-modules==0.2.8,pydot==1.4.2,PyHamcrest==1.10.1,pymongo==3.12.3,pyparsing==2.4.7,pytest==4.6.11,pytest-forked==1.4.0,pytest-timeout==1.4.2,pytest-xdist==1.34.0,python-dateutil==2.8.2,pytz==2021.3,PyYAML==6.0,requests==2.27.0,requests-mock==1.9.3,rsa==4.8,six==1.16.0,SQLAlchemy==1.4.29,tenacity==5.1.5,testcontainers==3.4.2,typing-extensions==3.10.0.2,urllib3==1.26.7,wcwidth==0.2.5,websocket-client==1.2.3,wrapt==1.13.3>
flink-runner-test run-test-pre: PYTHONHASHSEED='4081274772'
flink-runner-test run-test-pre: commands[0] | python --version
Python 3.8.9
flink-runner-test run-test-pre: commands[1] | pip --version
pip 21.3.1 from <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-flink-runner-test/flink-runner-test/lib/python3.8/site-packages/pip> (python 3.8)
flink-runner-test run-test-pre: commands[2] | pip check
No broken requirements found.
flink-runner-test run-test-pre: commands[3] | bash <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
flink-runner-test run-test: commands[0] | <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/scripts/pytest_validates_runner.sh> flink-runner-test <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/portability/flink_runner_test.py> '--flink_job_server_jar=<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/runners/flink/1.13/job-server/build/libs/beam-runners-flink-1.13-job-server-2.36.0-SNAPSHOT.jar> --environment_type=LOOPBACK'
============================= test session starts ==============================
platform linux -- Python 3.8.9, pytest-4.6.11, py-1.11.0, pluggy-0.13.1
cachedir: target/.tox-flink-runner-test/flink-runner-test/.pytest_cache
rootdir: <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python,> inifile: pytest.ini
plugins: xdist-1.34.0, timeout-1.4.2, forked-1.4.0, requests-mock-1.9.3
timeout: 600.0s
timeout method: signal
timeout func_only: False
collected 171 items

apache_beam/runners/portability/flink_runner_test.py .s...ss...........s [ 11%]
....s.....s...........s..ss.....ss.s...s...ss..sss......s....s.....s.... [ 53%]
.......s..ss.....ssss...s...ss...........s....s.....s...........s..ss... [ 95%]
..ss.s..                                                                 [100%]

=============================== warnings summary ===============================
target/.tox-flink-runner-test/flink-runner-test/lib/python3.8/site-packages/tenacity/_asyncio.py:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-flink-runner-test/flink-runner-test/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_Python_VR_Flink/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/pytest_flink-runner-test.xml> -
============= 131 passed, 40 skipped, 1 warnings in 957.68 seconds =============
flink-runner-test run-test-post: commands[0] | bash <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
  flink-runner-test: commands succeeded
  congratulations :)

> Task :sdks:python:test-suites:portable:py38:flinkValidatesRunner

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:flinkCompatibilityMatrixLOOPBACK'.
> 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 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.3.2/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 27m 35s
121 actionable tasks: 74 executed, 43 from cache, 4 up-to-date

Publishing build scan...
https://gradle.com/s/7ng3bf3dhtezs

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_VR_Flink #1847

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


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