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/09 13:11:23 UTC

Build failed in Jenkins: beam_PostCommit_Python_VR_Flink #691

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


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