You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@beam.apache.org by "Beam JIRA Bot (Jira)" <ji...@apache.org> on 2021/10/15 17:25:04 UTC

[jira] [Updated] (BEAM-8444) Incompatibility between FnApiRunnerSplitTestWithMultiWorkers.test_checkpoint_sdf and beam_fn_api

     [ https://issues.apache.org/jira/browse/BEAM-8444?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ]

Beam JIRA Bot updated BEAM-8444:
--------------------------------
    Labels: stale-assigned  (was: )

> Incompatibility between FnApiRunnerSplitTestWithMultiWorkers.test_checkpoint_sdf and beam_fn_api
> ------------------------------------------------------------------------------------------------
>
>                 Key: BEAM-8444
>                 URL: https://issues.apache.org/jira/browse/BEAM-8444
>             Project: Beam
>          Issue Type: Bug
>          Components: sdk-py-harness
>            Reporter: Robert Bradshaw
>            Assignee: Robert Bradshaw
>            Priority: P3
>              Labels: stale-assigned
>
> {code}
> test_checkpoint_sdf (apache_beam.runners.portability.fn_api_runner_test.FnApiRunnerSplitTestWithMultiWorkers) ... Traceback (most recent call last):
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py", line 170, in _execute
>     response = task()
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py", line 203, in <lambda>
>     self._execute(lambda: worker.do_instruction(work), work)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py", line 360, in do_instruction
>     request.instruction_id)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py", line 386, in process_bundle
>     bundle_processor.process_bundle(instruction_id))
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py", line 663, in process_bundle
>     data.transform_id].process_encoded(data.data)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py", line 143, in process_encoded
>     self.output(decoded_value)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/worker/operations.py", line 256, in output
>     cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/worker/operations.py", line 143, in receive
>     self.consumer.process(windowed_value)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/worker/operations.py", line 594, in process
>     delayed_application = self.dofn_receiver.receive(o)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/common.py", line 776, in receive
>     self.process(windowed_value)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/common.py", line 782, in process
>     self._reraise_augmented(exn)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/common.py", line 780, in process
>     return self.do_fn_invoker.invoke_process(windowed_value)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/common.py", line 588, in invoke_process
>     windowed_value, additional_args, additional_kwargs, output_processor)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/common.py", line 660, in _invoke_process_per_window
>     windowed_value, self.process_method(*args_for_process))
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/common.py", line 919, in process_outputs
>     self.main_receivers.receive(windowed_value)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/worker/operations.py", line 143, in receive
>     self.consumer.process(windowed_value)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/worker/operations.py", line 594, in process
>     delayed_application = self.dofn_receiver.receive(o)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/common.py", line 776, in receive
>     self.process(windowed_value)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/common.py", line 782, in process
>     self._reraise_augmented(exn)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/common.py", line 780, in process
>     return self.do_fn_invoker.invoke_process(windowed_value)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/common.py", line 441, in invoke_process
>     windowed_value, self.process_method(windowed_value.value))
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/common.py", line 919, in process_outputs
>     self.main_receivers.receive(windowed_value)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/worker/operations.py", line 143, in receive
>     self.consumer.process(windowed_value)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/worker/operations.py", line 594, in process
>     delayed_application = self.dofn_receiver.receive(o)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/common.py", line 776, in receive
>     self.process(windowed_value)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/common.py", line 782, in process
>     self._reraise_augmented(exn)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/common.py", line 849, in _reraise_augmented
>     raise_with_traceback(new_exn)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/common.py", line 780, in process
>     return self.do_fn_invoker.invoke_process(windowed_value)
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/common.py", line 441, in invoke_process
>     windowed_value, self.process_method(windowed_value.value))
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/core.py", line 1358, in <lambda>
>     wrapper = lambda x: [fn(x)]
>   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/testing/util.py", line 144, in _equal
>     'Failed assert: %r == %r' % (expected, actual))
> BeamAssertException: Failed assert: [(2, 0), (2, 1), (3, 0), (3, 1), (3, 2)] == [(3, 0), (3, 1), (3, 2), (3, 1), (2, 0), (2, 1), (3, 0), (3, 2)] [while running 'assert_that/Match']
> {code}



--
This message was sent by Atlassian Jira
(v8.3.4#803005)