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

Build failed in Jenkins: beam_PostCommit_Python35_VR_Flink #1689

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

Changes:

[github] [BEAM-9652] Ensure that the multipartition write sets the correct coder

[github] [BEAM-8889]add experiment flag use_grpc_for_gcs (#11183)


------------------------------------------
[...truncated 678.58 KB...]
    options = super(FlinkRunnerTestOptimized, self).create_options()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 165, in create_options
    options = super(FlinkRunnerTest, self).create_options()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 189, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 154, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 160, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 126, in _start_local_runner_subprocess_job_service
    GRPCChannelFactory.insecure_channel(address))
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/channel_factory.py",> line 39, in insecure_channel
    target, options=options + GRPCChannelFactory.DEFAULT_OPTIONS)
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/__init__.py",> line 1860, in insecure_channel
    from grpc import _channel  # pylint: disable=cyclic-import
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 25, in <module>
    import grpc.experimental
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/experimental/__init__.py",> line 89, in <module>
    from grpc._simple_stubs import unary_unary, unary_stream, stream_unary, stream_stream
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_simple_stubs.py",> line 61
    _LOGGER.debug(f"Creating insecure channel with options '{options}' " +
                                                                       ^
SyntaxError: invalid syntax

======================================================================
ERROR: test_sdf_synthetic_source (__main__.FlinkRunnerTestOptimized)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 783, in test_sdf_synthetic_source
    with self.create_pipeline() as p:
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 201, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 372, in create_options
    options = super(FlinkRunnerTestOptimized, self).create_options()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 165, in create_options
    options = super(FlinkRunnerTest, self).create_options()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 189, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 154, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 160, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 126, in _start_local_runner_subprocess_job_service
    GRPCChannelFactory.insecure_channel(address))
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/channel_factory.py",> line 39, in insecure_channel
    target, options=options + GRPCChannelFactory.DEFAULT_OPTIONS)
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/__init__.py",> line 1860, in insecure_channel
    from grpc import _channel  # pylint: disable=cyclic-import
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 25, in <module>
    import grpc.experimental
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/experimental/__init__.py",> line 89, in <module>
    from grpc._simple_stubs import unary_unary, unary_stream, stream_unary, stream_stream
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_simple_stubs.py",> line 61
    _LOGGER.debug(f"Creating insecure channel with options '{options}' " +
                                                                       ^
SyntaxError: invalid syntax

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.FlinkRunnerTestOptimized)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 395, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 442, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 201, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 372, in create_options
    options = super(FlinkRunnerTestOptimized, self).create_options()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 165, in create_options
    options = super(FlinkRunnerTest, self).create_options()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 189, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 154, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 160, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 126, in _start_local_runner_subprocess_job_service
    GRPCChannelFactory.insecure_channel(address))
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/channel_factory.py",> line 39, in insecure_channel
    target, options=options + GRPCChannelFactory.DEFAULT_OPTIONS)
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/__init__.py",> line 1860, in insecure_channel
    from grpc import _channel  # pylint: disable=cyclic-import
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 25, in <module>
    import grpc.experimental
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/experimental/__init__.py",> line 89, in <module>
    from grpc._simple_stubs import unary_unary, unary_stream, stream_unary, stream_stream
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_simple_stubs.py",> line 61
    _LOGGER.debug(f"Creating insecure channel with options '{options}' " +
                                                                       ^
SyntaxError: invalid syntax

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTestOptimized)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 606, in test_windowing
    with self.create_pipeline() as p:
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 201, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 372, in create_options
    options = super(FlinkRunnerTestOptimized, self).create_options()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 165, in create_options
    options = super(FlinkRunnerTest, self).create_options()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 189, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 154, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 160, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 126, in _start_local_runner_subprocess_job_service
    GRPCChannelFactory.insecure_channel(address))
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/channel_factory.py",> line 39, in insecure_channel
    target, options=options + GRPCChannelFactory.DEFAULT_OPTIONS)
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/__init__.py",> line 1860, in insecure_channel
    from grpc import _channel  # pylint: disable=cyclic-import
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 25, in <module>
    import grpc.experimental
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/experimental/__init__.py",> line 89, in <module>
    from grpc._simple_stubs import unary_unary, unary_stream, stream_unary, stream_stream
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_simple_stubs.py",> line 61
    _LOGGER.debug(f"Creating insecure channel with options '{options}' " +
                                                                       ^
SyntaxError: invalid syntax

======================================================================
FAIL: test_assert_that (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_simple_stubs.py",> line 61
    _LOGGER.debug(f"Creating insecure channel with options '{options}' " +
                                                                       ^
SyntaxError: invalid syntax

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 110, in test_assert_that
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a']))
AssertionError: "Failed assert" does not match "invalid syntax (_simple_stubs.py, line 61)"

======================================================================
FAIL: test_error_message_includes_stage (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 654, in test_error_message_includes_stage
    self.assertIn('StageC', message)
AssertionError: 'StageC' not found in 'invalid syntax'

======================================================================
FAIL: test_error_traceback_includes_user_code (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 675, in test_error_traceback_includes_user_code
    self.assertIn('first', message)
AssertionError: 'first' not found in 'Traceback (most recent call last):\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 668, in test_error_traceback_includes_user_code\n    with self.create_pipeline() as p:\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 201, in create_pipeline\n    return beam.Pipeline(self.get_runner(), self.create_options())\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 165, in create_options\n    options = super(FlinkRunnerTest, self).create_options()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 189, in create_options\n    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 154, in _get_job_endpoint\n    cls._job_endpoint = cls._create_job_endpoint()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 160, in _create_job_endpoint\n    return cls._start_local_runner_subprocess_job_service()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 126, in _start_local_runner_subprocess_job_service\n    GRPCChannelFactory.insecure_channel(address))\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/channel_factory.py",> line 39, in insecure_channel\n    target, options=options + GRPCChannelFactory.DEFAULT_OPTIONS)\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/__init__.py",> line 1860, in insecure_channel\n    from grpc import _channel  # pylint: disable=cyclic-import\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 25, in <module>\n    import grpc.experimental\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/experimental/__init__.py",> line 89, in <module>\n    from grpc._simple_stubs import unary_unary, unary_stream, stream_unary, stream_stream\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_simple_stubs.py",> line 61\n    _LOGGER.debug(f"Creating insecure channel with options \'{options}\' " +\n                                                                       ^\nSyntaxError: invalid syntax\n'

======================================================================
FAIL: test_assert_that (__main__.FlinkRunnerTestOptimized)
----------------------------------------------------------------------
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_simple_stubs.py",> line 61
    _LOGGER.debug(f"Creating insecure channel with options '{options}' " +
                                                                       ^
SyntaxError: invalid syntax

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 110, in test_assert_that
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a']))
AssertionError: "Failed assert" does not match "invalid syntax (_simple_stubs.py, line 61)"

======================================================================
FAIL: test_error_message_includes_stage (__main__.FlinkRunnerTestOptimized)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 654, in test_error_message_includes_stage
    self.assertIn('StageC', message)
AssertionError: 'StageC' not found in 'invalid syntax'

======================================================================
FAIL: test_error_traceback_includes_user_code (__main__.FlinkRunnerTestOptimized)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 675, in test_error_traceback_includes_user_code
    self.assertIn('first', message)
AssertionError: 'first' not found in 'Traceback (most recent call last):\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 668, in test_error_traceback_includes_user_code\n    with self.create_pipeline() as p:\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 201, in create_pipeline\n    return beam.Pipeline(self.get_runner(), self.create_options())\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 372, in create_options\n    options = super(FlinkRunnerTestOptimized, self).create_options()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 165, in create_options\n    options = super(FlinkRunnerTest, self).create_options()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 189, in create_options\n    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 154, in _get_job_endpoint\n    cls._job_endpoint = cls._create_job_endpoint()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 160, in _create_job_endpoint\n    return cls._start_local_runner_subprocess_job_service()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 126, in _start_local_runner_subprocess_job_service\n    GRPCChannelFactory.insecure_channel(address))\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/channel_factory.py",> line 39, in insecure_channel\n    target, options=options + GRPCChannelFactory.DEFAULT_OPTIONS)\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/__init__.py",> line 1860, in insecure_channel\n    from grpc import _channel  # pylint: disable=cyclic-import\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 25, in <module>\n    import grpc.experimental\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/experimental/__init__.py",> line 89, in <module>\n    from grpc._simple_stubs import unary_unary, unary_stream, stream_unary, stream_stream\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_simple_stubs.py",> line 61\n    _LOGGER.debug(f"Creating insecure channel with options \'{options}\' " +\n                                                                       ^\nSyntaxError: invalid syntax\n'

----------------------------------------------------------------------
Ran 78 tests in 8.028s

FAILED (failures=6, errors=56, skipped=14)

> Task :sdks:python:test-suites:portable:py35:flinkCompatibilityMatrixStreamingPreOptimizeLOOPBACK FAILED

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 55

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py35:flinkCompatibilityMatrixBatchLOOPBACK'.
> 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://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 55

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py35:flinkCompatibilityMatrixStreamingLOOPBACK'.
> 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://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 55

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py35:flinkCompatibilityMatrixStreamingPreOptimizeLOOPBACK'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

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

Deprecated Gradle features were used in this build, making it incompatible with Gradle 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.2.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 3m 27s
75 actionable tasks: 61 executed, 13 from cache, 1 up-to-date

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

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_Python35_VR_Flink #1691

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


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


Build failed in Jenkins: beam_PostCommit_Python35_VR_Flink #1690

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

Changes:


------------------------------------------
[...truncated 677.51 KB...]
    options = super(FlinkRunnerTestOptimized, self).create_options()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 165, in create_options
    options = super(FlinkRunnerTest, self).create_options()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 189, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 154, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 160, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 126, in _start_local_runner_subprocess_job_service
    GRPCChannelFactory.insecure_channel(address))
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/channel_factory.py",> line 39, in insecure_channel
    target, options=options + GRPCChannelFactory.DEFAULT_OPTIONS)
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/__init__.py",> line 1860, in insecure_channel
    from grpc import _channel  # pylint: disable=cyclic-import
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 25, in <module>
    import grpc.experimental
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/experimental/__init__.py",> line 89, in <module>
    from grpc._simple_stubs import unary_unary, unary_stream, stream_unary, stream_stream
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_simple_stubs.py",> line 61
    _LOGGER.debug(f"Creating insecure channel with options '{options}' " +
                                                                       ^
SyntaxError: invalid syntax

======================================================================
ERROR: test_sdf_synthetic_source (__main__.FlinkRunnerTestOptimized)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 783, in test_sdf_synthetic_source
    with self.create_pipeline() as p:
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 201, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 372, in create_options
    options = super(FlinkRunnerTestOptimized, self).create_options()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 165, in create_options
    options = super(FlinkRunnerTest, self).create_options()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 189, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 154, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 160, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 126, in _start_local_runner_subprocess_job_service
    GRPCChannelFactory.insecure_channel(address))
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/channel_factory.py",> line 39, in insecure_channel
    target, options=options + GRPCChannelFactory.DEFAULT_OPTIONS)
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/__init__.py",> line 1860, in insecure_channel
    from grpc import _channel  # pylint: disable=cyclic-import
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 25, in <module>
    import grpc.experimental
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/experimental/__init__.py",> line 89, in <module>
    from grpc._simple_stubs import unary_unary, unary_stream, stream_unary, stream_stream
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_simple_stubs.py",> line 61
    _LOGGER.debug(f"Creating insecure channel with options '{options}' " +
                                                                       ^
SyntaxError: invalid syntax

======================================================================
ERROR: test_windowed_pardo_state_timers (__main__.FlinkRunnerTestOptimized)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 395, in test_windowed_pardo_state_timers
    self._run_pardo_state_timers(True)
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 442, in _run_pardo_state_timers
    with self.create_pipeline() as p:
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 201, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 372, in create_options
    options = super(FlinkRunnerTestOptimized, self).create_options()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 165, in create_options
    options = super(FlinkRunnerTest, self).create_options()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 189, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 154, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 160, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 126, in _start_local_runner_subprocess_job_service
    GRPCChannelFactory.insecure_channel(address))
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/channel_factory.py",> line 39, in insecure_channel
    target, options=options + GRPCChannelFactory.DEFAULT_OPTIONS)
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/__init__.py",> line 1860, in insecure_channel
    from grpc import _channel  # pylint: disable=cyclic-import
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 25, in <module>
    import grpc.experimental
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/experimental/__init__.py",> line 89, in <module>
    from grpc._simple_stubs import unary_unary, unary_stream, stream_unary, stream_stream
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_simple_stubs.py",> line 61
    _LOGGER.debug(f"Creating insecure channel with options '{options}' " +
                                                                       ^
SyntaxError: invalid syntax

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTestOptimized)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 606, in test_windowing
    with self.create_pipeline() as p:
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 201, in create_pipeline
    return beam.Pipeline(self.get_runner(), self.create_options())
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 372, in create_options
    options = super(FlinkRunnerTestOptimized, self).create_options()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 165, in create_options
    options = super(FlinkRunnerTest, self).create_options()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 189, in create_options
    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 154, in _get_job_endpoint
    cls._job_endpoint = cls._create_job_endpoint()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 160, in _create_job_endpoint
    return cls._start_local_runner_subprocess_job_service()
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 126, in _start_local_runner_subprocess_job_service
    GRPCChannelFactory.insecure_channel(address))
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/channel_factory.py",> line 39, in insecure_channel
    target, options=options + GRPCChannelFactory.DEFAULT_OPTIONS)
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/__init__.py",> line 1860, in insecure_channel
    from grpc import _channel  # pylint: disable=cyclic-import
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 25, in <module>
    import grpc.experimental
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/experimental/__init__.py",> line 89, in <module>
    from grpc._simple_stubs import unary_unary, unary_stream, stream_unary, stream_stream
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_simple_stubs.py",> line 61
    _LOGGER.debug(f"Creating insecure channel with options '{options}' " +
                                                                       ^
SyntaxError: invalid syntax

======================================================================
FAIL: test_assert_that (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_simple_stubs.py",> line 61
    _LOGGER.debug(f"Creating insecure channel with options '{options}' " +
                                                                       ^
SyntaxError: invalid syntax

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 110, in test_assert_that
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a']))
AssertionError: "Failed assert" does not match "invalid syntax (_simple_stubs.py, line 61)"

======================================================================
FAIL: test_error_message_includes_stage (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 654, in test_error_message_includes_stage
    self.assertIn('StageC', message)
AssertionError: 'StageC' not found in 'invalid syntax'

======================================================================
FAIL: test_error_traceback_includes_user_code (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 675, in test_error_traceback_includes_user_code
    self.assertIn('first', message)
AssertionError: 'first' not found in 'Traceback (most recent call last):\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 668, in test_error_traceback_includes_user_code\n    with self.create_pipeline() as p:\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 201, in create_pipeline\n    return beam.Pipeline(self.get_runner(), self.create_options())\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 165, in create_options\n    options = super(FlinkRunnerTest, self).create_options()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 189, in create_options\n    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 154, in _get_job_endpoint\n    cls._job_endpoint = cls._create_job_endpoint()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 160, in _create_job_endpoint\n    return cls._start_local_runner_subprocess_job_service()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 126, in _start_local_runner_subprocess_job_service\n    GRPCChannelFactory.insecure_channel(address))\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/channel_factory.py",> line 39, in insecure_channel\n    target, options=options + GRPCChannelFactory.DEFAULT_OPTIONS)\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/__init__.py",> line 1860, in insecure_channel\n    from grpc import _channel  # pylint: disable=cyclic-import\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 25, in <module>\n    import grpc.experimental\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/experimental/__init__.py",> line 89, in <module>\n    from grpc._simple_stubs import unary_unary, unary_stream, stream_unary, stream_stream\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_simple_stubs.py",> line 61\n    _LOGGER.debug(f"Creating insecure channel with options \'{options}\' " +\n                                                                       ^\nSyntaxError: invalid syntax\n'

======================================================================
FAIL: test_assert_that (__main__.FlinkRunnerTestOptimized)
----------------------------------------------------------------------
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_simple_stubs.py",> line 61
    _LOGGER.debug(f"Creating insecure channel with options '{options}' " +
                                                                       ^
SyntaxError: invalid syntax

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 110, in test_assert_that
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a']))
AssertionError: "Failed assert" does not match "invalid syntax (_simple_stubs.py, line 61)"

======================================================================
FAIL: test_error_message_includes_stage (__main__.FlinkRunnerTestOptimized)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 654, in test_error_message_includes_stage
    self.assertIn('StageC', message)
AssertionError: 'StageC' not found in 'invalid syntax'

======================================================================
FAIL: test_error_traceback_includes_user_code (__main__.FlinkRunnerTestOptimized)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 675, in test_error_traceback_includes_user_code
    self.assertIn('first', message)
AssertionError: 'first' not found in 'Traceback (most recent call last):\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 668, in test_error_traceback_includes_user_code\n    with self.create_pipeline() as p:\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 201, in create_pipeline\n    return beam.Pipeline(self.get_runner(), self.create_options())\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 372, in create_options\n    options = super(FlinkRunnerTestOptimized, self).create_options()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 165, in create_options\n    options = super(FlinkRunnerTest, self).create_options()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 189, in create_options\n    options.view_as(PortableOptions).job_endpoint = self._get_job_endpoint()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 154, in _get_job_endpoint\n    cls._job_endpoint = cls._create_job_endpoint()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 160, in _create_job_endpoint\n    return cls._start_local_runner_subprocess_job_service()\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 126, in _start_local_runner_subprocess_job_service\n    GRPCChannelFactory.insecure_channel(address))\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/channel_factory.py",> line 39, in insecure_channel\n    target, options=options + GRPCChannelFactory.DEFAULT_OPTIONS)\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/__init__.py",> line 1860, in insecure_channel\n    from grpc import _channel  # pylint: disable=cyclic-import\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py",> line 25, in <module>\n    import grpc.experimental\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/experimental/__init__.py",> line 89, in <module>\n    from grpc._simple_stubs import unary_unary, unary_stream, stream_unary, stream_stream\n  File "<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_simple_stubs.py",> line 61\n    _LOGGER.debug(f"Creating insecure channel with options \'{options}\' " +\n                                                                       ^\nSyntaxError: invalid syntax\n'

----------------------------------------------------------------------
Ran 78 tests in 7.167s

FAILED (failures=6, errors=56, skipped=14)

> Task :sdks:python:test-suites:portable:py35:flinkCompatibilityMatrixStreamingPreOptimizeLOOPBACK FAILED

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 55

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py35:flinkCompatibilityMatrixBatchLOOPBACK'.
> 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://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 55

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py35:flinkCompatibilityMatrixStreamingLOOPBACK'.
> 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://builds.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 55

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py35:flinkCompatibilityMatrixStreamingPreOptimizeLOOPBACK'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

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

Deprecated Gradle features were used in this build, making it incompatible with Gradle 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.2.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2m 55s
75 actionable tasks: 56 executed, 18 from cache, 1 up-to-date

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

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