You are viewing a plain text version of this content. The canonical link for it is here.
Posted to github@beam.apache.org by "tvalentyn (via GitHub)" <gi...@apache.org> on 2023/04/13 16:40:21 UTC

[GitHub] [beam] tvalentyn commented on issue #26209: [Bug]: cloudpickle appears to incorrectly unpickle cloned combiners

tvalentyn commented on issue #26209:
URL: https://github.com/apache/beam/issues/26209#issuecomment-1507271346

   Test failure looks like the following:
   
   
   ```__________________ LocalCombineFnLifecycleTest_0.test_combine __________________
   ...
   self = <apache_beam.transforms.combinefn_lifecycle_test.LocalCombineFnLifecycleTest_0 testMethod=test_combine>
   
       def test_combine(self):
   >     run_combine(TestPipeline(runner=self.runner()))
   
   apache_beam/transforms/combinefn_lifecycle_test.py:88: 
   _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
   apache_beam/transforms/combinefn_lifecycle_pipeline.py:108: in run_combine
       with pipeline as p:
   apache_beam/pipeline.py:600: in __exit__
       self.result = self.run()
   apache_beam/testing/test_pipeline.py:116: in run
       state = result.wait_until_finish()
   apache_beam/runners/direct/direct_runner.py:588: in wait_until_finish
       self._executor.await_completion()
   apache_beam/runners/direct/executor.py:432: in await_completion
       self._executor.await_completion()
   apache_beam/runners/direct/executor.py:480: in await_completion
       raise update.exception
   apache_beam/runners/direct/executor.py:370: in call
       self.attempt_call(
   apache_beam/runners/direct/executor.py:404: in attempt_call
       evaluator.start_bundle()
   apache_beam/runners/direct/transform_evaluator.py:869: in start_bundle
       self.runner.setup()
   apache_beam/runners/common.py:[147](https://github.com/apache/beam/actions/runs/4613151287/jobs/8154848595?pr=26088#step:6:148)2: in setup
       self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
   apache_beam/runners/common.py:1468: in _invoke_lifecycle_method
       self._reraise_augmented(exn)
   apache_beam/runners/common.py:[150](https://github.com/apache/beam/actions/runs/4613151287/jobs/8154848595?pr=26088#step:6:151)8: in _reraise_augmented
       raise new_exn.with_traceback(tb)
   apache_beam/runners/common.py:1466: in _invoke_lifecycle_method
       lifecycle_method()
   apache_beam/runners/common.py:552: in invoke_setup
       self.signature.setup_lifecycle_method.method_value()
   apache_beam/runners/direct/helper_transforms.py:101: in setup
       self._combine_fn.setup()
   apache_beam/typehints/typecheck.py:205: in setup
       self._combinefn.setup(*args, **kwargs)
   apache_beam/transforms/combiners.py:843: in setup
       self.fn.setup(*self.args, **self.kwargs)
   apache_beam/transforms/combiners.py:665: in setup
       c.setup(*args, **kwargs)
   _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
   
   self = <apache_beam.transforms.combinefn_lifecycle_pipeline.CallSequenceEnforcingCombineFn object at 0x7f3918796750>
   args = (None,), kwargs = {}
   
       def setup(self, *args, **kwargs):
   >     assert not self._setup_called, 'setup should not be called twice'
   E     AssertionError: setup should not be called twice [while running 'Do/CombinePerKey/CombinePerKey(PreCombineFn)/ParDo(FinishCombine)']
   
   ```


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org