You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@beam.apache.org by "Kenneth Knowles (Jira)" <ji...@apache.org> on 2019/11/02 20:20:00 UTC

[jira] [Updated] (BEAM-7594) test_read_from_text_with_file_name_file_pattern is flaky

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

Kenneth Knowles updated BEAM-7594:
----------------------------------
    Status: Open  (was: Triage Needed)

> test_read_from_text_with_file_name_file_pattern is flaky
> --------------------------------------------------------
>
>                 Key: BEAM-7594
>                 URL: https://issues.apache.org/jira/browse/BEAM-7594
>             Project: Beam
>          Issue Type: Bug
>          Components: sdk-py-core, test-failures
>            Reporter: Valentyn Tymofieiev
>            Assignee: Lorenzo Caggioni
>            Priority: Major
>              Labels: currently-failing
>             Fix For: Not applicable
>
>
> cc: [~lcaggio] [~chamikara]
> {noformat}
> 22:05:08 ======================================================================
> 22:05:08 ERROR: test_read_from_text_with_file_name_file_pattern (apache_beam.io.textio_test.TextSourceTest)
> 22:05:08 ----------------------------------------------------------------------
> 22:05:08 Traceback (most recent call last):
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/io/textio_test.py", line 517, in test_read_from_text_with_file_name_file_pattern
> 22:05:08     pipeline.run()
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/testing/test_pipeline.py", line 107, in run
> 22:05:08     else test_runner_api))
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/pipeline.py", line 406, in run
> 22:05:08     self._options).run(False)
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/pipeline.py", line 419, in run
> 22:05:08     return self.runner.run_pipeline(self, self._options)
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/runners/direct/direct_runner.py", line 128, in run_pipeline
> 22:05:08     return runner.run_pipeline(pipeline, options)
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner.py", line 294, in run_pipeline
> 22:05:08     default_environment=self._default_environment))
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner.py", line 301, in run_via_runner_api
> 22:05:08     return self.run_stages(stage_context, stages)
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner.py", line 383, in run_stages
> 22:05:08     stage_context.safe_coders)
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner.py", line 655, in _run_stage
> 22:05:08     result, splits = bundle_manager.process_bundle(data_input, data_output)
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner.py", line 1471, in process_bundle
> 22:05:08     result_future = self._controller.control_handler.push(process_bundle_req)
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner.py", line 990, in push
> 22:05:08     response = self.worker.do_instruction(request)
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py", line 342, in do_instruction
> 22:05:08     request.instruction_id)
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py", line 368, in process_bundle
> 22:05:08     bundle_processor.process_bundle(instruction_id))
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py", line 593, in process_bundle
> 22:05:08     data.ptransform_id].process_encoded(data.data)
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py", line 143, in process_encoded
> 22:05:08     self.output(decoded_value)
> 22:05:08   File "apache_beam/runners/worker/operations.py", line 255, in apache_beam.runners.worker.operations.Operation.output
> 22:05:08     def output(self, windowed_value, output_index=0):
> 22:05:08   File "apache_beam/runners/worker/operations.py", line 256, in apache_beam.runners.worker.operations.Operation.output
> 22:05:08     cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
> 22:05:08   File "apache_beam/runners/worker/operations.py", line 143, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
> 22:05:08     self.consumer.process(windowed_value)
> 22:05:08   File "apache_beam/runners/worker/operations.py", line 593, in apache_beam.runners.worker.operations.DoOperation.process
> 22:05:08     with self.scoped_process_state:
> 22:05:08   File "apache_beam/runners/worker/operations.py", line 594, in apache_beam.runners.worker.operations.DoOperation.process
> 22:05:08     delayed_application = self.dofn_receiver.receive(o)
> 22:05:08   File "apache_beam/runners/common.py", line 778, in apache_beam.runners.common.DoFnRunner.receive
> 22:05:08     self.process(windowed_value)
> 22:05:08   File "apache_beam/runners/common.py", line 784, in apache_beam.runners.common.DoFnRunner.process
> 22:05:08     self._reraise_augmented(exn)
> 22:05:08   File "apache_beam/runners/common.py", line 836, in apache_beam.runners.common.DoFnRunner._reraise_augmented
> 22:05:08     raise
> 22:05:08   File "apache_beam/runners/common.py", line 782, in apache_beam.runners.common.DoFnRunner.process
> 22:05:08     return self.do_fn_invoker.invoke_process(windowed_value)
> 22:05:08   File "apache_beam/runners/common.py", line 594, in apache_beam.runners.common.PerWindowInvoker.invoke_process
> 22:05:08     self._invoke_process_per_window(
> 22:05:08   File "apache_beam/runners/common.py", line 665, in apache_beam.runners.common.PerWindowInvoker._invoke_process_per_window
> 22:05:08     output_processor.process_outputs(
> 22:05:08   File "apache_beam/runners/common.py", line 882, in apache_beam.runners.common._OutputProcessor.process_outputs
> 22:05:08     def process_outputs(self, windowed_input_element, results):
> 22:05:08   File "apache_beam/runners/common.py", line 921, in apache_beam.runners.common._OutputProcessor.process_outputs
> 22:05:08     self.main_receivers.receive(windowed_value)
> 22:05:08   File "apache_beam/runners/worker/operations.py", line 143, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
> 22:05:08     self.consumer.process(windowed_value)
> 22:05:08   File "apache_beam/runners/worker/operations.py", line 593, in apache_beam.runners.worker.operations.DoOperation.process
> 22:05:08     with self.scoped_process_state:
> 22:05:08   File "apache_beam/runners/worker/operations.py", line 594, in apache_beam.runners.worker.operations.DoOperation.process
> 22:05:08     delayed_application = self.dofn_receiver.receive(o)
> 22:05:08   File "apache_beam/runners/common.py", line 778, in apache_beam.runners.common.DoFnRunner.receive
> 22:05:08     self.process(windowed_value)
> 22:05:08   File "apache_beam/runners/common.py", line 784, in apache_beam.runners.common.DoFnRunner.process
> 22:05:08     self._reraise_augmented(exn)
> 22:05:08   File "apache_beam/runners/common.py", line 836, in apache_beam.runners.common.DoFnRunner._reraise_augmented
> 22:05:08     raise
> 22:05:08   File "apache_beam/runners/common.py", line 782, in apache_beam.runners.common.DoFnRunner.process
> 22:05:08     return self.do_fn_invoker.invoke_process(windowed_value)
> 22:05:08   File "apache_beam/runners/common.py", line 453, in apache_beam.runners.common.SimpleInvoker.invoke_process
> 22:05:08     output_processor.process_outputs(
> 22:05:08   File "apache_beam/runners/common.py", line 921, in apache_beam.runners.common._OutputProcessor.process_outputs
> 22:05:08     self.main_receivers.receive(windowed_value)
> 22:05:08   File "apache_beam/runners/worker/operations.py", line 143, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
> 22:05:08     self.consumer.process(windowed_value)
> 22:05:08   File "apache_beam/runners/worker/operations.py", line 593, in apache_beam.runners.worker.operations.DoOperation.process
> 22:05:08     with self.scoped_process_state:
> 22:05:08   File "apache_beam/runners/worker/operations.py", line 594, in apache_beam.runners.worker.operations.DoOperation.process
> 22:05:08     delayed_application = self.dofn_receiver.receive(o)
> 22:05:08   File "apache_beam/runners/common.py", line 778, in apache_beam.runners.common.DoFnRunner.receive
> 22:05:08     self.process(windowed_value)
> 22:05:08   File "apache_beam/runners/common.py", line 784, in apache_beam.runners.common.DoFnRunner.process
> 22:05:08     self._reraise_augmented(exn)
> 22:05:08   File "apache_beam/runners/common.py", line 851, in apache_beam.runners.common.DoFnRunner._reraise_augmented
> 22:05:08     raise_with_traceback(new_exn)
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/target/.tox-py37-cython/py37-cython/lib/python3.7/site-packages/future/utils/__init__.py", line 419, in raise_with_traceback
> 22:05:08     raise exc.with_traceback(traceback)
> 22:05:08   File "apache_beam/runners/common.py", line 782, in apache_beam.runners.common.DoFnRunner.process
> 22:05:08     return self.do_fn_invoker.invoke_process(windowed_value)
> 22:05:08   File "apache_beam/runners/common.py", line 454, in apache_beam.runners.common.SimpleInvoker.invoke_process
> 22:05:08     windowed_value, self.process_method(windowed_value.value))
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/transforms/core.py", line 1293, in <lambda>
> 22:05:08     wrapper = lambda x: [fn(x)]
> 22:05:08   File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Phrase/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/testing/util.py", line 130, in _equal
> 22:05:08     'Failed assert: %r == %r' % (sorted_expected, sorted_actual))
> 22:05:08 apache_beam.testing.util.BeamAssertException: Failed assert: [('/tmp/201906190459575wsvf9fb', 'line0'), ('/tmp/201906190459575wsvf9fb', 'line1'), ('/tmp/201906190459575wsvf9fb', 'line2'), ('/tmp/201906190459575wsvf9fb', 'line3'), ('/tmp/201906190459575wsvf9fb', 'line4'), ('/tmp/20190619045957b06j5eks', 'line0'), ('/tmp/20190619045957b06j5eks', 'line1'), ('/tmp/20190619045957b06j5eks', 'line2'), ('/tmp/20190619045957b06j5eks', 'line3'), ('/tmp/20190619045957b06j5eks', 'line4')] == [('/tmp/201906190459570_h6i4fs', 'line0'), ('/tmp/201906190459570_h6i4fs', 'line1'), ('/tmp/201906190459570_h6i4fs', 'line2'), ('/tmp/201906190459570_h6i4fs', 'line3'), ('/tmp/201906190459570_h6i4fs', 'line4'), ('/tmp/201906190459575wsvf9fb', 'line0'), ('/tmp/201906190459575wsvf9fb', 'line1'), ('/tmp/201906190459575wsvf9fb', 'line2'), ('/tmp/201906190459575wsvf9fb', 'line3'), ('/tmp/201906190459575wsvf9fb', 'line4'), ('/tmp/20190619045957b06j5eks', 'line0'), ('/tmp/20190619045957b06j5eks', 'line1'), ('/tmp/20190619045957b06j5eks', 'line2'), ('/tmp/20190619045957b06j5eks', 'line3'), ('/tmp/20190619045957b06j5eks', 'line4'), ('/tmp/20190619045957bde47oq8', 'line0'), ('/tmp/20190619045957bde47oq8', 'line1'), ('/tmp/20190619045957bde47oq8', 'line2'), ('/tmp/20190619045957bde47oq8', 'line3'), ('/tmp/20190619045957bde47oq8', 'line4')] [while running 'assert_that/Match']
> {noformat}



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