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 2018/11/08 14:30:39 UTC

Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #678

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

Changes:

[robertwb] Cleanup lint errors.

------------------------------------------
[...truncated 479.51 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541687430.57_0dcbf8d1-3ab4-41bf-9058-8721517283a1 failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541687430.92_0c117890-b7da-42b4-818f-81a7809c46af failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541687431.43_29a894fb-b76d-4dc2-a632-657a88bff674 failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541687431.8_d99badfb-61ab-42c4-8fdb-66a1073136e1 failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541687432.12_da49c5a4-2aee-4f4a-a3c4-bc616addccb6 failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541687432.42_badad9a4-6b5b-4812-9d08-6d9abda282bb failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541687432.76_30493b12-facf-4ed2-bd09-a6621e80ef30 failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541687433.28_328ed66f-8ebb-4d62-a884-198398f0cdf1 failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541687433.74_44c92f62-7cbe-425b-848e-81285068f13e failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541687434.21_e0f6f599-a6d7-48d0-90cb-7c7ff2a4b2ca failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541687435.24_f306312c-b2d4-47ac-8ef7-3462c408eda5 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541687435.7_ef3be7f5-d979-4397-bdca-71c086f6228e failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541687436.18_5c799843-d939-43c9-b97b-63a7c6e55c6a failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541687436.54_d99a145f-945e-46f2-9f4a-25337f94ff92 failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541687436.9_7c32ba09-79a0-4223-8251-4425453b3fab failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541687437.36_0daddad4-0b14-4102-8c2f-e4b9601f6570 failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541687437.68_394a159e-cb8c-4e12-b5c9-773b0fbc2b91 failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 11.812s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 13.7 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 6m 9s
60 actionable tasks: 55 executed, 4 from cache, 1 up-to-date

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

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

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/698/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_Python_VR_Flink #697

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/697/display/redirect?page=changes>

Changes:

[ankurgoenka] [BEAM-5467] Adding back environment to python pipeline

------------------------------------------
[...truncated 4.44 MB...]
[flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint - http://localhost:41443 was granted leadership with leaderSessionID=c90327ad-2d59-47ce-ba50-ba7521dbdcfe
[flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService - Received confirmation of leadership for leader http://localhost:41443 , session=c90327ad-2d59-47ce-ba50-ba7521dbdcfe
[flink-runner-job-server] INFO org.apache.flink.runtime.rpc.akka.AkkaRpcService - Starting RPC endpoint for org.apache.flink.runtime.dispatcher.StandaloneDispatcher at akka://flink/user/dispatcher5d874160-3faf-4791-9cf4-63588858097f .
[flink-runner-job-server] INFO org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService - Proposing leadership to contender org.apache.flink.runtime.dispatcher.StandaloneDispatcher@53b6205 @ akka://flink/user/dispatcher5d874160-3faf-4791-9cf4-63588858097f
[flink-runner-job-server] INFO org.apache.flink.runtime.minicluster.MiniCluster - Flink Mini Cluster started successfully
[flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.dispatcher.StandaloneDispatcher - Dispatcher akka://flink/user/dispatcher5d874160-3faf-4791-9cf4-63588858097f was granted leadership with fencing token eca1715b-33a1-4f14-b5f3-ba03f94e7c31
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.dispatcher.StandaloneDispatcher - Recovering all persisted jobs.
[flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService - Received confirmation of leadership for leader akka://flink/user/dispatcher5d874160-3faf-4791-9cf4-63588858097f , session=eca1715b-33a1-4f14-b5f3-ba03f94e7c31
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.dispatcher.StandaloneDispatcher - Submitting job b504cfdbe355304ba1d80cc8bcfc99c7 (test_windowing_1541816169.86).
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.rpc.akka.AkkaRpcService - Starting RPC endpoint for org.apache.flink.runtime.jobmaster.JobMaster at akka://flink/user/jobmanager_41 .
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.jobmaster.JobMaster - Initializing job test_windowing_1541816169.86 (b504cfdbe355304ba1d80cc8bcfc99c7).
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.jobmaster.JobMaster - Using restart strategy NoRestartStrategy for test_windowing_1541816169.86 (b504cfdbe355304ba1d80cc8bcfc99c7).
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.rpc.akka.AkkaRpcService - Starting RPC endpoint for org.apache.flink.runtime.jobmaster.slotpool.SlotPool at akka://flink/user/dc299b5e-683e-49b0-b364-1d0cf68bff33 .
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Job recovers via failover strategy: full graph restart
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.jobmaster.JobMaster - Running initialization on master for job test_windowing_1541816169.86 (b504cfdbe355304ba1d80cc8bcfc99c7).
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.jobmaster.JobMaster - Successfully ran initialization on master in 0 ms.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.jobmaster.JobMaster - No state backend has been configured, using default (Memory / JobManager) MemoryStateBackend (data in heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints: 'null', asynchronous: TRUE, maxStateSize: 5242880)
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService - Proposing leadership to contender org.apache.flink.runtime.jobmaster.JobManagerRunner@45745e62 @ akka://flink/user/jobmanager_41
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.jobmaster.JobManagerRunner - JobManager runner for job test_windowing_1541816169.86 (b504cfdbe355304ba1d80cc8bcfc99c7) was granted leadership with session id 64460718-05ac-4e37-9705-bf03def60b2a at akka://flink/user/jobmanager_41.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.jobmaster.JobMaster - Starting execution of job test_windowing_1541816169.86 (b504cfdbe355304ba1d80cc8bcfc99c7)
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Job test_windowing_1541816169.86 (b504cfdbe355304ba1d80cc8bcfc99c7) switched from state CREATED to RUNNING.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (613dcb24fc9ec9e8c9f7d03a84357fe3) switched from CREATED to SCHEDULED.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1) (6c508e445709fc5583064087f0ec6e1b) switched from CREATED to SCHEDULED.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (3f74c2d6ee4651a49c819ffc5d84ea72) switched from CREATED to SCHEDULED.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (36517e9d607ccfc164c74c0819598730) switched from CREATED to SCHEDULED.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (1/1) (71df1487d05a43b9c86ac46df118ec5f) switched from CREATED to SCHEDULED.
[flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.jobmaster.slotpool.SlotPool - Cannot serve slot request, no ResourceManager connected. Adding as pending request [SlotRequestId{735dc2f0393e38ca20d2ba1ca9b4363a}]
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (25b7085d160a265b60d852d911698b2f) switched from CREATED to SCHEDULED.
[jobmanager-future-thread-1] INFO org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService - Received confirmation of leadership for leader akka://flink/user/jobmanager_41 , session=64460718-05ac-4e37-9705-bf03def60b2a
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.jobmaster.JobMaster - Connecting to ResourceManager akka://flink/user/resourcemanager_be4d7f39-8493-4fef-b3fa-33c6a3c8aa7e(825f07c10f4e2b4b3f27776811864325)
[flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.jobmaster.JobMaster - Resolved ResourceManager address, beginning registration
[flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.jobmaster.JobMaster - Registration at ResourceManager attempt 1 (timeout=100ms)
[flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.resourcemanager.StandaloneResourceManager - Registering job manager 9705bf03def60b2a6446071805ac4e37@akka://flink/user/jobmanager_41 for job b504cfdbe355304ba1d80cc8bcfc99c7.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.resourcemanager.StandaloneResourceManager - Registered job manager 9705bf03def60b2a6446071805ac4e37@akka://flink/user/jobmanager_41 for job b504cfdbe355304ba1d80cc8bcfc99c7.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.jobmaster.JobMaster - JobManager successfully registered at ResourceManager, leader id: 825f07c10f4e2b4b3f27776811864325.
[flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.jobmaster.slotpool.SlotPool - Requesting new slot [SlotRequestId{735dc2f0393e38ca20d2ba1ca9b4363a}] and profile ResourceProfile{cpuCores=-1.0, heapMemoryInMB=-1, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0} from resource manager.
[flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.resourcemanager.StandaloneResourceManager - Request slot with profile ResourceProfile{cpuCores=-1.0, heapMemoryInMB=-1, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0} for job b504cfdbe355304ba1d80cc8bcfc99c7 with allocation id AllocationID{a2b817be9e39a3582468786cdee703b0}.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Receive slot request AllocationID{a2b817be9e39a3582468786cdee703b0} for job b504cfdbe355304ba1d80cc8bcfc99c7 from resource manager with leader id 825f07c10f4e2b4b3f27776811864325.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Allocated slot for AllocationID{a2b817be9e39a3582468786cdee703b0}.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.JobLeaderService - Add job b504cfdbe355304ba1d80cc8bcfc99c7 for job leader monitoring.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.JobLeaderService - Try to register at job manager akka://flink/user/jobmanager_41 with leader id 64460718-05ac-4e37-9705-bf03def60b2a.
[flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.taskexecutor.JobLeaderService - Resolved JobManager address, beginning registration
[flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.taskexecutor.JobLeaderService - Registration at JobManager attempt 1 (timeout=100ms)
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.JobLeaderService - Successful registration at job manager akka://flink/user/jobmanager_41 for job b504cfdbe355304ba1d80cc8bcfc99c7.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Establish JobManager connection for job b504cfdbe355304ba1d80cc8bcfc99c7.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Offer reserved slots to the leader of job b504cfdbe355304ba1d80cc8bcfc99c7.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Activate slot AllocationID{a2b817be9e39a3582468786cdee703b0}.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1) (6c508e445709fc5583064087f0ec6e1b) switched from SCHEDULED to DEPLOYING.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Deploying Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1) (attempt #0) to localhost
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (613dcb24fc9ec9e8c9f7d03a84357fe3) switched from SCHEDULED to DEPLOYING.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Deploying Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (attempt #0) to localhost
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (3f74c2d6ee4651a49c819ffc5d84ea72) switched from SCHEDULED to DEPLOYING.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Deploying Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (attempt #0) to localhost
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (36517e9d607ccfc164c74c0819598730) switched from SCHEDULED to DEPLOYING.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Deploying GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (attempt #0) to localhost
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Received task Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1).
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (1/1) (71df1487d05a43b9c86ac46df118ec5f) switched from SCHEDULED to DEPLOYING.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Deploying ToKeyedWorkItem (1/1) (attempt #0) to localhost
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (25b7085d160a265b60d852d911698b2f) switched from SCHEDULED to DEPLOYING.
[Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1) (6c508e445709fc5583064087f0ec6e1b) switched from CREATED to DEPLOYING.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Deploying assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (attempt #0) to localhost
[Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Creating FileSystem stream leak safety net for task Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1) (6c508e445709fc5583064087f0ec6e1b) [DEPLOYING]
[Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Loading JAR files for task Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1) (6c508e445709fc5583064087f0ec6e1b) [DEPLOYING].
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Received task Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1).
[Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Registering task at network: Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1) (6c508e445709fc5583064087f0ec6e1b) [DEPLOYING].
[Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (613dcb24fc9ec9e8c9f7d03a84357fe3) switched from CREATED to DEPLOYING.
[Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Creating FileSystem stream leak safety net for task Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (613dcb24fc9ec9e8c9f7d03a84357fe3) [DEPLOYING]
[Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Loading JAR files for task Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (613dcb24fc9ec9e8c9f7d03a84357fe3) [DEPLOYING].
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Received task Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1).
[Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Registering task at network: Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (613dcb24fc9ec9e8c9f7d03a84357fe3) [DEPLOYING].
[Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (3f74c2d6ee4651a49c819ffc5d84ea72) switched from CREATED to DEPLOYING.
[Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Creating FileSystem stream leak safety net for task Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (3f74c2d6ee4651a49c819ffc5d84ea72) [DEPLOYING]
[Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Loading JAR files for task Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (3f74c2d6ee4651a49c819ffc5d84ea72) [DEPLOYING].
[Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Registering task at network: Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (3f74c2d6ee4651a49c819ffc5d84ea72) [DEPLOYING].
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Received task GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1).
[GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (36517e9d607ccfc164c74c0819598730) switched from CREATED to DEPLOYING.
[GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Creating FileSystem stream leak safety net for task GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (36517e9d607ccfc164c74c0819598730) [DEPLOYING]
[GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Loading JAR files for task GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (36517e9d607ccfc164c74c0819598730) [DEPLOYING].
[GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Registering task at network: GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (36517e9d607ccfc164c74c0819598730) [DEPLOYING].
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Received task ToKeyedWorkItem (1/1).
[ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - ToKeyedWorkItem (1/1) (71df1487d05a43b9c86ac46df118ec5f) switched from CREATED to DEPLOYING.
[ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Creating FileSystem stream leak safety net for task ToKeyedWorkItem (1/1) (71df1487d05a43b9c86ac46df118ec5f) [DEPLOYING]
[ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Loading JAR files for task ToKeyedWorkItem (1/1) (71df1487d05a43b9c86ac46df118ec5f) [DEPLOYING].
[Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1) (6c508e445709fc5583064087f0ec6e1b) switched from DEPLOYING to RUNNING.
[ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Registering task at network: ToKeyedWorkItem (1/1) (71df1487d05a43b9c86ac46df118ec5f) [DEPLOYING].
[flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1) (6c508e445709fc5583064087f0ec6e1b) switched from DEPLOYING to RUNNING.
[Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.streaming.runtime.tasks.StreamTask - No state backend has been configured, using default (Memory / JobManager) MemoryStateBackend (data in heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints: 'null', asynchronous: TRUE, maxStateSize: 5242880)
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Received task assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1).
[Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (613dcb24fc9ec9e8c9f7d03a84357fe3) switched from DEPLOYING to RUNNING.
[Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.streaming.runtime.tasks.StreamTask - No state backend has been configured, using default (Memory / JobManager) MemoryStateBackend (data in heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints: 'null', asynchronous: TRUE, maxStateSize: 5242880)
[flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (613dcb24fc9ec9e8c9f7d03a84357fe3) switched from DEPLOYING to RUNNING.
[Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (3f74c2d6ee4651a49c819ffc5d84ea72) switched from DEPLOYING to RUNNING.
[flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (3f74c2d6ee4651a49c819ffc5d84ea72) switched from DEPLOYING to RUNNING.
[Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.streaming.runtime.tasks.StreamTask - No state backend has been configured, using default (Memory / JobManager) MemoryStateBackend (data in heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints: 'null', asynchronous: TRUE, maxStateSize: 5242880)
[assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (25b7085d160a265b60d852d911698b2f) switched from CREATED to DEPLOYING.
[assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Creating FileSystem stream leak safety net for task assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (25b7085d160a265b60d852d911698b2f) [DEPLOYING]
[assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Loading JAR files for task assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (25b7085d160a265b60d852d911698b2f) [DEPLOYING].
[ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - ToKeyedWorkItem (1/1) (71df1487d05a43b9c86ac46df118ec5f) switched from DEPLOYING to RUNNING.
[flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (1/1) (71df1487d05a43b9c86ac46df118ec5f) switched from DEPLOYING to RUNNING.
[ToKeyedWorkItem (1/1)] INFO org.apache.flink.streaming.runtime.tasks.StreamTask - No state backend has been configured, using default (Memory / JobManager) MemoryStateBackend (data in heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints: 'null', asynchronous: TRUE, maxStateSize: 5242880)
[assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Registering task at network: assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (25b7085d160a265b60d852d911698b2f) [DEPLOYING].
[assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (25b7085d160a265b60d852d911698b2f) switched from DEPLOYING to RUNNING.
[GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (36517e9d607ccfc164c74c0819598730) switched from DEPLOYING to RUNNING.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (25b7085d160a265b60d852d911698b2f) switched from DEPLOYING to RUNNING.
[assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.streaming.runtime.tasks.StreamTask - No state backend has been configured, using default (Memory / JobManager) MemoryStateBackend (data in heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints: 'null', asynchronous: TRUE, maxStateSize: 5242880)
[GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.streaming.runtime.tasks.StreamTask - No state backend has been configured, using default (Memory / JobManager) MemoryStateBackend (data in heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints: 'null', asynchronous: TRUE, maxStateSize: 5242880)
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (36517e9d607ccfc164c74c0819598730) switched from DEPLOYING to RUNNING.
[Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] WARN org.apache.flink.metrics.MetricGroup - The operator name 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 exceeded the 80 characters length limit and was truncated.
[assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.state.heap.HeapKeyedStateBackend - Initializing heap keyed state backend with stream factory.
[Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.state.heap.HeapKeyedStateBackend - Initializing heap keyed state backend with stream factory.
[GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.state.heap.HeapKeyedStateBackend - Initializing heap keyed state backend with stream factory.
[Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] WARN org.apache.beam.runners.fnexecution.environment.DockerCommand - Unable to pull docker image jenkins-docker-apache.bintray.io/beam/python:latest, cause: Received exit code 1 for command 'docker pull jenkins-docker-apache.bintray.io/beam/python:latest'. stderr: Error response from daemon: unknown: Repo 'apache' was not found
[grpc-default-executor-1] INFO org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService - GetManifest for /tmp/flinktestyC5bJk/job_53dae6f5-113d-40ce-a2e7-ce25284b6b23/MANIFEST
[grpc-default-executor-1] INFO org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService - Loading manifest for retrieval token /tmp/flinktestyC5bJk/job_53dae6f5-113d-40ce-a2e7-ce25284b6b23/MANIFEST
[grpc-default-executor-1] INFO org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService - Manifest at /tmp/flinktestyC5bJk/job_53dae6f5-113d-40ce-a2e7-ce25284b6b23/MANIFEST has 0 artifact locations
[grpc-default-executor-1] INFO org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService - GetManifest for /tmp/flinktestyC5bJk/job_53dae6f5-113d-40ce-a2e7-ce25284b6b23/MANIFEST -> 0 artifacts
[grpc-default-executor-1] INFO org.apache.beam.runners.fnexecution.logging.GrpcLoggingService - Beam Fn Logging client connected.
[grpc-default-executor-1] INFO sdk_worker_main.main - Logging handler created.
[grpc-default-executor-1] INFO sdk_worker_main.start - Status HTTP server running at localhost:34903
[grpc-default-executor-1] INFO sdk_worker_main.main - semi_persistent_directory: /tmp
[grpc-default-executor-1] WARN sdk_worker_main._load_main_session - No session file found: /tmp/staged/pickled_main_session. Functions defined in __main__ (interactive session) may fail. 
[grpc-default-executor-1] INFO pipeline_options.get_all_options - Parsing unknown args: [u'--direct_runner_use_stacked_bundle', u'--options_id=21', u'--pipeline_type_check', u'--sdk_worker_parallelism=1']
[grpc-default-executor-1] INFO sdk_worker_main.main - Python sdk harness started with pipeline_options: {'runner': u'None', 'streaming': True, 'experiments': [u'beam_fn_api'], 'sdk_location': u'container', 'flink_master': '[auto]', 'direct_runner_use_stacked_bundle': None, 'sdk_worker_parallelism': u'1', 'job_name': u'test_windowing_1541816169.86', 'options_id': u'21', 'pipeline_type_check': None, 'parallelism': 1, 'job_endpoint': u'localhost:50341'}
[grpc-default-executor-1] INFO sdk_worker.__init__ - Creating insecure control channel.
[grpc-default-executor-1] INFO sdk_worker.__init__ - Control channel established.
[grpc-default-executor-1] INFO sdk_worker.__init__ - Initializing SDKHarness with 12 workers.
[grpc-default-executor-1] INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService - Beam Fn Control client connected with id 1
[grpc-default-executor-1] INFO sdk_worker.create_state_handler - Creating channel for localhost:41241
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/write/ref_PCollection_PCollection_4:0 
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/write/ref_PCollection_PCollection_24:1:0 
[grpc-default-executor-1] INFO data_plane.create_data_channel - Creating channel for localhost:45341
[grpc-default-executor-1] INFO org.apache.beam.runners.fnexecution.data.GrpcDataService - Beam Fn Data client connected.
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_17:0 
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_1:0 
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/write/ref_PCollection_PCollection_12:0 
[Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1) (6c508e445709fc5583064087f0ec6e1b) switched from RUNNING to FINISHED.
[Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1) (6c508e445709fc5583064087f0ec6e1b).
[Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1) (6c508e445709fc5583064087f0ec6e1b) [FINISHED]
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 6c508e445709fc5583064087f0ec6e1b.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Source: Custom Source -> 26assert_that/Create/Impulse.None/beam:env:docker:v1:0 (1/1) (6c508e445709fc5583064087f0ec6e1b) switched from RUNNING to FINISHED.
[Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (613dcb24fc9ec9e8c9f7d03a84357fe3) switched from RUNNING to FINISHED.
[Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (613dcb24fc9ec9e8c9f7d03a84357fe3).
[Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (613dcb24fc9ec9e8c9f7d03a84357fe3) [FINISHED]
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem 613dcb24fc9ec9e8c9f7d03a84357fe3.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Source: Custom Source -> 14Create/Impulse.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (613dcb24fc9ec9e8c9f7d03a84357fe3) switched from RUNNING to FINISHED.
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_7:0 
[Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (3f74c2d6ee4651a49c819ffc5d84ea72) switched from RUNNING to FINISHED.
[Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (3f74c2d6ee4651a49c819ffc5d84ea72).
[Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (3f74c2d6ee4651a49c819ffc5d84ea72) [FINISHED]
[flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem 3f74c2d6ee4651a49c819ffc5d84ea72.
[flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey -> 72Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 -> ToKeyedWorkItem (1/1) (3f74c2d6ee4651a49c819ffc5d84ea72) switched from RUNNING to FINISHED.
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/write/ref_PCollection_PCollection_24:0:0 
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_15:0 
[GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (36517e9d607ccfc164c74c0819598730) switched from RUNNING to FINISHED.
[GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (36517e9d607ccfc164c74c0819598730).
[GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (36517e9d607ccfc164c74c0819598730) [FINISHED]
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 36517e9d607ccfc164c74c0819598730.
[ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - ToKeyedWorkItem (1/1) (71df1487d05a43b9c86ac46df118ec5f) switched from RUNNING to FINISHED.
[ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for ToKeyedWorkItem (1/1) (71df1487d05a43b9c86ac46df118ec5f).
[ToKeyedWorkItem (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task ToKeyedWorkItem (1/1) (71df1487d05a43b9c86ac46df118ec5f) [FINISHED]
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task ToKeyedWorkItem 71df1487d05a43b9c86ac46df118ec5f.
[flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - GroupByKey -> 24GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (36517e9d607ccfc164c74c0819598730) switched from RUNNING to FINISHED.
[flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - ToKeyedWorkItem (1/1) (71df1487d05a43b9c86ac46df118ec5f) switched from RUNNING to FINISHED.
[grpc-default-executor-1] WARN bundle_processor.create_operation - No unique name set for transform fn/read/ref_PCollection_PCollection_27:0 
[grpc-default-executor-1] INFO sdk_worker.run - No more requests from control plane
[grpc-default-executor-1] INFO sdk_worker.run - SDK Harness waiting for in-flight requests to complete
[grpc-default-executor-1] INFO data_plane.close - Closing all cached grpc data channels.
[grpc-default-executor-0] WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer - Hanged up for unknown endpoint.
[grpc-default-executor-0] INFO sdk_worker.close - Closing all cached gRPC state handlers.
[grpc-default-executor-1] INFO sdk_worker.run - Done consuming work.
[grpc-default-executor-1] INFO sdk_worker_main.main - Python sdk harness exiting.
[grpc-default-executor-1] INFO org.apache.beam.runners.fnexecution.logging.GrpcLoggingService - Logging client hanged up.
[assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer - Hanged up for unknown endpoint.
[assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (25b7085d160a265b60d852d911698b2f) switched from RUNNING to FINISHED.
[assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Freeing task resources for assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (25b7085d160a265b60d852d911698b2f).
[assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1)] INFO org.apache.flink.runtime.taskmanager.Task - Ensuring all FileSystem streams are closed for task assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (25b7085d160a265b60d852d911698b2f) [FINISHED]
[flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Un-registering task and sending final execution state FINISHED to JobManager for task assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 25b7085d160a265b60d852d911698b2f.
[flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - assert_that/Group/GroupByKey -> 42assert_that/Group/GroupByKey/GroupByWindow.None/beam:env:docker:v1:0 (1/1) (25b7085d160a265b60d852d911698b2f) switched from RUNNING to FINISHED.
[flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Job test_windowing_1541816169.86 (b504cfdbe355304ba1d80cc8bcfc99c7) switched from state RUNNING to FINISHED.
[flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.checkpoint.CheckpointCoordinator - Stopping checkpoint coordinator for job b504cfdbe355304ba1d80cc8bcfc99c7.
[flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore - Shutting down
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.dispatcher.StandaloneDispatcher - Job b504cfdbe355304ba1d80cc8bcfc99c7 reached globally terminal state FINISHED.
[flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.jobmaster.JobMaster - Stopping the JobMaster for job test_windowing_1541816169.86(b504cfdbe355304ba1d80cc8bcfc99c7).
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Close JobManager connection for job b504cfdbe355304ba1d80cc8bcfc99c7.
[flink-runner-job-server] INFO org.apache.flink.runtime.minicluster.MiniCluster - Shutting down Flink Mini Cluster
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.jobmaster.slotpool.SlotPool - Suspending SlotPool.
[flink-runner-job-server] INFO org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint - Shutting down rest endpoint.
[flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.jobmaster.JobMaster - Close ResourceManager connection 8dff754b33d606c4eaa65bfe27382688: JobManager is shutting down..
[flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.dispatcher.StandaloneDispatcher - Stopping dispatcher akka://flink/user/dispatcher5d874160-3faf-4791-9cf4-63588858097f.
[flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.dispatcher.StandaloneDispatcher - Stopping all currently running jobs of dispatcher akka://flink/user/dispatcher5d874160-3faf-4791-9cf4-63588858097f.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.resourcemanager.StandaloneResourceManager - Disconnect job manager 9705bf03def60b2a6446071805ac4e37@akka://flink/user/jobmanager_41 for job b504cfdbe355304ba1d80cc8bcfc99c7 from the resource manager.
[flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.rpc.akka.AkkaRpcActor - The rpc endpoint org.apache.flink.runtime.jobmaster.slotpool.SlotPool has not been started yet. Discarding message org.apache.flink.runtime.rpc.messages.LocalRpcInvocation until processing is started.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager - Closing the SlotManager.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable - Free slot TaskSlot(index:0, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{a2b817be9e39a3582468786cdee703b0}, jobId: b504cfdbe355304ba1d80cc8bcfc99c7).
[flink-akka.actor.default-dispatcher-2] INFO org.apache.flink.runtime.taskexecutor.JobLeaderService - Could not resolve JobManager address akka://flink/user/jobmanager_41, retrying in 10000 ms: Could not connect to rpc endpoint under address akka://flink/user/jobmanager_41..
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager - Suspending the SlotManager.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.JobLeaderService - Remove job b504cfdbe355304ba1d80cc8bcfc99c7 from job leader monitoring.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Close JobManager connection for job b504cfdbe355304ba1d80cc8bcfc99c7.
[flink-akka.actor.default-dispatcher-5] INFO org.apache.flink.runtime.jobmaster.slotpool.SlotPool - Stopping SlotPool.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Stopping TaskExecutor akka://flink/user/taskmanager_40.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager - Shutting down TaskExecutorLocalStateStoresManager.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.io.disk.iomanager.IOManager - I/O manager removed spill file directory /tmp/flink-io-29cbf861-0111-4644-a78c-68b507b283de
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.io.network.NetworkEnvironment - Shutting down the network environment and its components.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.JobLeaderService - Stop job leader service.
[ForkJoinPool.commonPool-worker-2] INFO org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint - Removing cache directory /tmp/flink-web-ui
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.taskexecutor.TaskExecutor - Stopped TaskExecutor akka://flink/user/taskmanager_40.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator - Shutting down stack trace sample coordinator.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.dispatcher.StandaloneDispatcher - Stopped dispatcher akka://flink/user/dispatcher5d874160-3faf-4791-9cf4-63588858097f.
[flink-akka.actor.default-dispatcher-4] INFO org.apache.flink.runtime.rpc.akka.AkkaRpcService - Stopping Akka RPC service.
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.blob.PermanentBlobCache - Shutting down BLOB cache
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.blob.TransientBlobCache - Shutting down BLOB cache
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:45211
[flink-akka.actor.default-dispatcher-3] INFO org.apache.flink.runtime.rpc.akka.AkkaRpcService - Stopped Akka RPC service.
[flink-runner-job-server] INFO org.apache.beam.runners.flink.FlinkRunner - Execution finished in 2091 msecs
[flink-runner-job-server] INFO org.apache.beam.runners.flink.FlinkRunner - Final accumulator values:
[flink-runner-job-server] INFO org.apache.beam.runners.flink.FlinkRunner - __metricscontainers : org.apache.beam.runners.core.metrics.MetricsContainerStepMap@16fdda
.
----------------------------------------------------------------------
Ran 26 tests in 79.690s

OK (skipped=7)
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':' Thread 2,5,main]) completed. Took 1 mins 21.812 secs.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 139

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 11m 3s
60 actionable tasks: 55 executed, 4 from cache, 1 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #696

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

------------------------------------------
[...truncated 473.76 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541808427.15_a41f4f9f-1f77-485f-9208-a088f8628b89 failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541808427.69_6e343e18-5648-46aa-8db8-67be5f283362 failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541808428.25_a738c6e0-a3ed-44a1-8d7b-c1a03d07b55c failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541808428.64_6b4318b4-0e5b-4d9c-8162-6c1cca77fd49 failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541808428.98_48d659b3-6896-4ecf-bc2d-23e7a4630499 failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541808429.29_5133f6b4-2688-4499-a272-366b2630575a failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541808429.64_1f773a2b-0105-41ea-9791-491f825dfb66 failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541808430.29_d0d49a46-b5fe-4642-b67d-74ea322dac0f failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541808430.99_4b4a79ec-2a7b-4d78-9df8-eb6f92bb9d57 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541808431.6_0e2ae370-2820-433b-999d-0616dfdf6e38 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541808432.8_6294ff4e-b79d-4e35-aef9-1bb678865432 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541808433.36_bf021f4a-12ad-4687-88d0-1e5de9d7f815 failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541808433.84_c89e509c-d008-490f-88e8-a5971426a208 failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541808434.22_8774a562-b058-4325-a2a8-2995452356c7 failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541808434.55_a8a65e58-341b-4b79-b6af-b5e329bf0c26 failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541808435.07_0dfd854e-9f11-4b11-88a9-ea9f4eee2999 failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541808435.9_a7362f8d-8d07-40b6-81c7-12406594c708 failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 14.569s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 18.159 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 7m 6s
60 actionable tasks: 55 executed, 4 from cache, 1 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #695

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

------------------------------------------
[...truncated 474.09 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541786745.08_ebf8d66b-7a35-4070-a18e-80b60df64f17 failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541786745.44_b308bc40-3a21-412e-bad9-361d24dc8d55 failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541786745.96_a2f0472b-36f0-4244-ad70-d743e7be4943 failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541786746.32_c9c29237-2079-43ae-9ce7-17d8471ce4ec failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541786746.63_878c8e35-20b7-43ff-af7c-96d4748a4340 failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541786746.94_86cc1da6-b11a-4299-9c56-b1e9624cc419 failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541786747.31_7fe9e0f7-7c29-48e6-a670-3338d65be830 failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541786747.83_9b8cb0eb-8678-4378-8668-d7313aaa0407 failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541786748.32_e3cb407d-4f10-49b1-a5d2-7ffdcd5395da failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541786748.82_956cb743-36c9-47e6-902b-4052667dd027 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541786749.81_cf68e8fc-55e6-4230-b649-e3c5ee513952 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541786750.21_cedae38d-0313-434e-a2fb-55fba1a21596 failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541786750.63_13b22737-a0b3-458d-84b4-c1b13ddb9d59 failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541786750.97_25338422-dc7c-455e-8813-a9fa9776dbd8 failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541786751.27_d0382009-bfe3-4184-adb2-2a34521a6c3b failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541786751.71_7e92e208-8afe-4118-9f2a-6c995d25689f failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541786752.03_408b31cb-fba4-4556-afe6-0ec3682054fb failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 11.655s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':' Thread 5,5,main]) completed. Took 13.516 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 5m 46s
60 actionable tasks: 55 executed, 4 from cache, 1 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #694

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/694/display/redirect?page=changes>

Changes:

[github] [BEAM-3741] Proto changes for reporting backlog/splitting/finalizing

------------------------------------------
[...truncated 474.33 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541785722.55_00d14ab0-d39b-493f-91da-7d9106d8723a failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541785722.93_59ed9964-8ded-4ace-8537-abd293360d3f failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541785723.43_73b9e1a1-ba5f-4760-a77c-eb935c06146e failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541785723.78_c6213bb5-bf0a-48c7-83cc-a660777478e7 failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541785724.07_b8059170-8792-4a2d-8656-e38442232111 failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541785724.36_ba93ec2f-39b5-4d7e-abb1-5d4db51f8cf7 failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541785724.68_1ef3fc7f-9126-4436-9aa5-2a3d212e724c failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541785725.18_2bb09628-69f2-43a6-82e5-0ba173e396b5 failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541785725.65_00f6bf95-3262-4fce-ab47-09954c585ac1 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541785726.12_1b1bdfbb-ac04-4edb-ba12-18b5b9952ef3 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541785727.11_4c66678f-dd45-4c58-8429-5d5c452eff8f failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541785727.74_f1054c1d-8f21-4287-88db-4343344e7db7 failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541785728.33_1a4e456a-ba20-4306-842a-7f1f550164c2 failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541785728.81_111f2df4-e322-45d4-afd4-5be08e33f2f3 failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541785729.18_ca1efd4d-63c4-4a58-85e5-8c5c4bb6baca failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541785729.57_943b107c-82ee-4c74-bd18-3e0064573c8c failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541785729.86_33e9016a-8536-41b8-a384-f49e062f3013 failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 11.949s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':' Thread 9,5,main]) completed. Took 13.848 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 5m 48s
60 actionable tasks: 59 executed, 1 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #693

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

------------------------------------------
[...truncated 473.93 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541785364.7_11f783c8-98d3-4143-80e4-da0a8fedbc1a failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541785365.06_f573c014-36e4-4b67-b664-b8c4c0b8ee4b failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541785365.58_17a27814-2905-4dfd-a73f-8e61b05ed771 failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541785365.95_c6810e68-4e2b-4c38-9c17-a7bfd1f81b15 failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541785366.26_820fdc77-63da-4c1e-8d46-0372dc582be9 failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541785366.55_5bb2bb3d-08fa-4bb2-82ed-c796f82427a2 failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541785366.92_33b5b8ad-3b7c-4d9a-87dd-adae485f05a6 failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541785367.52_cae8d4ef-2675-481c-a3d1-fa7261496e38 failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541785368.06_280ef60a-33b2-4b85-b0cd-2d62b58246e8 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541785368.52_3fabe253-bb62-4f2d-9366-913c7b3cf934 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541785369.5_3a2819ad-8840-4219-b7d2-f920aabdc534 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541785369.89_5b4ce96e-e3b7-4fdc-8363-9a2f0af5c177 failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541785370.32_f5dc44b3-18bf-4acb-9d02-648cb8cb2012 failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541785370.64_cbc55665-dd4e-4c81-9f38-7c19ac171310 failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541785370.95_ebfdbc98-6d64-4a9a-b9ae-a0b7f779eba5 failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541785371.33_9b03251a-7898-4cc0-821b-17bd455e7c3c failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541785371.63_d1eda2a5-e212-4bab-a33e-b1c74453df0e failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 11.181s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':' Thread 7,5,main]) completed. Took 13.059 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 5m 46s
60 actionable tasks: 55 executed, 4 from cache, 1 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #692

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/692/display/redirect?page=changes>

Changes:

[david.moravek] [BEAM-5790] Euphoria: Remove Dataset abstraction.

[david.moravek] [BEAM-5790] Euphoria: Fix missing website link.

[david.moravek] [BEAM-5790] Euphoria: Remove OutputBuilder where possible.

------------------------------------------
[...truncated 477.30 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541785009.51_5e99c4b7-54ff-437b-b20d-2e55624b839e failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541785009.89_366e73f1-ec17-4601-a9b5-7f6bee556b99 failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541785010.41_81c79dc3-4ed7-4538-8cf9-bf7bddb800c8 failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541785010.79_9bb7f2ac-32d7-4cea-85c3-88020db239ff failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541785011.1_fa1d83d0-0817-4afc-9aa9-20659b5adf0e failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541785011.41_781bfed1-2c04-421e-bd24-dd131754171d failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541785011.73_b5e8304d-016d-4b10-a647-bdda7d06d373 failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541785012.22_da5dbe63-99a5-480c-b4f4-d06fa4ee59a9 failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541785012.67_cb860165-4909-4eb0-864c-d870cb49db3a failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541785013.14_d7b65ef2-801e-4963-a771-7673881135a2 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541785014.11_4845714c-c399-4eff-9ea0-98d9ca3dd5aa failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541785014.49_c97a3cbc-a917-40b3-ad69-080fe8483b5f failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541785014.95_48222d80-edbb-478c-9a94-9a725b768be3 failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541785015.26_b782ccfa-39d4-425c-9c9c-a731bf7610c2 failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541785015.55_2d88e9b8-b268-4ece-86ae-64e56b65b3e0 failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541785015.96_17e3b59f-a5b3-48bf-b77a-0aadd5d0b48c failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541785016.25_e384b4bf-cc41-4709-bdc6-7075e42611e2 failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 10.933s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 12.921 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 6m 2s
60 actionable tasks: 55 executed, 4 from cache, 1 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #691

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/691/display/redirect?page=changes>

Changes:

[iemejia] [BEAM-6023] Remove Create.Values translation from Spark Runner

------------------------------------------
[...truncated 477.45 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541769075.26_fabb952e-e56a-4709-8cff-caef86c7b284 failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541769075.6_419e70aa-1d68-444a-9264-30cae9937dbf failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541769076.11_7e19db22-9edc-40f1-b818-20e1de5b216f failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541769076.46_616cafe1-5836-4165-9145-aa9539647e15 failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541769076.75_75700e83-9ff1-477a-bb62-d4ea7d7263c2 failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541769077.04_4146a9c3-6aef-4ea8-ad96-f0364dbb258d failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541769077.38_77781719-01c3-4c10-b3ed-3e368725ce6b failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541769077.87_86eb862a-b551-4b50-bebb-174dff278fc0 failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541769078.31_4681b085-c521-4467-9411-d113a188d87c failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541769078.79_b2fb6304-2843-4ded-af76-271662518326 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541769079.75_ddc7f5be-56c2-4efa-9810-0c84cd0a3b33 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541769080.13_5c107b01-0ebb-4faf-80a7-bc780db106d0 failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541769080.54_b4623108-6858-4e1b-a615-8f7e59efd1f1 failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541769080.85_571e35de-4fc1-43fc-bc0f-ce4f45c6f672 failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541769081.15_bd5c6699-647b-485b-b513-0c8abc6f7f80 failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541769081.53_f1f7326a-84f9-431a-8262-22652e59eb1a failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541769081.84_947bea1b-b6d1-47e5-bb8a-b994a86e4f73 failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 10.864s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':',5,main]) completed. Took 12.664 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 6m 1s
60 actionable tasks: 55 executed, 4 from cache, 1 up-to-date

Publishing build scan...
https://gradle.com/s/6du3amianjyua

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #690

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

------------------------------------------
[...truncated 474.42 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541765164.55_88b53b5e-b174-44aa-9da8-7f06d97840c9 failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541765164.92_e79c13a1-7e32-4473-8dd3-94f593dc8bf1 failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541765165.44_959ee35d-c6a2-461c-acf0-c61956219aae failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541765165.81_6bf906af-e4b3-4026-aab6-b4c1aa695afc failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541765166.14_ab5907ef-0fd1-4816-89c5-a884a76bef01 failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541765166.44_b9648305-e076-4684-a69f-27351fdf4aee failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541765166.78_17f6abe6-4494-45a9-90f9-b4c36473fc92 failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541765167.3_ee826805-8776-4942-9f38-54eea5defc28 failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541765167.78_2281c334-050f-4a21-9188-163eea7fd235 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541765168.26_a15943ed-b165-4990-96f0-f10385466f29 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541765169.26_660376a9-5eda-4e21-b304-e255fd653730 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541765169.66_6a034859-9bc0-43ae-947a-57c41e98933c failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541765170.11_7b474726-3235-4c4b-8bd9-de168511a8d5 failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541765170.44_f2a31f22-0cf0-4328-938a-d07cffe760e9 failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541765170.74_297ba0f5-5d7d-4172-af53-b002b9237fb5 failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541765171.18_5d86a499-0fdd-4921-a8b7-0f5770ed9b82 failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541765171.48_75c9aec0-4d7a-4098-9092-c404f8a147b1 failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 11.563s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Daemon worker,5,main]) completed. Took 13.426 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 6m 1s
60 actionable tasks: 55 executed, 4 from cache, 1 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #689

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/689/display/redirect?page=changes>

Changes:

[huangry] Revert "Revert "[BEAM-5299] Define max timestamp for global window in

------------------------------------------
[...truncated 479.01 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541763023.16_5dd8f584-fb97-4505-90f0-a4bc3be57e2c failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541763023.51_d1b2647e-4c08-4434-9355-be0ea6ac903f failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541763024.02_fbf21c92-06b6-4ee1-b049-d8275fc75727 failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541763024.41_a005353e-031a-4d74-a8ec-45ab71c8aacd failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541763024.71_a3ff53de-8c2f-4dc1-a84e-b17f7975f7ef failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541763025.01_1acff4bb-487c-400d-abe4-00e0ce1f1dc7 failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541763025.33_58381000-11ba-4252-9b03-c8e1d4adff52 failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541763025.86_9b237899-9635-4270-bb89-92bb84470132 failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541763026.35_9a40c7fb-8486-4584-9c5e-717429a8d45e failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541763026.81_72f4414d-64d7-42cd-b829-5f7a64c651c6 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541763027.76_6d8faaa3-c548-4425-b400-a6dd65f7c04f failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541763028.16_2b4047b4-8482-4176-8cfc-82842826e48b failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541763028.57_b433cd28-d6e0-43da-8b2a-e71402f94048 failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541763028.88_87504f68-ddcf-4a77-9b99-27aadab55b2b failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541763029.18_1598ce95-c0d1-4cd3-aad2-4d44c6eda52b failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541763029.56_535863f5-5b34-4d4e-9f13-e54365d97b9c failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541763029.86_2c124934-047a-4652-bbd4-a6ede9d5ce19 failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 11.455s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':' Thread 2,5,main]) completed. Took 13.305 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 6m 17s
60 actionable tasks: 58 executed, 1 from cache, 1 up-to-date

Publishing build scan...
https://gradle.com/s/5phxn2tasgwai

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #688

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

------------------------------------------
[...truncated 480.94 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541743618.43_07a6dcf5-7c8e-4a12-866c-af8cdf180f8d failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541743618.96_7fa3f136-f06a-4e03-a1a5-b648ce9ec242 failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541743619.61_2de33db7-25c6-48c3-921b-91a8214884b6 failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541743620.07_9792d7a3-374a-4bec-8815-5d4ad198f496 failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541743620.58_24de17df-45cd-4c92-b392-88cdad5f5d28 failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541743620.89_b36292af-6951-40d3-9de6-bb4e7e93eb8b failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541743621.31_6c52a39b-e610-40c3-9236-6b56c7c41a47 failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541743622.03_c40f3251-4d56-4e9e-8bc8-685ff3b26031 failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541743622.7_7ca6ba81-e72b-4336-8ef8-cd9ebe128521 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541743623.27_ced3ec2b-e08a-4368-8766-64ac31943d9f failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541743624.39_df0b4852-2789-43bb-8dc5-40d691030488 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541743624.87_1d3ea53e-096a-42b8-b864-8e1637aedce1 failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541743625.51_6179ac29-8310-46e6-a938-856135326751 failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541743625.85_fe6205a9-a39d-4de7-a5cf-caf49098d4c7 failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541743626.22_b8a721af-e767-42ce-a99b-4fa3db026ec5 failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541743626.79_80fa31fd-37f5-40b7-be67-6dec6999ffef failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541743627.19_d3b7f986-c455-4d65-a5e6-c102e13858be failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 14.347s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':' Thread 6,5,main]) completed. Took 16.606 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 6m 58s
60 actionable tasks: 55 executed, 4 from cache, 1 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #687

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/687/display/redirect?page=changes>

Changes:

[scott] [BEAM-6028] Revert "Merge pull request #6979: Add helper task to print

------------------------------------------
[...truncated 473.23 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541724180.3_92509136-8317-4fff-b507-6902b02e9174 failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541724180.69_4b3bae16-e077-46c9-9110-f8801d0c6462 failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541724181.24_15cbd91b-7d76-42f0-b491-9fac62f43fb4 failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541724181.62_720fd04a-66aa-4a27-b815-e6b3846338d2 failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541724181.97_797dade4-381f-467c-a921-f141ea8d9656 failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541724182.27_c7daa86c-b76d-4a6c-afb3-5c478218fa70 failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541724182.63_3ed82516-9e6d-4fa5-a9b0-78baa9d596c5 failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541724183.18_951027cc-dc7f-405f-a8ee-a1ad13b22d48 failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541724183.66_c8cddfb5-39e1-46f9-b35b-fbeba1a7c050 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541724184.15_722ab6f4-e24b-4790-ac62-ef36cfeb9783 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541724185.21_ce8b5949-ef2d-4199-a89e-242dfcc49a60 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541724185.65_3c4d924f-cf61-4c54-b9ed-914a0e970783 failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541724186.16_f4f98816-c15a-4222-b32d-78e2aac0a7f2 failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541724186.54_fd89d351-a544-4589-bc8d-e2b1147a5c54 failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541724186.97_2f3b0c97-c5e6-49ef-8bc9-cd5558bba78c failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541724187.51_09d0242d-5e80-4abb-a026-dd0200caf623 failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541724187.88_a8ecd792-09bc-4261-a583-a83d0f474830 failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 12.295s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':' Thread 10,5,main]) completed. Took 14.263 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 5m 47s
60 actionable tasks: 55 executed, 4 from cache, 1 up-to-date

Publishing build scan...
https://gradle.com/s/5hnm7nu63tgww

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #686

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

------------------------------------------
[...truncated 473.78 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541721946.28_8fa07910-8aa0-4613-9f73-e72cab6193e1 failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541721946.67_36ea84c5-7918-4cba-a079-1e019722120b failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541721947.17_37165f10-dacd-4ba6-a2b8-a30e062d851d failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541721947.52_92cb1e1a-0693-4ed1-bb7c-f10db5e3682c failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541721947.81_73a8a039-b092-407b-86cb-0c7e9dc8455b failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541721948.09_9ddfcb91-8d13-40e3-8473-4d348075e508 failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541721948.41_d7496346-208a-4f4a-8ec6-d6702cebb562 failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541721948.93_a378ec6f-6ac6-44d5-86c4-af96e6502313 failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541721949.36_0da02fe8-5207-466e-b66b-5118be63d4b0 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541721949.83_f0138b9c-e87d-4728-9951-9fd2c414f68a failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541721950.8_9c8a3a21-f68f-4a42-b1dc-9a6a1600125a failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541721951.22_635c9ebd-8869-46fd-be88-a1aa31814ac8 failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541721951.69_b39a2acc-3c11-421f-8dfb-5bfa2aff4cf4 failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541721952.04_4e9bba46-2939-4e37-ad2c-a5e035579942 failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541721952.36_e89fa06e-170b-4765-842e-435ffe8cea12 failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541721952.8_d01d9bca-7e62-48ba-b458-9d9f39994d25 failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541721953.11_2f7c525d-c158-49f3-ad37-dbce586c09f8 failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 11.689s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':',5,main]) completed. Took 13.555 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 5m 46s
60 actionable tasks: 55 executed, 4 from cache, 1 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #685

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/685/display/redirect?page=changes>

Changes:

[melissapa] [BEAM-6026] Add website pages with SDK dependencies

[scott] Disable link checking on GitHub website links.

------------------------------------------
[...truncated 476.94 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541720166.61_3a6ed356-992e-45c0-9c97-80b4a5129350 failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541720166.95_5132746a-ac90-4101-8ff2-620f1e677f8c failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541720167.44_a68dac4b-d368-49f2-8113-c8a546f60b72 failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541720167.79_a7dc3cc4-b2c5-437e-831e-04d1f3071a76 failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541720168.09_1f9d1fc0-a96e-4206-8929-607f3c244054 failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541720168.4_d4e3c73e-fecf-47e7-9dd9-2354ac33a967 failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541720168.75_ebf90c03-a181-4314-b10f-30c7accd7547 failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541720169.26_8b5431c7-0b27-4d6d-8cf3-ba366ee08163 failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541720169.77_000be31a-5d23-4e76-b5ad-1ecc6a6e8526 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541720170.21_1f78afbf-54db-4972-8dbf-db84d17d493f failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541720171.17_c547142e-e115-4e02-b23f-eedd5fbcb128 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541720171.55_2bbc6703-9573-4bdc-8cf4-5ae51aa39db3 failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541720172.0_0aa97749-d48a-4040-81ae-e6514cb73596 failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541720172.33_a4834a11-5dad-4ebe-a514-ecfda0f2aeb7 failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541720172.65_d326ed94-a833-47df-9b82-98b6717d0582 failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541720173.04_7ec63052-21a6-4553-9d55-b66e876eab45 failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541720173.34_0008c434-3480-4989-93d6-158f3cd5124a failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 11.029s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':' Thread 11,5,main]) completed. Took 12.822 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 6m 2s
60 actionable tasks: 50 executed, 9 from cache, 1 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #684

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/684/display/redirect?page=changes>

Changes:

[amaliujia] [BEAM-5943][BEAM-5940] 1. Add ENDS_WITH. 2. Add LEGNTH.

[amaliujia] [BEAM-5945] add reverse

[amaliujia] [BEAM-5952] add STARTS_WITH.

[amaliujia] [SQL] add NULL check for builtin functions.

[amaliujia] [BEAM-5852] add FROM_HEX

[amaliujia] [BEAM-5962] Add TO_HEX

[amaliujia] [BEAM-5963]: add LPAD

[amaliujia] [BEAM-5965] Add RPAD

------------------------------------------
[...truncated 474.16 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541714871.57_66d4697c-18ac-414b-9ddf-470787d6b866 failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541714871.95_5e5268d8-0948-4fa9-bbbf-c0b568a1c329 failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541714872.48_9c9be4fa-eae9-4eb0-8768-520d0a1679f1 failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541714872.85_cd14b082-3bfc-42dd-b1f6-ebf4b6a17e56 failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541714873.17_f7f470b6-4f90-4884-b046-b9efc2ae0538 failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541714873.48_0f407aa4-20d3-4518-84d8-5b8169258393 failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541714873.83_70cddb8b-69be-4c20-9913-562995ea3397 failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541714874.35_f0c0c971-0490-4d2d-b095-67c4aa0140fa failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541714874.84_79ae0ff2-9cf2-48de-9134-d5b3bd00b995 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541714875.32_2f9f2c92-73b4-416b-99d7-2d3ce1db63c4 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541714876.32_a52c3432-31d7-40a1-a223-3c875de4e687 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541714876.71_909d2833-dc58-416a-88e7-d2762eab838b failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541714877.15_85de782c-cbeb-4c16-9a72-5b112a089250 failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541714877.48_26b24ba6-bae8-400e-8077-02993fced670 failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541714877.77_91d6f89b-4493-46d8-9b0d-217ab0406458 failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541714878.2_d4aed785-39e5-40c6-87fc-918a95b66033 failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541714878.5_e75390f5-6c15-4199-8b2e-28e8e1f32b4b failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 11.265s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':' Thread 10,5,main]) completed. Took 13.128 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 5m 53s
60 actionable tasks: 55 executed, 4 from cache, 1 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #683

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/683/display/redirect?page=changes>

Changes:

[github] [BEAM-6013] Reduce logging within SerializableCoder. (#6982)

------------------------------------------
[...truncated 473.88 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541709247.48_125efa31-9731-45e0-8896-b98fa6475b25 failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541709247.84_1f53608d-e14b-4764-b861-acf07706abe3 failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541709248.37_60652aa4-766a-4223-819e-514e41e01556 failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541709248.75_9b6d4f44-2ded-4daa-8a2a-3bc12fa72361 failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541709249.06_44f4554e-bde0-4965-979b-1f9c62ca1151 failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541709249.37_052305b3-101b-4225-8bf9-1545cb511336 failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541709249.7_146b2685-c1be-4662-8525-7d27ac41dff9 failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541709250.21_a72cf3db-c636-4da5-9822-eab26bd2fc70 failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541709250.68_135defa0-b29b-4888-88cf-75de6aab3d73 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541709251.16_da14be20-a9bd-42a8-a471-4bddebf664a3 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541709252.13_c3da355b-c745-406f-aaf5-3732ac144889 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541709252.53_3b5f23e7-9c91-4b87-ba98-e433f871366c failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541709252.97_5e500706-670b-4056-bdfb-ae01f8606757 failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541709253.28_60c35c23-020a-4884-8859-d5fe183afeed failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541709253.57_bb117925-d4fa-4a0b-8e86-d1ec1a08b272 failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541709253.95_5c6d1de7-7285-43dc-ba9a-6cae37076588 failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541709254.23_e6917879-cab0-4da2-beed-1e5d06c96ff2 failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 11.193s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 13.027 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 5m 50s
60 actionable tasks: 56 executed, 3 from cache, 1 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #682

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/682/display/redirect?page=changes>

Changes:

[lcwik] [BEAM-5931] Add worker jar to integrationTest targets. (#6966)

------------------------------------------
[...truncated 481.09 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541708754.07_ce9c0703-981a-4ab6-9e04-23f66de31812 failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541708754.42_26185d75-17de-48f5-9933-d8eab83238fb failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541708754.92_de2e5700-4599-4d96-bf18-d559f4960380 failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541708755.29_c9929574-38e9-4293-893b-f43a63615679 failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541708755.61_8f10043e-f4b3-46fe-b122-0a43819c4ffe failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541708755.96_4c68f105-3876-4e97-a501-b6d16d92eec2 failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541708756.29_cd614b83-aa75-40c8-a7d2-123e4025f0ae failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541708756.81_25035812-54b3-4503-9961-c09f7ebac6cb failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541708757.28_99094955-9119-423b-bda4-d0899813aaaa failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541708757.79_245727a3-6553-4075-b6df-792f7034e9cf failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541708758.88_f981e447-870c-4c1b-8968-7439c1edbc37 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541708759.27_76f03aca-e4e7-4dae-bc3f-c2163f3868d2 failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541708759.69_c87368d4-4081-4797-babf-1e46d9125f2e failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541708760.04_3ca9045c-442b-4edc-96ac-684550d0020b failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541708760.38_2bd5f099-c546-4479-935d-61eb53114b6e failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541708760.84_36a96198-01b3-4658-bbd6-2eff842333ef failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541708761.15_79d9a8ac-e767-4678-bbb3-0b1703fac709 failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 11.419s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':' Thread 11,5,main]) completed. Took 13.773 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 7m 22s
60 actionable tasks: 59 executed, 1 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #681

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/681/display/redirect?page=changes>

Changes:

[lcwik] Dataflow Worker: Add worker_id to windmill request headers (#6663)

------------------------------------------
[...truncated 473.53 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541701510.33_f138be3d-774e-47be-83d5-39271d01a29b failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541701510.66_7680c37e-14b1-406e-a85b-aef39f2f8e49 failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541701511.3_90d206cd-5076-4c2d-9f07-fa3c3533dfba failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541701511.62_92d59292-b803-47ae-b3ba-cc6f924e0ff5 failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541701511.9_1166588b-2b1f-4ca9-9ae8-4786413366ea failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541701512.17_f26e1fba-679f-4806-b7ef-2981a24667cf failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541701512.48_f3138953-d13d-41ed-9026-0621186a53f6 failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541701512.95_cd761585-05d9-41ee-afc1-652b28e02857 failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541701513.37_6c93885f-4b0c-40c5-a7a5-6a8b2007317e failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541701513.86_d7786d4f-6673-43f8-9d2e-8f41e18d35ad failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541701514.76_4f9d63a2-aaeb-464f-a758-a57bd593d3fc failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541701515.11_f8f8c90d-1cf8-4712-881a-851771dd3dce failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541701515.49_813bd02e-0443-45d9-bdd8-45c48d6884e7 failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541701515.78_90ade22e-53bb-49ad-b477-78cee5f26c72 failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541701516.04_8ddde22d-98d2-4c38-a771-581301e315c4 failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541701516.41_499b45e8-5204-4f3b-b674-d25fa9ca60ed failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541701516.77_06158cfb-6689-4584-994b-3d2a02fbf730 failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 9.179s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':' Thread 7,5,main]) completed. Took 11.048 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 5m 32s
60 actionable tasks: 55 executed, 4 from cache, 1 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #680

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/680/display/redirect?page=changes>

Changes:

[lcwik] Tolerate duplicate counters from SDK in StreamingDataflowWorker. (#6951)

------------------------------------------
[...truncated 473.98 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541701171.16_962f6b67-f0ae-4737-8a52-a339112eb486 failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541701171.65_a68e3d6e-5e4b-48bf-85ed-9136dcdab990 failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541701172.13_3d54f6e1-6e0d-4ac6-929d-d408be9db421 failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541701172.45_85ef8d73-4be2-41f8-ba88-b2fd183d7a3c failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541701172.73_f659346b-8765-4014-876b-64dd68079781 failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541701173.0_62378d05-af33-4229-ad93-34d2513be5b6 failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541701173.3_9234ebfa-0c77-4923-aedc-b027ea5e1613 failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541701173.77_3958f7ba-0f81-40da-b968-58a9408f002f failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541701174.2_ab1100e2-0369-4be2-a2b5-be015cd97eeb failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541701174.62_76d5d568-8d66-4987-939c-fc0b6c37724a failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541701175.52_d06536df-2064-41d5-8a26-7461eae012a1 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541701175.95_3c236f34-1035-474a-9e2e-d8c6fc608ef4 failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541701176.33_9f84fa72-df4c-4342-9188-33e7ebccc20b failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541701176.63_b136ad9d-5aa3-4244-aa19-697954c8a493 failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541701176.91_99b2c5fd-0d52-4643-9a74-3a65f8156c32 failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541701177.28_a4e347ea-ba30-4bef-96a5-c2f5f22a2525 failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541701177.55_ea8fa551-ffb6-4691-ae3c-9f378e72ac58 failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 10.996s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 12.836 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 5m 48s
60 actionable tasks: 55 executed, 4 from cache, 1 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #679

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

------------------------------------------
[...truncated 473.75 KB...]
    assert_that(res, equal_to([('a', 1.5), ('b', 3.0)]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_combine_per_key_1541700321.8_013079a4-6673-493e-bed4-f5f815452d16 failed in state FAILED.

======================================================================
ERROR: test_create (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 65, in test_create
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a', 'b']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_create_1541700322.13_41ea3a4c-bd1e-463f-bae4-27d346b21b9e failed in state FAILED.

======================================================================
ERROR: test_flatten (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 322, in test_flatten
    assert_that(res, equal_to(['a', 'b', 'c', 'd']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flatten_1541700322.58_9e2f46d7-2dbf-4d23-8fd0-11003cf8f6c9 failed in state FAILED.

======================================================================
ERROR: test_flattened_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 206, in test_flattened_side_input
    equal_to([(None, {'a': 1, 'b': 2})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_flattened_side_input_1541700322.91_31313b78-4cd1-4a6e-9736-b999d8e4b4c4 failed in state FAILED.

======================================================================
ERROR: test_gbk_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 217, in test_gbk_side_input
    equal_to([(None, {'a': [1]})]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_gbk_side_input_1541700323.18_03678155-9b04-40cf-9cc6-a40bbabccd8e failed in state FAILED.

======================================================================
ERROR: test_group_by_key (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 315, in test_group_by_key
    assert_that(res, equal_to([('a', [1, 2]), ('b', [3])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_group_by_key_1541700323.44_c2692a6c-5128-468e-9ce1-32d331657d43 failed in state FAILED.

======================================================================
ERROR: test_large_elements (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 382, in test_large_elements
    assert_that(gbk_res, equal_to(['a', 'b']), label='gbk')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_large_elements_1541700323.74_11a3d7c7-739b-488e-8301-f4d2ad18b828 failed in state FAILED.

======================================================================
ERROR: test_multimap_side_input (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 231, in test_multimap_side_input
    equal_to([('a', [1, 3]), ('b', [2])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_multimap_side_input_1541700324.21_858bf495-f791-4e87-8f38-a9b3a17972dc failed in state FAILED.

======================================================================
ERROR: test_pardo (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 73, in test_pardo
    assert_that(res, equal_to(['aax', 'bcbcx']))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_1541700324.64_20e58eda-e84f-4f0c-aab9-6de53a7d6a9a failed in state FAILED.

======================================================================
ERROR: test_pardo_side_and_main_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 149, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_and_main_outputs_1541700325.07_1d8f4dae-1fe0-4c57-a596-2b6bd77e7062 failed in state FAILED.

======================================================================
ERROR: test_pardo_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 163, in test_pardo_side_inputs
    ('a', 'y'), ('b', 'y'), ('c', 'y')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_inputs_1541700326.0_00e53381-4db3-43fc-90ba-df4ee07745ac failed in state FAILED.

======================================================================
ERROR: test_pardo_side_outputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 131, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_side_outputs_1541700326.36_7337cf6a-7df2-4f62-8988-76d6dc39ae9e failed in state FAILED.

======================================================================
ERROR: test_pardo_state_only (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 280, in test_pardo_state_only
    equal_to(expected))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_state_only_1541700326.79_766ff288-0ee7-4f0a-8c4f-4c42435a44ea failed in state FAILED.

======================================================================
ERROR: test_pardo_unfusable_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 244, in test_pardo_unfusable_side_inputs
    equal_to([('a', 'a'), ('a', 'b'), ('b', 'a'), ('b', 'b')]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_unfusable_side_inputs_1541700327.08_ae870e38-04ca-415d-b379-747200e9cca2 failed in state FAILED.

======================================================================
ERROR: test_pardo_windowed_side_inputs (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 193, in test_pardo_windowed_side_inputs
    label='windowed')
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_pardo_windowed_side_inputs_1541700327.34_93590836-e27b-4bdf-8212-744b0ae0a12f failed in state FAILED.

======================================================================
ERROR: test_read (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",> line 104, in test_read
    assert_that(lines, lambda lines: len(lines) > 0)
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_read_1541700327.69_9c1b0843-8653-48aa-a7b1-d1881fe4d94e failed in state FAILED.

======================================================================
ERROR: test_windowing (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "apache_beam/runners/portability/fn_api_runner_test.py", line 360, in test_windowing
    assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))
  File "apache_beam/pipeline.py", line 425, in __exit__
    self.run().wait_until_finish()
  File "apache_beam/runners/portability/portable_runner.py", line 226, in wait_until_finish
    'Pipeline %s failed in state %s.' % (self._job_id, self._state))
RuntimeError: Pipeline test_windowing_1541700327.95_e438f70e-1db0-4ba6-8015-ee5fa831b7e3 failed in state FAILED.

----------------------------------------------------------------------
Ran 26 tests in 8.895s

FAILED (errors=17, skipped=7)

> Task :beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER FAILED
:beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 10.801 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixBatchDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

2: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_VR_Flink/ws/src/sdks/python/build.gradle'> line: 426

* What went wrong:
Execution failed for task ':beam-sdks-python:flinkCompatibilityMatrixStreamingDOCKER'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 5m 18s
60 actionable tasks: 55 executed, 4 from cache, 1 up-to-date

Publishing build scan...
https://gradle.com/s/5ssjdcw2azxeq

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