Enable prism by default (where supported) #26666
21 fail, 46 skipped, 190 pass in 6m 21s
Annotations
Check warning on line 0 in apache_beam.examples.snippets.snippets_test.SnippetsTest
github-actions / Test Results
All 2 runs failed: test_model_co_group_by_key_tuple (apache_beam.examples.snippets.snippets_test.SnippetsTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 9s]
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 4s]
Raw output
AssertionError: Lists differ: ["amy[54 chars]]", "carl; ['[email protected]', '[email protected][85 chars] []"] != ["amy[54 chars]]", "amy; ['[email protected]']; ['111-222-3333'[280 chars] []"]
First differing element 1:
"carl; ['[email protected]', '[email protected]']; ['444-555-6666']"
"amy; ['[email protected]']; ['111-222-3333', '333-444-5555']"
Second list contains 4 additional elements.
First extra element 4:
"james; []; ['222-333-4444']"
["amy; ['[email protected]']; ['111-222-3333', '333-444-5555']",
+ "amy; ['[email protected]']; ['111-222-3333', '333-444-5555']",
+ "carl; ['[email protected]', '[email protected]']; ['444-555-6666']",
"carl; ['[email protected]', '[email protected]']; ['444-555-6666']",
"james; []; ['222-333-4444']",
+ "james; []; ['222-333-4444']",
+ "julia; ['[email protected]']; []",
"julia; ['[email protected]']; []"]
self = <apache_beam.examples.snippets.snippets_test.SnippetsTest testMethod=test_model_co_group_by_key_tuple>
def test_model_co_group_by_key_tuple(self):
with TestPipeline() as p:
# [START model_group_by_key_cogroupbykey_tuple_inputs]
emails_list = [
('amy', '[email protected]'),
('carl', '[email protected]'),
('julia', '[email protected]'),
('carl', '[email protected]'),
]
phones_list = [
('amy', '111-222-3333'),
('james', '222-333-4444'),
('amy', '333-444-5555'),
('carl', '444-555-6666'),
]
emails = p | 'CreateEmails' >> beam.Create(emails_list)
phones = p | 'CreatePhones' >> beam.Create(phones_list)
# [END model_group_by_key_cogroupbykey_tuple_inputs]
result_path = self.create_temp_file()
snippets.model_co_group_by_key_tuple(emails, phones, result_path)
# [START model_group_by_key_cogroupbykey_tuple_outputs]
results = [
(
'amy',
{
'emails': ['[email protected]'],
'phones': ['111-222-3333', '333-444-5555']
}),
(
'carl',
{
'emails': ['[email protected]', '[email protected]'],
'phones': ['444-555-6666']
}),
('james', {
'emails': [], 'phones': ['222-333-4444']
}),
('julia', {
'emails': ['[email protected]'], 'phones': []
}),
]
# [END model_group_by_key_cogroupbykey_tuple_outputs]
# [START model_group_by_key_cogroupbykey_tuple_formatted_outputs]
formatted_results = [
"amy; ['[email protected]']; ['111-222-3333', '333-444-5555']",
"carl; ['[email protected]', '[email protected]']; ['444-555-6666']",
"james; []; ['222-333-4444']",
"julia; ['[email protected]']; []",
]
# [END model_group_by_key_cogroupbykey_tuple_formatted_outputs]
expected_results = [
'%s; %s; %s' % (name, info['emails'], info['phones']) for name,
info in results
]
self.assertEqual(expected_results, formatted_results)
> self.assertEqual(formatted_results, self.get_output(result_path))
E AssertionError: Lists differ: ["amy[54 chars]]", "carl; ['[email protected]', '[email protected][85 chars] []"] != ["amy[54 chars]]", "amy; ['[email protected]']; ['111-222-3333'[280 chars] []"]
E
E First differing element 1:
E "carl; ['[email protected]', '[email protected]']; ['444-555-6666']"
E "amy; ['[email protected]']; ['111-222-3333', '333-444-5555']"
E
E Second list contains 4 additional elements.
E First extra element 4:
E "james; []; ['222-333-4444']"
E
E ["amy; ['[email protected]']; ['111-222-3333', '333-444-5555']",
E + "amy; ['[email protected]']; ['111-222-3333', '333-444-5555']",
E + "carl; ['[email protected]', '[email protected]']; ['444-555-6666']",
E "carl; ['[email protected]', '[email protected]']; ['444-555-6666']",
E "james; []; ['222-333-4444']",
E + "james; []; ['222-333-4444']",
E + "julia; ['[email protected]']; []",
E "julia; ['[email protected]']; []"]
apache_beam/examples/snippets/snippets_test.py:1005: AssertionError
Check warning on line 0 in apache_beam.examples.snippets.snippets_test.SnippetsTest
github-actions / Test Results
All 2 runs failed: test_model_composite_transform_example (apache_beam.examples.snippets.snippets_test.SnippetsTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 6s]
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 3s]
Raw output
AssertionError: Lists differ: ['aa: 1', 'bb: 2', 'cc: 3'] != ['aa: 1', 'aa: 1', 'bb: 2', 'bb: 2', 'cc: 3', 'cc: 3']
First differing element 1:
'bb: 2'
'aa: 1'
Second list contains 3 additional elements.
First extra element 3:
'bb: 2'
- ['aa: 1', 'bb: 2', 'cc: 3']
+ ['aa: 1', 'aa: 1', 'bb: 2', 'bb: 2', 'cc: 3', 'cc: 3']
self = <apache_beam.examples.snippets.snippets_test.SnippetsTest testMethod=test_model_composite_transform_example>
def test_model_composite_transform_example(self):
contents = ['aa bb cc', 'bb cc', 'cc']
result_path = self.create_temp_file()
snippets.model_composite_transform_example(contents, result_path)
> self.assertEqual(['aa: 1', 'bb: 2', 'cc: 3'], self.get_output(result_path))
E AssertionError: Lists differ: ['aa: 1', 'bb: 2', 'cc: 3'] != ['aa: 1', 'aa: 1', 'bb: 2', 'bb: 2', 'cc: 3', 'cc: 3']
E
E First differing element 1:
E 'bb: 2'
E 'aa: 1'
E
E Second list contains 3 additional elements.
E First extra element 3:
E 'bb: 2'
E
E - ['aa: 1', 'bb: 2', 'cc: 3']
E + ['aa: 1', 'aa: 1', 'bb: 2', 'bb: 2', 'cc: 3', 'cc: 3']
apache_beam/examples/snippets/snippets_test.py:912: AssertionError
Check warning on line 0 in apache_beam.examples.snippets.snippets_test.SnippetsTest
github-actions / Test Results
All 2 runs failed: test_examples_ptransforms_templated (apache_beam.examples.snippets.snippets_test.SnippetsTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 7s]
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 3s]
Raw output
AssertionError: Lists differ: ['11', '11', '12', '12', '13', '13'] != ['11', '12', '13']
First differing element 1:
'11'
'12'
First list contains 3 additional elements.
First extra element 3:
'12'
- ['11', '11', '12', '12', '13', '13']
+ ['11', '12', '13']
self = <apache_beam.examples.snippets.snippets_test.SnippetsTest testMethod=test_examples_ptransforms_templated>
def test_examples_ptransforms_templated(self):
pipelines = [snippets.examples_ptransforms_templated]
for pipeline in pipelines:
temp_path = self.create_temp_file('1\n 2\n 3')
result_path = self.create_temp_file()
pipeline({'read': temp_path, 'write': result_path})
> self.assertEqual(self.get_output(result_path), ['11', '12', '13'])
E AssertionError: Lists differ: ['11', '11', '12', '12', '13', '13'] != ['11', '12', '13']
E
E First differing element 1:
E '11'
E '12'
E
E First list contains 3 additional elements.
E First extra element 3:
E '12'
E
E - ['11', '11', '12', '12', '13', '13']
E + ['11', '12', '13']
apache_beam/examples/snippets/snippets_test.py:828: AssertionError
Check warning on line 0 in apache_beam.examples.snippets.snippets_test.SnippetsTest
github-actions / Test Results
1 out of 2 runs failed: test_model_custom_sink (apache_beam.examples.snippets.snippets_test.SnippetsTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 9s]
Raw output
AssertionError: assert not True
+ where True = <function exists at 0x7ffa9c482320>('/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-cloud/py310-cloud/tmp/tmpgrrfa146/final_table_no_ptransform0')
+ where <function exists at 0x7ffa9c482320> = <module 'posixpath' from '/opt/hostedtoolcache/Python/3.10.17/x64/lib/python3.10/posixpath.py'>.exists
+ where <module 'posixpath' from '/opt/hostedtoolcache/Python/3.10.17/x64/lib/python3.10/posixpath.py'> = os.path [while running 'WriteToSimpleKV/WriteImpl/FinalizeWrite']
self = <apache_beam.examples.snippets.snippets_test.SimpleKV object at 0x7ffa5433a890>
access_token = 'dummy_token'
old_name = 'tablef5edddd4-76d6-490c-93a9-2c7b2a8e61f7'
new_name = 'final_table_no_ptransform0'
def rename_table(self, access_token, old_name, new_name):
assert access_token == self._dummy_token
old_file_name = self._tmp_dir + os.sep + old_name
new_file_name = self._tmp_dir + os.sep + new_name
assert os.path.isfile(old_file_name)
> assert not os.path.exists(new_file_name)
E AssertionError: assert not True
E + where True = <function exists at 0x7ffa9c482320>('/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-cloud/py310-cloud/tmp/tmpgrrfa146/final_table_no_ptransform0')
E + where <function exists at 0x7ffa9c482320> = <module 'posixpath' from '/opt/hostedtoolcache/Python/3.10.17/x64/lib/python3.10/posixpath.py'>.exists
E + where <module 'posixpath' from '/opt/hostedtoolcache/Python/3.10.17/x64/lib/python3.10/posixpath.py'> = os.path
apache_beam/examples/snippets/snippets_test.py:673: AssertionError
During handling of the above exception, another exception occurred:
self = <apache_beam.examples.snippets.snippets_test.SnippetsTest testMethod=test_model_custom_sink>
def test_model_custom_sink(self):
tempdir_name = tempfile.mkdtemp()
class SimpleKV(object):
def __init__(self, tmp_dir):
self._dummy_token = 'dummy_token'
self._tmp_dir = tmp_dir
def connect(self, url):
return self._dummy_token
def open_table(self, access_token, table_name):
assert access_token == self._dummy_token
file_name = self._tmp_dir + os.sep + table_name
assert not os.path.exists(file_name)
open(file_name, 'wb').close()
return table_name
def write_to_table(self, access_token, table_name, key, value):
assert access_token == self._dummy_token
file_name = self._tmp_dir + os.sep + table_name
assert os.path.exists(file_name)
with open(file_name, 'ab') as f:
content = (key + ':' + value + os.linesep).encode('utf-8')
f.write(content)
def rename_table(self, access_token, old_name, new_name):
assert access_token == self._dummy_token
old_file_name = self._tmp_dir + os.sep + old_name
new_file_name = self._tmp_dir + os.sep + new_name
assert os.path.isfile(old_file_name)
assert not os.path.exists(new_file_name)
os.rename(old_file_name, new_file_name)
> snippets.model_custom_sink(
SimpleKV(tempdir_name),
[('key' + str(i), 'value' + str(i)) for i in range(100)],
'final_table_no_ptransform',
'final_table_with_ptransform')
apache_beam/examples/snippets/snippets_test.py:677:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/examples/snippets/snippets.py:794: in model_custom_sink
with beam.Pipeline(options=PipelineOptions()) as pipeline:
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/pipeline.py:644: in __exit__
self.result = self.run()
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/pipeline.py:618: in run
return self.runner.run_pipeline(self, self._options)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/direct/direct_runner.py:190: in run_pipeline
return runner.run_pipeline(pipeline, options)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:196: in run_pipeline
self._latest_run_result = self.run_via_runner_api(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:223: in run_via_runner_api
return self.run_stages(stage_context, stages)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:470: in run_stages
bundle_results = self._execute_bundle(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:795: in _execute_bundle
self._run_bundle(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:1034: in _run_bundle
result, splits = bundle_manager.process_bundle(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:1360: in process_bundle
result_future = self._worker_handler.control_conn.push(process_bundle_req)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/worker_handlers.py:386: in push
response = self.worker.do_instruction(request)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py:658: in do_instruction
return getattr(self, request_type)(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py:696: in process_bundle
bundle_processor.process_bundle(instruction_id))
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py:1274: in process_bundle
input_op_by_transform_id[element.transform_id].process_encoded(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py:237: in process_encoded
self.output(decoded_value)
apache_beam/runners/worker/operations.py:566: in apache_beam.runners.worker.operations.Operation.output
def output(self, windowed_value, output_index=0):
apache_beam/runners/worker/operations.py:568: in apache_beam.runners.worker.operations.Operation.output
_cast_to_receiver(self.receivers[output_index]).receive(windowed_value)
apache_beam/runners/worker/operations.py:259: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
def receive(self, windowed_value):
apache_beam/runners/worker/operations.py:262: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
self.consumer.process(windowed_value)
apache_beam/runners/worker/operations.py:949: in apache_beam.runners.worker.operations.DoOperation.process
with self.scoped_process_state:
apache_beam/runners/worker/operations.py:950: in apache_beam.runners.worker.operations.DoOperation.process
delayed_applications = self.dofn_runner.process(o)
apache_beam/runners/common.py:1497: in apache_beam.runners.common.DoFnRunner.process
self._reraise_augmented(exn, windowed_value)
apache_beam/runners/common.py:1606: in apache_beam.runners.common.DoFnRunner._reraise_augmented
raise new_exn
apache_beam/runners/common.py:1495: in apache_beam.runners.common.DoFnRunner.process
return self.do_fn_invoker.invoke_process(windowed_value)
apache_beam/runners/common.py:911: in apache_beam.runners.common.PerWindowInvoker.invoke_process
self._invoke_process_per_window(
apache_beam/runners/common.py:1055: in apache_beam.runners.common.PerWindowInvoker._invoke_process_per_window
self.process_method(*args_for_process, **kwargs_for_process),
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/io/iobase.py:1237: in _finalize_write
outputs = sink.finalize_write(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/examples/snippets/snippets.py:703: in finalize_write
self._simplekv.rename_table(
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
self = <apache_beam.examples.snippets.snippets_test.SimpleKV object at 0x7ffa5433a890>
access_token = 'dummy_token'
old_name = 'tablef5edddd4-76d6-490c-93a9-2c7b2a8e61f7'
new_name = 'final_table_no_ptransform0'
def rename_table(self, access_token, old_name, new_name):
assert access_token == self._dummy_token
old_file_name = self._tmp_dir + os.sep + old_name
new_file_name = self._tmp_dir + os.sep + new_name
assert os.path.isfile(old_file_name)
> assert not os.path.exists(new_file_name)
E AssertionError: assert not True
E + where True = <function exists at 0x7ffa9c482320>('/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-cloud/py310-cloud/tmp/tmpgrrfa146/final_table_no_ptransform0')
E + where <function exists at 0x7ffa9c482320> = <module 'posixpath' from '/opt/hostedtoolcache/Python/3.10.17/x64/lib/python3.10/posixpath.py'>.exists
E + where <module 'posixpath' from '/opt/hostedtoolcache/Python/3.10.17/x64/lib/python3.10/posixpath.py'> = os.path [while running 'WriteToSimpleKV/WriteImpl/FinalizeWrite']
apache_beam/examples/snippets/snippets_test.py:673: AssertionError
Check warning on line 0 in apache_beam.examples.snippets.snippets_test.SnippetsTest
github-actions / Test Results
All 2 runs failed: test_examples_wordcount_0 (apache_beam.examples.snippets.snippets_test.SnippetsTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 5s]
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 4s]
Raw output
AssertionError: Lists differ: ['abc: 2', 'abc: 2', 'def: 1', 'def: 1', 'ghi: 1', 'ghi: 1', 'jkl: 1', 'jkl: 1'] != ['abc: 2', 'def: 1', 'ghi: 1', 'jkl: 1']
First differing element 1:
'abc: 2'
'def: 1'
First list contains 4 additional elements.
First extra element 4:
'ghi: 1'
- ['abc: 2', 'abc: 2', 'def: 1', 'def: 1', 'ghi: 1', 'ghi: 1', 'jkl: 1', 'jkl: 1']
+ ['abc: 2', 'def: 1', 'ghi: 1', 'jkl: 1']
a = (<apache_beam.examples.snippets.snippets_test.SnippetsTest testMethod=test_examples_wordcount_0>,)
kw = {}
@wraps(func)
def standalone_func(*a, **kw):
> return func(*(a + p.args), **p.kwargs, **kw)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/parameterized/parameterized.py:620:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
apache_beam/examples/snippets/snippets_test.py:818: in test_examples_wordcount
self.assertEqual(
E AssertionError: Lists differ: ['abc: 2', 'abc: 2', 'def: 1', 'def: 1', 'ghi: 1', 'ghi: 1', 'jkl: 1', 'jkl: 1'] != ['abc: 2', 'def: 1', 'ghi: 1', 'jkl: 1']
E
E First differing element 1:
E 'abc: 2'
E 'def: 1'
E
E First list contains 4 additional elements.
E First extra element 4:
E 'ghi: 1'
E
E - ['abc: 2', 'abc: 2', 'def: 1', 'def: 1', 'ghi: 1', 'ghi: 1', 'jkl: 1', 'jkl: 1']
E + ['abc: 2', 'def: 1', 'ghi: 1', 'jkl: 1']
Check warning on line 0 in apache_beam.examples.snippets.snippets_test.SnippetsTest
github-actions / Test Results
1 out of 2 runs failed: test_examples_wordcount_1 (apache_beam.examples.snippets.snippets_test.SnippetsTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 5s]
Raw output
AssertionError: Lists differ: ['abc: 2', 'abc: 2', 'def: 1', 'def: 1', 'ghi: 1', 'ghi: 1', 'jkl: 1', 'jkl: 1'] != ['abc: 2', 'def: 1', 'ghi: 1', 'jkl: 1']
First differing element 1:
'abc: 2'
'def: 1'
First list contains 4 additional elements.
First extra element 4:
'ghi: 1'
- ['abc: 2', 'abc: 2', 'def: 1', 'def: 1', 'ghi: 1', 'ghi: 1', 'jkl: 1', 'jkl: 1']
+ ['abc: 2', 'def: 1', 'ghi: 1', 'jkl: 1']
a = (<apache_beam.examples.snippets.snippets_test.SnippetsTest testMethod=test_examples_wordcount_1>,)
kw = {}
@wraps(func)
def standalone_func(*a, **kw):
> return func(*(a + p.args), **p.kwargs, **kw)
target/.tox-py310/py310/lib/python3.10/site-packages/parameterized/parameterized.py:620:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
apache_beam/examples/snippets/snippets_test.py:818: in test_examples_wordcount
self.assertEqual(
E AssertionError: Lists differ: ['abc: 2', 'abc: 2', 'def: 1', 'def: 1', 'ghi: 1', 'ghi: 1', 'jkl: 1', 'jkl: 1'] != ['abc: 2', 'def: 1', 'ghi: 1', 'jkl: 1']
E
E First differing element 1:
E 'abc: 2'
E 'def: 1'
E
E First list contains 4 additional elements.
E First extra element 4:
E 'ghi: 1'
E
E - ['abc: 2', 'abc: 2', 'def: 1', 'def: 1', 'ghi: 1', 'ghi: 1', 'jkl: 1', 'jkl: 1']
E + ['abc: 2', 'def: 1', 'ghi: 1', 'jkl: 1']
Check warning on line 0 in apache_beam.examples.snippets.snippets_test.SnippetsTest
github-actions / Test Results
All 2 runs failed: test_model_join_using_side_inputs (apache_beam.examples.snippets.snippets_test.SnippetsTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 5s]
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 5s]
Raw output
AssertionError: Lists differ: ['a; [19 chars]2', 'b; [email protected]; x8452'] != ['a; [19 chars]2', 'a; [email protected]; x4312', 'b; [email protected][33 chars]452']
First differing element 1:
'b; [email protected]; x8452'
'a; [email protected]; x4312'
Second list contains 2 additional elements.
First extra element 2:
'b; [email protected]; x8452'
- ['a; [email protected]; x4312', 'b; [email protected]; x8452']
+ ['a; [email protected]; x4312',
+ 'a; [email protected]; x4312',
+ 'b; [email protected]; x8452',
+ 'b; [email protected]; x8452']
self = <apache_beam.examples.snippets.snippets_test.SnippetsTest testMethod=test_model_join_using_side_inputs>
def test_model_join_using_side_inputs(self):
name_list = ['a', 'b']
email_list = [['a', '[email protected]'], ['b', '[email protected]']]
phone_list = [['a', 'x4312'], ['b', 'x8452']]
result_path = self.create_temp_file()
snippets.model_join_using_side_inputs(
name_list, email_list, phone_list, result_path)
expect = ['a; [email protected]; x4312', 'b; [email protected]; x8452']
> self.assertEqual(expect, self.get_output(result_path))
E AssertionError: Lists differ: ['a; [19 chars]2', 'b; [email protected]; x8452'] != ['a; [19 chars]2', 'a; [email protected]; x4312', 'b; [email protected][33 chars]452']
E
E First differing element 1:
E 'b; [email protected]; x8452'
E 'a; [email protected]; x4312'
E
E Second list contains 2 additional elements.
E First extra element 2:
E 'b; [email protected]; x8452'
E
E - ['a; [email protected]; x4312', 'b; [email protected]; x8452']
E + ['a; [email protected]; x4312',
E + 'a; [email protected]; x4312',
E + 'b; [email protected]; x8452',
E + 'b; [email protected]; x8452']
apache_beam/examples/snippets/snippets_test.py:1075: AssertionError
Check warning on line 0 in apache_beam.examples.snippets.snippets_test.CombineTest
github-actions / Test Results
1 out of 2 runs failed: test_bounded_sum (apache_beam.examples.snippets.snippets_test.CombineTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 7s]
Raw output
AssertionError: Lists differ: [1111] != [1111, 1111]
Second list contains 1 additional elements.
First extra element 1:
1111
- [1111]
+ [1111, 1111]
self = <apache_beam.examples.snippets.snippets_test.CombineTest testMethod=test_bounded_sum>
def test_bounded_sum(self):
# [START combine_bounded_sum]
pc = [1, 10, 100, 1000]
def bounded_sum(values, bound=500):
return min(sum(values), bound)
small_sum = pc | beam.CombineGlobally(bounded_sum) # [500]
large_sum = pc | beam.CombineGlobally(bounded_sum, bound=5000) # [1111]
# [END combine_bounded_sum]
self.assertEqual([500], small_sum)
> self.assertEqual([1111], large_sum)
E AssertionError: Lists differ: [1111] != [1111, 1111]
E
E Second list contains 1 additional elements.
E First extra element 1:
E 1111
E
E - [1111]
E + [1111, 1111]
apache_beam/examples/snippets/snippets_test.py:1245: AssertionError
Check warning on line 0 in apache_beam.examples.snippets.snippets_test.SnippetsTest
github-actions / Test Results
All 2 runs failed: test_examples_wordcount_2 (apache_beam.examples.snippets.snippets_test.SnippetsTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 3s]
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 4s]
Raw output
AssertionError: Lists differ: ['abc: 2', 'abc: 2', 'def: 1', 'def: 1', 'ghi: 1', 'ghi: 1', 'jkl: 1', 'jkl: 1'] != ['abc: 2', 'def: 1', 'ghi: 1', 'jkl: 1']
First differing element 1:
'abc: 2'
'def: 1'
First list contains 4 additional elements.
First extra element 4:
'ghi: 1'
- ['abc: 2', 'abc: 2', 'def: 1', 'def: 1', 'ghi: 1', 'ghi: 1', 'jkl: 1', 'jkl: 1']
+ ['abc: 2', 'def: 1', 'ghi: 1', 'jkl: 1']
a = (<apache_beam.examples.snippets.snippets_test.SnippetsTest testMethod=test_examples_wordcount_2>,)
kw = {}
@wraps(func)
def standalone_func(*a, **kw):
> return func(*(a + p.args), **p.kwargs, **kw)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/parameterized/parameterized.py:620:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
apache_beam/examples/snippets/snippets_test.py:818: in test_examples_wordcount
self.assertEqual(
E AssertionError: Lists differ: ['abc: 2', 'abc: 2', 'def: 1', 'def: 1', 'ghi: 1', 'ghi: 1', 'jkl: 1', 'jkl: 1'] != ['abc: 2', 'def: 1', 'ghi: 1', 'jkl: 1']
E
E First differing element 1:
E 'abc: 2'
E 'def: 1'
E
E First list contains 4 additional elements.
E First extra element 4:
E 'ghi: 1'
E
E - ['abc: 2', 'abc: 2', 'def: 1', 'def: 1', 'ghi: 1', 'ghi: 1', 'jkl: 1', 'jkl: 1']
E + ['abc: 2', 'def: 1', 'ghi: 1', 'jkl: 1']
Check warning on line 0 in apache_beam.examples.snippets.snippets_test.SnippetsTest
github-actions / Test Results
1 out of 2 runs failed: test_model_multiple_pcollections_flatten (apache_beam.examples.snippets.snippets_test.SnippetsTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 3s]
Raw output
AssertionError: Lists differ: ['a', 'b', 'c', 'd', 'e', 'f'] != ['a', 'a', 'b', 'b', 'c', 'c', 'd', 'd', 'e', 'e', 'f', 'f']
First differing element 1:
'b'
'a'
Second list contains 6 additional elements.
First extra element 6:
'd'
- ['a', 'b', 'c', 'd', 'e', 'f']
+ ['a', 'a', 'b', 'b', 'c', 'c', 'd', 'd', 'e', 'e', 'f', 'f']
self = <apache_beam.examples.snippets.snippets_test.SnippetsTest testMethod=test_model_multiple_pcollections_flatten>
def test_model_multiple_pcollections_flatten(self):
contents = ['a', 'b', 'c', 'd', 'e', 'f']
result_path = self.create_temp_file()
snippets.model_multiple_pcollections_flatten(contents, result_path)
> self.assertEqual(contents, self.get_output(result_path))
E AssertionError: Lists differ: ['a', 'b', 'c', 'd', 'e', 'f'] != ['a', 'a', 'b', 'b', 'c', 'c', 'd', 'd', 'e', 'e', 'f', 'f']
E
E First differing element 1:
E 'b'
E 'a'
E
E Second list contains 6 additional elements.
E First extra element 6:
E 'd'
E
E - ['a', 'b', 'c', 'd', 'e', 'f']
E + ['a', 'a', 'b', 'b', 'c', 'c', 'd', 'd', 'e', 'e', 'f', 'f']
apache_beam/examples/snippets/snippets_test.py:918: AssertionError
Check warning on line 0 in apache_beam.examples.snippets.snippets_test.SnippetsTest
github-actions / Test Results
All 2 runs failed: test_model_multiple_pcollections_flatten_with (apache_beam.examples.snippets.snippets_test.SnippetsTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 3s]
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 4s]
Raw output
AssertionError: Lists differ: ['a', 'b', 'c', 'd', 'e', 'f'] != ['a', 'a', 'b', 'b', 'c', 'c', 'd', 'd', 'e', 'e', 'f', 'f']
First differing element 1:
'b'
'a'
Second list contains 6 additional elements.
First extra element 6:
'd'
- ['a', 'b', 'c', 'd', 'e', 'f']
+ ['a', 'a', 'b', 'b', 'c', 'c', 'd', 'd', 'e', 'e', 'f', 'f']
self = <apache_beam.examples.snippets.snippets_test.SnippetsTest testMethod=test_model_multiple_pcollections_flatten_with>
def test_model_multiple_pcollections_flatten_with(self):
contents = ['a', 'b', 'c', 'd', 'e', 'f']
result_path = self.create_temp_file()
snippets.model_multiple_pcollections_flatten_with(contents, result_path)
> self.assertEqual(contents, self.get_output(result_path))
E AssertionError: Lists differ: ['a', 'b', 'c', 'd', 'e', 'f'] != ['a', 'a', 'b', 'b', 'c', 'c', 'd', 'd', 'e', 'e', 'f', 'f']
E
E First differing element 1:
E 'b'
E 'a'
E
E Second list contains 6 additional elements.
E First extra element 6:
E 'd'
E
E - ['a', 'b', 'c', 'd', 'e', 'f']
E + ['a', 'a', 'b', 'b', 'c', 'c', 'd', 'd', 'e', 'e', 'f', 'f']
apache_beam/examples/snippets/snippets_test.py:924: AssertionError
Check warning on line 0 in apache_beam.examples.snippets.snippets_test.SnippetsTest
github-actions / Test Results
All 2 runs failed: test_examples_wordcount_debugging (apache_beam.examples.snippets.snippets_test.SnippetsTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 4s]
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 4s]
Raw output
AssertionError: Lists differ: ['Flourish: 3', 'Flourish: 3', 'stomach: 1', 'stomach: 1'] != ['Flourish: 3', 'stomach: 1']
First differing element 1:
'Flourish: 3'
'stomach: 1'
First list contains 2 additional elements.
First extra element 2:
'stomach: 1'
- ['Flourish: 3', 'Flourish: 3', 'stomach: 1', 'stomach: 1']
+ ['Flourish: 3', 'stomach: 1']
self = <apache_beam.examples.snippets.snippets_test.SnippetsTest testMethod=test_examples_wordcount_debugging>
def test_examples_wordcount_debugging(self):
temp_path = self.create_temp_file(
'Flourish Flourish Flourish stomach abc def')
result_path = self.create_temp_file()
snippets_examples_wordcount_debugging.examples_wordcount_debugging({
'read': temp_path, 'write': result_path
})
> self.assertEqual(
self.get_output(result_path), ['Flourish: 3', 'stomach: 1'])
E AssertionError: Lists differ: ['Flourish: 3', 'Flourish: 3', 'stomach: 1', 'stomach: 1'] != ['Flourish: 3', 'stomach: 1']
E
E First differing element 1:
E 'Flourish: 3'
E 'stomach: 1'
E
E First list contains 2 additional elements.
E First extra element 2:
E 'stomach: 1'
E
E - ['Flourish: 3', 'Flourish: 3', 'stomach: 1', 'stomach: 1']
E + ['Flourish: 3', 'stomach: 1']
apache_beam/examples/snippets/snippets_test.py:837: AssertionError
Check warning on line 0 in apache_beam.examples.snippets.snippets_test.SnippetsTest
github-actions / Test Results
All 2 runs failed: test_model_multiple_pcollections_flatten_with_transform (apache_beam.examples.snippets.snippets_test.SnippetsTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 4s]
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 4s]
Raw output
AssertionError: Lists differ: ['a', 'b', 'c', 'd', 'e', 'f', 'x', 'y', 'z'] != ['a', 'a', 'b', 'b', 'c', 'c', 'd', 'd', 'e', 'e[37 chars] 'z']
First differing element 1:
'b'
'a'
Second list contains 9 additional elements.
First extra element 9:
'e'
- ['a', 'b', 'c', 'd', 'e', 'f', 'x', 'y', 'z']
+ ['a',
+ 'a',
+ 'b',
+ 'b',
+ 'c',
+ 'c',
+ 'd',
+ 'd',
+ 'e',
+ 'e',
+ 'f',
+ 'f',
+ 'x',
+ 'x',
+ 'y',
+ 'y',
+ 'z',
+ 'z']
self = <apache_beam.examples.snippets.snippets_test.SnippetsTest testMethod=test_model_multiple_pcollections_flatten_with_transform>
def test_model_multiple_pcollections_flatten_with_transform(self):
contents = ['a', 'b', 'c', 'd', 'e', 'f']
result_path = self.create_temp_file()
snippets.model_multiple_pcollections_flatten_with_transform(
contents, result_path)
> self.assertEqual(contents + ['x', 'y', 'z'], self.get_output(result_path))
E AssertionError: Lists differ: ['a', 'b', 'c', 'd', 'e', 'f', 'x', 'y', 'z'] != ['a', 'a', 'b', 'b', 'c', 'c', 'd', 'd', 'e', 'e[37 chars] 'z']
E
E First differing element 1:
E 'b'
E 'a'
E
E Second list contains 9 additional elements.
E First extra element 9:
E 'e'
E
E - ['a', 'b', 'c', 'd', 'e', 'f', 'x', 'y', 'z']
E + ['a',
E + 'a',
E + 'b',
E + 'b',
E + 'c',
E + 'c',
E + 'd',
E + 'd',
E + 'e',
E + 'e',
E + 'f',
E + 'f',
E + 'x',
E + 'x',
E + 'y',
E + 'y',
E + 'z',
E + 'z']
apache_beam/examples/snippets/snippets_test.py:931: AssertionError
Check warning on line 0 in apache_beam.examples.snippets.snippets_test.SnippetsTest
github-actions / Test Results
All 2 runs failed: test_pipeline_logging (apache_beam.examples.snippets.snippets_test.SnippetsTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 3s]
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 4s]
Raw output
AssertionError: Lists differ: ['a', 'are', 'found', 'found', 'found', 'from', '[111 chars]ere'] != ['a', 'a', 'are', 'are', 'found', 'found', 'found[276 chars]ere']
First differing element 1:
'are'
'a'
Second list contains 21 additional elements.
First extra element 21:
'love'
['a',
+ 'a',
+ 'are',
'are',
'found',
'found',
'found',
+ 'found',
+ 'found',
+ 'found',
+ 'from',
'from',
'hopeless',
+ 'hopeless',
+ 'in',
'in',
'love',
'love',
'love',
+ 'love',
+ 'love',
+ 'love',
+ 'place',
'place',
'right',
'right',
+ 'right',
+ 'right',
'start',
+ 'start',
+ 'the',
'the',
'we',
'we',
'we',
'we',
+ 'we',
+ 'we',
+ 'we',
+ 'we',
+ 'where',
'where']
self = <apache_beam.examples.snippets.snippets_test.SnippetsTest testMethod=test_pipeline_logging>
def test_pipeline_logging(self):
result_path = self.create_temp_file()
lines = [
'we found love right where we are',
'we found love right from the start',
'we found love in a hopeless place'
]
snippets.pipeline_logging(lines, result_path)
> self.assertEqual(
sorted(' '.join(lines).split(' ')), self.get_output(result_path))
E AssertionError: Lists differ: ['a', 'are', 'found', 'found', 'found', 'from', '[111 chars]ere'] != ['a', 'a', 'are', 'are', 'found', 'found', 'found[276 chars]ere']
E
E First differing element 1:
E 'are'
E 'a'
E
E Second list contains 21 additional elements.
E First extra element 21:
E 'love'
E
E ['a',
E + 'a',
E + 'are',
E 'are',
E 'found',
E 'found',
E 'found',
E + 'found',
E + 'found',
E + 'found',
E + 'from',
E 'from',
E 'hopeless',
E + 'hopeless',
E + 'in',
E 'in',
E 'love',
E 'love',
E 'love',
E + 'love',
E + 'love',
E + 'love',
E + 'place',
E 'place',
E 'right',
E 'right',
E + 'right',
E + 'right',
E 'start',
E + 'start',
E + 'the',
E 'the',
E 'we',
E 'we',
E 'we',
E 'we',
E + 'we',
E + 'we',
E + 'we',
E + 'we',
E + 'where',
E 'where']
apache_beam/examples/snippets/snippets_test.py:799: AssertionError
Check warning on line 0 in apache_beam.examples.snippets.snippets_test.SnippetsTest
github-actions / Test Results
All 2 runs failed: test_model_pcollection (apache_beam.examples.snippets.snippets_test.SnippetsTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 3s]
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 3s]
Raw output
AssertionError: Lists differ: ['Or [39 chars] ', 'Or to take arms against a sea of troubles[283 chars]er "] != ['Or [39 chars] ', 'The slings and arrows of outrageous fortu[94 chars]er "]
First differing element 1:
'Or to take arms against a sea of troubles, '
'The slings and arrows of outrageous fortune, '
First list contains 4 additional elements.
First extra element 4:
'To be, or not to be: that is the question: '
['Or to take arms against a sea of troubles, ',
- 'Or to take arms against a sea of troubles, ',
- 'The slings and arrows of outrageous fortune, ',
'The slings and arrows of outrageous fortune, ',
'To be, or not to be: that is the question: ',
- 'To be, or not to be: that is the question: ',
- "Whether 'tis nobler in the mind to suffer ",
"Whether 'tis nobler in the mind to suffer "]
self = <apache_beam.examples.snippets.snippets_test.SnippetsTest testMethod=test_model_pcollection>
def test_model_pcollection(self):
temp_path = self.create_temp_file()
snippets.model_pcollection(temp_path)
> self.assertEqual(
self.get_output(temp_path),
[
'Or to take arms against a sea of troubles, ',
'The slings and arrows of outrageous fortune, ',
'To be, or not to be: that is the question: ',
'Whether \'tis nobler in the mind to suffer ',
])
E AssertionError: Lists differ: ['Or [39 chars] ', 'Or to take arms against a sea of troubles[283 chars]er "] != ['Or [39 chars] ', 'The slings and arrows of outrageous fortu[94 chars]er "]
E
E First differing element 1:
E 'Or to take arms against a sea of troubles, '
E 'The slings and arrows of outrageous fortune, '
E
E First list contains 4 additional elements.
E First extra element 4:
E 'To be, or not to be: that is the question: '
E
E ['Or to take arms against a sea of troubles, ',
E - 'Or to take arms against a sea of troubles, ',
E - 'The slings and arrows of outrageous fortune, ',
E 'The slings and arrows of outrageous fortune, ',
E 'To be, or not to be: that is the question: ',
E - 'To be, or not to be: that is the question: ',
E - "Whether 'tis nobler in the mind to suffer ",
E "Whether 'tis nobler in the mind to suffer "]
apache_beam/examples/snippets/snippets_test.py:622: AssertionError
Check warning on line 0 in apache_beam.examples.snippets.snippets_test.SnippetsTest
github-actions / Test Results
All 2 runs failed: test_pipeline_options_remote (apache_beam.examples.snippets.snippets_test.SnippetsTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 3s]
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 5s]
Raw output
AssertionError: Lists differ: ['aa', 'bb', 'cc'] != ['aa', 'aa', 'aa', 'bb', 'bb', 'bb', 'cc', 'cc', 'cc']
First differing element 1:
'bb'
'aa'
Second list contains 6 additional elements.
First extra element 3:
'bb'
- ['aa', 'bb', 'cc']
+ ['aa', 'aa', 'aa', 'bb', 'bb', 'bb', 'cc', 'cc', 'cc']
self = <apache_beam.examples.snippets.snippets_test.SnippetsTest testMethod=test_pipeline_options_remote>
def test_pipeline_options_remote(self):
> self._run_test_pipeline_for_options(snippets.pipeline_options_remote)
apache_beam/examples/snippets/snippets_test.py:786:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
apache_beam/examples/snippets/snippets_test.py:780: in _run_test_pipeline_for_options
self.assertEqual(['aa', 'bb', 'cc'], self.get_output(result_path))
E AssertionError: Lists differ: ['aa', 'bb', 'cc'] != ['aa', 'aa', 'aa', 'bb', 'bb', 'bb', 'cc', 'cc', 'cc']
E
E First differing element 1:
E 'bb'
E 'aa'
E
E Second list contains 6 additional elements.
E First extra element 3:
E 'bb'
E
E - ['aa', 'bb', 'cc']
E + ['aa', 'aa', 'aa', 'bb', 'bb', 'bb', 'cc', 'cc', 'cc']
Check warning on line 0 in apache_beam.examples.snippets.snippets_test.CombineTest
github-actions / Test Results
1 out of 2 runs failed: test_custom_average (apache_beam.examples.snippets.snippets_test.CombineTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 4s]
Raw output
AssertionError: Lists differ: [4.25] != [4.25, 4.25]
Second list contains 1 additional elements.
First extra element 1:
4.25
- [4.25]
+ [4.25, 4.25]
self = <apache_beam.examples.snippets.snippets_test.CombineTest testMethod=test_custom_average>
def test_custom_average(self):
pc = [2, 3, 5, 7]
# [START combine_custom_average_define]
class AverageFn(beam.CombineFn):
def create_accumulator(self):
return (0.0, 0)
def add_input(self, sum_count, input):
(sum, count) = sum_count
return sum + input, count + 1
def merge_accumulators(self, accumulators):
sums, counts = zip(*accumulators)
return sum(sums), sum(counts)
def extract_output(self, sum_count):
(sum, count) = sum_count
return sum / count if count else float('NaN')
def compact(self, accumulator):
# No-op
return accumulator
# [END combine_custom_average_define]
# [START combine_custom_average_execute]
average = pc | beam.CombineGlobally(AverageFn())
# [END combine_custom_average_execute]
> self.assertEqual([4.25], average)
E AssertionError: Lists differ: [4.25] != [4.25, 4.25]
E
E Second list contains 1 additional elements.
E First extra element 1:
E 4.25
E
E - [4.25]
E + [4.25, 4.25]
apache_beam/examples/snippets/snippets_test.py:1285: AssertionError
github-actions / Test Results
test_enrichment_with_vertex_ai (apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest) failed
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 7s]
Raw output
AssertionError: Items in the first set but not the second:
" gender='1'"
' sale_price=15.0'
" state='1'"
' product_id=14235'
" country='1')"
"Row(user_id='2963'"
Items in the second set but not the first:
' product_id=11203'
" state='0'"
" gender='0'"
" country='0')"
' sale_price=12.0'
"Row(user_id='21422'"
self = <apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest testMethod=test_enrichment_with_vertex_ai>
mock_stdout = <_io.StringIO object at 0x7fe220322710>
def test_enrichment_with_vertex_ai(self, mock_stdout):
enrichment_with_vertex_ai()
output = mock_stdout.getvalue().splitlines()
expected = validate_enrichment_with_vertex_ai()
for i in range(len(expected)):
> self.assertEqual(set(output[i].split(',')), set(expected[i].split(',')))
E AssertionError: Items in the first set but not the second:
E " gender='1'"
E ' sale_price=15.0'
E " state='1'"
E ' product_id=14235'
E " country='1')"
E "Row(user_id='2963'"
E Items in the second set but not the first:
E ' product_id=11203'
E " state='0'"
E " gender='0'"
E " country='0')"
E ' sale_price=12.0'
E "Row(user_id='21422'"
apache_beam/examples/snippets/transforms/elementwise/enrichment_test.py:77: AssertionError
github-actions / Test Results
test_enrichment_with_bigtable (apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest) failed
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 4s]
Raw output
AssertionError: Lists differ: ["Row[141 chars]e_id=1, customer_id=1, product_id=1, quantity=[489 chars]'})"] != ["Row[141 chars]e_id=3, customer_id=3, product_id=2, quantity=[215 chars]'})"]
First differing element 1:
"Row(sale_id=1, customer_id=1, product_id=1, quantity=[76 chars]2'})"
"Row(sale_id=3, customer_id=3, product_id=2, quantity=[76 chars]4'})"
First list contains 2 additional elements.
First extra element 3:
"Row(sale_id=3, customer_id=3, product_id=2, quantity=3, product={'product_id': '2', 'product_name': 'pixel 6', 'product_stock': '4'})"
Diff is 761 characters long. Set self.maxDiff to None to see it.
self = <apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest testMethod=test_enrichment_with_bigtable>
mock_stdout = <_io.StringIO object at 0x7b13242eb370>
def test_enrichment_with_bigtable(self, mock_stdout):
enrichment_with_bigtable()
output = mock_stdout.getvalue().splitlines()
expected = validate_enrichment_with_bigtable()
> self.assertEqual(output, expected)
E AssertionError: Lists differ: ["Row[141 chars]e_id=1, customer_id=1, product_id=1, quantity=[489 chars]'})"] != ["Row[141 chars]e_id=3, customer_id=3, product_id=2, quantity=[215 chars]'})"]
E
E First differing element 1:
E "Row(sale_id=1, customer_id=1, product_id=1, quantity=[76 chars]2'})"
E "Row(sale_id=3, customer_id=3, product_id=2, quantity=[76 chars]4'})"
E
E First list contains 2 additional elements.
E First extra element 3:
E "Row(sale_id=3, customer_id=3, product_id=2, quantity=3, product={'product_id': '2', 'product_name': 'pixel 6', 'product_stock': '4'})"
E
E Diff is 761 characters long. Set self.maxDiff to None to see it.
apache_beam/examples/snippets/transforms/elementwise/enrichment_test.py:69: AssertionError
github-actions / Test Results
test_enrichment_with_vertex_ai_legacy (apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest) failed
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 4s]
Raw output
AssertionError: Lists differ: ["Row[93 chars]vie_01', title='The Shawshank Redemption', gen[285 chars]n')"] != ["Row[93 chars]vie_02', title='The Shining', genres='Horror')[68 chars]n')"]
First differing element 1:
"Row(entity_id='movie_01', title='The Shawshank Redemption', genres='Drama')"
"Row(entity_id='movie_02', title='The Shining', genres='Horror')"
First list contains 3 additional elements.
First extra element 3:
"Row(entity_id='movie_02', title='The Shining', genres='Horror')"
["Row(entity_id='movie_01', title='The Shawshank Redemption', genres='Drama')",
- "Row(entity_id='movie_01', title='The Shawshank Redemption', genres='Drama')",
- "Row(entity_id='movie_04', title='The Dark Knight', genres='Action')",
- "Row(entity_id='movie_02', title='The Shining', genres='Horror')",
"Row(entity_id='movie_02', title='The Shining', genres='Horror')",
"Row(entity_id='movie_04', title='The Dark Knight', genres='Action')"]
self = <apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest testMethod=test_enrichment_with_vertex_ai_legacy>
mock_stdout = <_io.StringIO object at 0x7fe0f3a33b50>
def test_enrichment_with_vertex_ai_legacy(self, mock_stdout):
enrichment_with_vertex_ai_legacy()
output = mock_stdout.getvalue().splitlines()
expected = validate_enrichment_with_vertex_ai_legacy()
self.maxDiff = None
> self.assertEqual(output, expected)
E AssertionError: Lists differ: ["Row[93 chars]vie_01', title='The Shawshank Redemption', gen[285 chars]n')"] != ["Row[93 chars]vie_02', title='The Shining', genres='Horror')[68 chars]n')"]
E
E First differing element 1:
E "Row(entity_id='movie_01', title='The Shawshank Redemption', genres='Drama')"
E "Row(entity_id='movie_02', title='The Shining', genres='Horror')"
E
E First list contains 3 additional elements.
E First extra element 3:
E "Row(entity_id='movie_02', title='The Shining', genres='Horror')"
E
E ["Row(entity_id='movie_01', title='The Shawshank Redemption', genres='Drama')",
E - "Row(entity_id='movie_01', title='The Shawshank Redemption', genres='Drama')",
E - "Row(entity_id='movie_04', title='The Dark Knight', genres='Action')",
E - "Row(entity_id='movie_02', title='The Shining', genres='Horror')",
E "Row(entity_id='movie_02', title='The Shining', genres='Horror')",
E "Row(entity_id='movie_04', title='The Dark Knight', genres='Action')"]
apache_beam/examples/snippets/transforms/elementwise/enrichment_test.py:84: AssertionError
github-actions / Test Results
All 2 runs failed: test_pardo_dofn_methods (apache_beam.examples.snippets.transforms.elementwise.pardo_test.ParDoStdoutTest)
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 3s]
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 3s]
Raw output
AssertionError: Lists differ: ['__i[113 chars]e', 'setup', 'start_bundle', '* process', '* p[73 chars]own'] != ['__i[113 chars]e', 'teardown']
First differing element 9:
'setup'
'teardown'
First list contains 8 additional elements.
First extra element 10:
'start_bundle'
['__init__',
'setup',
'start_bundle',
'* process',
'* process',
'* process',
'* process',
'* process',
'* finish_bundle',
- 'setup',
- 'start_bundle',
- '* process',
- '* process',
- '* process',
- '* process',
- '* process',
- '* finish_bundle',
'teardown']
self = <apache_beam.examples.snippets.transforms.elementwise.pardo_test.ParDoStdoutTest testMethod=test_pardo_dofn_methods>
mock_stdout = <_io.StringIO object at 0x7e089c6a81f0>
def test_pardo_dofn_methods(self, mock_stdout):
expected = pardo_dofn_methods.pardo_dofn_methods(check_dofn_methods)
actual = mock_stdout.getvalue().splitlines()
# For the stdout, check the ordering of the methods, not of the elements.
actual_stdout = [line.split(':')[0] for line in actual]
expected_stdout = [line.split(':')[0] for line in expected]
> self.assertEqual(actual_stdout, expected_stdout)
E AssertionError: Lists differ: ['__i[113 chars]e', 'setup', 'start_bundle', '* process', '* p[73 chars]own'] != ['__i[113 chars]e', 'teardown']
E
E First differing element 9:
E 'setup'
E 'teardown'
E
E First list contains 8 additional elements.
E First extra element 10:
E 'start_bundle'
E
E ['__init__',
E 'setup',
E 'start_bundle',
E '* process',
E '* process',
E '* process',
E '* process',
E '* process',
E '* finish_bundle',
E - 'setup',
E - 'start_bundle',
E - '* process',
E - '* process',
E - '* process',
E - '* process',
E - '* process',
E - '* finish_bundle',
E 'teardown']
apache_beam/examples/snippets/transforms/elementwise/pardo_test.py:109: AssertionError
Check notice on line 0 in .github
github-actions / Test Results
46 skipped tests found
There are 46 skipped tests, see "Raw output" for the full list of skipped tests.
Raw output
apache_beam.examples.avro_nyc_trips_it_test.AvroNycTripsIT ‑ test_avro_nyc_trips_output_files_on_small_input
apache_beam.examples.complete.autocomplete_it_test.AutocompleteIT ‑ test_autocomplete_output_files_on_small_input
apache_beam.examples.complete.autocomplete_test.AutocompleteTest ‑ test_autocomplete_it
apache_beam.examples.complete.distribopt_test.DistribOptimizationTest ‑ test_basics
apache_beam.examples.complete.estimate_pi_it_test.EstimatePiIT ‑ test_estimate_pi_output_file
apache_beam.examples.complete.game.game_stats_it_test.GameStatsIT ‑ test_game_stats_it
apache_beam.examples.complete.game.hourly_team_score_it_test.HourlyTeamScoreIT ‑ test_hourly_team_score_it
apache_beam.examples.complete.game.hourly_team_score_it_test.HourlyTeamScoreIT ‑ test_hourly_team_score_output_checksum_on_small_input
apache_beam.examples.complete.game.leader_board_it_test.LeaderBoardIT ‑ test_leader_board_it
apache_beam.examples.complete.game.user_score_it_test.UserScoreIT ‑ test_user_score_it
apache_beam.examples.complete.game.user_score_it_test.UserScoreIT ‑ test_userscore_output_checksum_on_small_input
apache_beam.examples.complete.juliaset.juliaset.juliaset_test.JuliaSetTest ‑ test_generate_fractal_image
apache_beam.examples.complete.juliaset.juliaset.juliaset_test_it.JuliaSetTestIT ‑ test_run_example_with_setup_file
apache_beam.examples.complete.tfidf_it_test.TfIdfIT ‑ test_basics
apache_beam.examples.complete.top_wikipedia_sessions_it_test.ComputeTopSessionsIT ‑ test_top_wikipedia_sessions_output_files_on_small_input
apache_beam.examples.cookbook.bigquery_side_input_it_test.BigQuerySideInputIT ‑ test_bigquery_side_input_it
apache_beam.examples.cookbook.bigquery_tornadoes_it_test.BigqueryTornadoesIT ‑ test_bigquery_tornadoes_it
apache_beam.examples.cookbook.bigtableio_it_test.BigtableIOWriteTest ‑ test_bigtable_write
apache_beam.examples.cookbook.coders_it_test.CodersIT ‑ test_coders_output_files_on_small_input
apache_beam.examples.cookbook.custom_ptransform_it_test.CustomPTransformIT ‑ test_custom_ptransform_output_files_on_small_input
apache_beam.examples.cookbook.datastore_wordcount_it_test.DatastoreWordCountIT ‑ test_datastore_wordcount_it
apache_beam.examples.cookbook.filters_test.FiltersTest ‑ test_filters_output_bigquery_matcher
apache_beam.examples.cookbook.group_with_coder_test.GroupWithCoderTest ‑ test_basics_with_type_check
apache_beam.examples.cookbook.group_with_coder_test.GroupWithCoderTest ‑ test_basics_without_type_check
apache_beam.examples.cookbook.mergecontacts_test.MergeContactsTest ‑ test_mergecontacts
apache_beam.examples.cookbook.multiple_output_pardo_test.MultipleOutputParDo ‑ test_multiple_output_pardo
apache_beam.examples.dataframe.flight_delays_it_test.FlightDelaysTest ‑ test_flight_delays
apache_beam.examples.dataframe.taxiride_it_test.TaxirideIT ‑ test_aggregation
apache_beam.examples.dataframe.taxiride_it_test.TaxirideIT ‑ test_enrich
apache_beam.examples.dataframe.wordcount_test.WordCountTest ‑ test_basics
apache_beam.examples.fastavro_it_test.FastavroIT ‑ test_avro_it
apache_beam.examples.inference.tfx_bsl.tfx_bsl_inference_it_test.TFXRunInferenceTests ‑ test_tfx_run_inference_mobilenetv2
apache_beam.examples.ml_transform.ml_transform_it_test
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_bigqueryio_xlang
apache_beam.examples.snippets.transforms.elementwise.enrichment_test
apache_beam.examples.snippets.transforms.elementwise.mltransform_test
apache_beam.examples.snippets.transforms.elementwise.runinference_test
apache_beam.examples.streaming_wordcount_debugging_it_test.StreamingWordcountDebuggingIT ‑ test_streaming_wordcount_debugging_it
apache_beam.examples.streaming_wordcount_it_test.StreamingWordCountIT ‑ test_streaming_wordcount_it
apache_beam.examples.wordcount_debugging_test.WordCountDebuggingTest ‑ test_basics
apache_beam.examples.wordcount_it_test.WordCountIT ‑ test_wordcount_impersonation_it
apache_beam.examples.wordcount_it_test.WordCountIT ‑ test_wordcount_it
apache_beam.examples.wordcount_it_test.WordCountIT ‑ test_wordcount_it_with_prebuilt_sdk_container_cloud_build
apache_beam.examples.wordcount_it_test.WordCountIT ‑ test_wordcount_it_with_prebuilt_sdk_container_local_docker
apache_beam.examples.wordcount_minimal_test.WordCountMinimalTest ‑ test_basics
apache_beam.examples.wordcount_test.WordCountTest ‑ test_basics
Check notice on line 0 in .github
github-actions / Test Results
257 tests found
There are 257 tests, see "Raw output" for the full list of tests.
Raw output
apache_beam.examples.avro_nyc_trips_it_test.AvroNycTripsIT ‑ test_avro_nyc_trips_output_files_on_small_input
apache_beam.examples.avro_nyc_trips_test.AvroNycTripsTest ‑ test_calculate_price_per_attribute
apache_beam.examples.avro_nyc_trips_test.AvroNycTripsTest ‑ test_create_key_with_service_and_day
apache_beam.examples.avro_nyc_trips_test.AvroNycTripsTest ‑ test_flatten_group
apache_beam.examples.complete.autocomplete_it_test.AutocompleteIT ‑ test_autocomplete_output_files_on_small_input
apache_beam.examples.complete.autocomplete_test.AutocompleteTest ‑ test_autocomplete_it
apache_beam.examples.complete.autocomplete_test.AutocompleteTest ‑ test_top_prefixes
apache_beam.examples.complete.distribopt_test.DistribOptimizationTest ‑ test_basics
apache_beam.examples.complete.estimate_pi_it_test.EstimatePiIT ‑ test_estimate_pi_output_file
apache_beam.examples.complete.estimate_pi_test.EstimatePiTest ‑ test_basics
apache_beam.examples.complete.game.game_stats_it_test.GameStatsIT ‑ test_game_stats_it
apache_beam.examples.complete.game.game_stats_test.GameStatsTest ‑ test_game_stats_sessions
apache_beam.examples.complete.game.game_stats_test.GameStatsTest ‑ test_spammy_users
apache_beam.examples.complete.game.hourly_team_score_it_test.HourlyTeamScoreIT ‑ test_hourly_team_score_it
apache_beam.examples.complete.game.hourly_team_score_it_test.HourlyTeamScoreIT ‑ test_hourly_team_score_output_checksum_on_small_input
apache_beam.examples.complete.game.hourly_team_score_test.HourlyTeamScoreTest ‑ test_hourly_team_score
apache_beam.examples.complete.game.leader_board_it_test.LeaderBoardIT ‑ test_leader_board_it
apache_beam.examples.complete.game.leader_board_test.LeaderBoardTest ‑ test_leader_board_teams
apache_beam.examples.complete.game.leader_board_test.LeaderBoardTest ‑ test_leader_board_users
apache_beam.examples.complete.game.user_score_it_test.UserScoreIT ‑ test_user_score_it
apache_beam.examples.complete.game.user_score_it_test.UserScoreIT ‑ test_userscore_output_checksum_on_small_input
apache_beam.examples.complete.game.user_score_test.UserScoreTest ‑ test_user_score
apache_beam.examples.complete.juliaset.juliaset.juliaset_test.JuliaSetTest ‑ test_generate_fractal_image
apache_beam.examples.complete.juliaset.juliaset.juliaset_test.JuliaSetTest ‑ test_output_file_format
apache_beam.examples.complete.juliaset.juliaset.juliaset_test_it.JuliaSetTestIT ‑ test_run_example_with_setup_file
apache_beam.examples.complete.tfidf_it_test.TfIdfIT ‑ test_basics
apache_beam.examples.complete.tfidf_test.TfIdfTest ‑ test_tfidf_transform
apache_beam.examples.complete.top_wikipedia_sessions_it_test.ComputeTopSessionsIT ‑ test_top_wikipedia_sessions_output_files_on_small_input
apache_beam.examples.complete.top_wikipedia_sessions_test.ComputeTopSessionsTest ‑ test_compute_top_sessions
apache_beam.examples.cookbook.bigquery_side_input_it_test.BigQuerySideInputIT ‑ test_bigquery_side_input_it
apache_beam.examples.cookbook.bigquery_side_input_test.BigQuerySideInputTest ‑ test_create_groups
apache_beam.examples.cookbook.bigquery_tornadoes_it_test.BigqueryTornadoesIT ‑ test_bigquery_tornadoes_it
apache_beam.examples.cookbook.bigquery_tornadoes_test.BigQueryTornadoesTest ‑ test_basics
apache_beam.examples.cookbook.bigtableio_it_test.BigtableIOWriteTest ‑ test_bigtable_write
apache_beam.examples.cookbook.coders_it_test.CodersIT ‑ test_coders_output_files_on_small_input
apache_beam.examples.cookbook.coders_test.CodersTest ‑ test_compute_points
apache_beam.examples.cookbook.combiners_test.CombinersTest ‑ test_combine_per_key_with_callable
apache_beam.examples.cookbook.combiners_test.CombinersTest ‑ test_combine_per_key_with_custom_callable
apache_beam.examples.cookbook.custom_ptransform_it_test.CustomPTransformIT ‑ test_custom_ptransform_output_files_on_small_input
apache_beam.examples.cookbook.custom_ptransform_test.CustomCountTest ‑ test_count1
apache_beam.examples.cookbook.custom_ptransform_test.CustomCountTest ‑ test_count2
apache_beam.examples.cookbook.custom_ptransform_test.CustomCountTest ‑ test_count3
apache_beam.examples.cookbook.datastore_wordcount_it_test.DatastoreWordCountIT ‑ test_datastore_wordcount_it
apache_beam.examples.cookbook.filters_test.FiltersTest ‑ test_basic_empty
apache_beam.examples.cookbook.filters_test.FiltersTest ‑ test_basic_empty_missing
apache_beam.examples.cookbook.filters_test.FiltersTest ‑ test_basics
apache_beam.examples.cookbook.filters_test.FiltersTest ‑ test_filters_output_bigquery_matcher
apache_beam.examples.cookbook.group_with_coder_test.GroupWithCoderTest ‑ test_basics_with_type_check
apache_beam.examples.cookbook.group_with_coder_test.GroupWithCoderTest ‑ test_basics_without_type_check
apache_beam.examples.cookbook.mergecontacts_test.MergeContactsTest ‑ test_mergecontacts
apache_beam.examples.cookbook.multiple_output_pardo_test.MultipleOutputParDo ‑ test_multiple_output_pardo
apache_beam.examples.dataframe.flight_delays_it_test.FlightDelaysTest ‑ test_flight_delays
apache_beam.examples.dataframe.taxiride_it_test.TaxirideIT ‑ test_aggregation
apache_beam.examples.dataframe.taxiride_it_test.TaxirideIT ‑ test_enrich
apache_beam.examples.dataframe.taxiride_test.TaxiRideExampleTest ‑ test_aggregation
apache_beam.examples.dataframe.taxiride_test.TaxiRideExampleTest ‑ test_enrich
apache_beam.examples.dataframe.wordcount_test.WordCountTest ‑ test_basics
apache_beam.examples.fastavro_it_test.FastavroIT ‑ test_avro_it
apache_beam.examples.inference.tfx_bsl.tfx_bsl_inference_it_test.TFXRunInferenceTests ‑ test_tfx_run_inference_mobilenetv2
apache_beam.examples.matrix_power_test.MatrixPowerTest ‑ test_basics
apache_beam.examples.ml_transform.ml_transform_it_test
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_bounded_sum
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_combine_concat
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_combine_per_key
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_combine_reduce
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_combine_values
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_count
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_custom_average
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_global_sum
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_keys
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_setting_fixed_windows
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_setting_global_window
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_setting_session_windows
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_setting_sliding_windows
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_setting_timestamp
apache_beam.examples.snippets.snippets_test.PTransformTest ‑ test_composite
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_side_input
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_side_input_dofn
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_using_flatmap
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_using_flatmap_yield
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_using_map
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_with_label
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_with_tagged_outputs
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_with_undeclared_outputs
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_yield
apache_beam.examples.snippets.snippets_test.SlowlyChangingSideInputsTest ‑ test_side_input_slow_update
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_construct_pipeline
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_examples_ptransforms_templated
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_examples_wordcount_0
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_examples_wordcount_1
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_examples_wordcount_2
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_examples_wordcount_3
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_examples_wordcount_debugging
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_examples_wordcount_streaming
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_bigqueryio
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_bigqueryio_xlang
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_co_group_by_key_tuple
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_composite_transform_example
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_composite_triggers
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_custom_sink
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_custom_source
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_datastoreio
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_early_late_triggers
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_group_by_key
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_join_using_side_inputs
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_multiple_pcollections_flatten
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_multiple_pcollections_flatten_with
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_multiple_pcollections_flatten_with_transform
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_multiple_pcollections_partition
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_other_composite_triggers
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_pcollection
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_pipelines
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_setting_trigger
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_textio
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_textio_compressed
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_use_and_query_metrics
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_pipeline_logging
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_pipeline_options_command_line
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_pipeline_options_local
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_pipeline_options_remote
apache_beam.examples.snippets.snippets_test.TypeHintsTest ‑ test_bad_types
apache_beam.examples.snippets.snippets_test.TypeHintsTest ‑ test_bad_types_annotations
apache_beam.examples.snippets.snippets_test.TypeHintsTest ‑ test_deterministic_key
apache_beam.examples.snippets.snippets_test.TypeHintsTest ‑ test_runtime_checks_off
apache_beam.examples.snippets.snippets_test.TypeHintsTest ‑ test_runtime_checks_on
apache_beam.examples.snippets.snippets_test.ValueProviderInfoTest ‑ test_accessing_valueprovider_info_after_run
apache_beam.examples.snippets.transforms.aggregation.approximatequantiles_test.ApproximateQuantilesTest ‑ test_approximatequantiles
apache_beam.examples.snippets.transforms.aggregation.approximateunique_test.ApproximateUniqueTest ‑ test_approximateunique
apache_beam.examples.snippets.transforms.aggregation.batchelements_test.BatchElementsTest ‑ test_batchelements
apache_beam.examples.snippets.transforms.aggregation.cogroupbykey_test.CoGroupByKeyTest ‑ test_cogroupbykey
apache_beam.examples.snippets.transforms.aggregation.combineglobally_test.CombineGloballyTest ‑ test_combineglobally_combinefn
apache_beam.examples.snippets.transforms.aggregation.combineglobally_test.CombineGloballyTest ‑ test_combineglobally_function
apache_beam.examples.snippets.transforms.aggregation.combineglobally_test.CombineGloballyTest ‑ test_combineglobally_lambda
apache_beam.examples.snippets.transforms.aggregation.combineglobally_test.CombineGloballyTest ‑ test_combineglobally_multiple_arguments
apache_beam.examples.snippets.transforms.aggregation.combineglobally_test.CombineGloballyTest ‑ test_combineglobally_side_inputs_singleton
apache_beam.examples.snippets.transforms.aggregation.combineperkey_test.CombinePerKeyTest ‑ test_combineperkey_combinefn
apache_beam.examples.snippets.transforms.aggregation.combineperkey_test.CombinePerKeyTest ‑ test_combineperkey_function
apache_beam.examples.snippets.transforms.aggregation.combineperkey_test.CombinePerKeyTest ‑ test_combineperkey_lambda
apache_beam.examples.snippets.transforms.aggregation.combineperkey_test.CombinePerKeyTest ‑ test_combineperkey_multiple_arguments
apache_beam.examples.snippets.transforms.aggregation.combineperkey_test.CombinePerKeyTest ‑ test_combineperkey_side_inputs_dict
apache_beam.examples.snippets.transforms.aggregation.combineperkey_test.CombinePerKeyTest ‑ test_combineperkey_side_inputs_iter
apache_beam.examples.snippets.transforms.aggregation.combineperkey_test.CombinePerKeyTest ‑ test_combineperkey_side_inputs_singleton
apache_beam.examples.snippets.transforms.aggregation.combineperkey_test.CombinePerKeyTest ‑ test_combineperkey_simple
apache_beam.examples.snippets.transforms.aggregation.combinevalues_test.CombineValuesTest ‑ test_combinevalues_combinefn
apache_beam.examples.snippets.transforms.aggregation.combinevalues_test.CombineValuesTest ‑ test_combinevalues_function
apache_beam.examples.snippets.transforms.aggregation.combinevalues_test.CombineValuesTest ‑ test_combinevalues_lambda
apache_beam.examples.snippets.transforms.aggregation.combinevalues_test.CombineValuesTest ‑ test_combinevalues_multiple_arguments
apache_beam.examples.snippets.transforms.aggregation.combinevalues_test.CombineValuesTest ‑ test_combinevalues_side_inputs_dict
apache_beam.examples.snippets.transforms.aggregation.combinevalues_test.CombineValuesTest ‑ test_combinevalues_side_inputs_iter
apache_beam.examples.snippets.transforms.aggregation.combinevalues_test.CombineValuesTest ‑ test_combinevalues_side_inputs_singleton
apache_beam.examples.snippets.transforms.aggregation.count_test.CountTest ‑ test_count_globally
apache_beam.examples.snippets.transforms.aggregation.count_test.CountTest ‑ test_count_per_element
apache_beam.examples.snippets.transforms.aggregation.count_test.CountTest ‑ test_count_per_key
apache_beam.examples.snippets.transforms.aggregation.distinct_test.DistinctTest ‑ test_distinct
apache_beam.examples.snippets.transforms.aggregation.groupby_test.GroupByTest ‑ test_expr_aggregate
apache_beam.examples.snippets.transforms.aggregation.groupby_test.GroupByTest ‑ test_global_aggregate
apache_beam.examples.snippets.transforms.aggregation.groupby_test.GroupByTest ‑ test_group_by_attr
apache_beam.examples.snippets.transforms.aggregation.groupby_test.GroupByTest ‑ test_group_by_attr_expr
apache_beam.examples.snippets.transforms.aggregation.groupby_test.GroupByTest ‑ test_groupby_expr
apache_beam.examples.snippets.transforms.aggregation.groupby_test.GroupByTest ‑ test_groupby_two_exprs
apache_beam.examples.snippets.transforms.aggregation.groupby_test.GroupByTest ‑ test_simple_aggregate
apache_beam.examples.snippets.transforms.aggregation.groupbykey_test.GroupByKeyTest ‑ test_groupbykey
apache_beam.examples.snippets.transforms.aggregation.groupintobatches_test.GroupIntoBatchesTest ‑ test_groupintobatches
apache_beam.examples.snippets.transforms.aggregation.latest_test.LatestTest ‑ test_latest_globally
apache_beam.examples.snippets.transforms.aggregation.latest_test.LatestTest ‑ test_latest_per_key
apache_beam.examples.snippets.transforms.aggregation.max_test.MaxTest ‑ test_max_globally
apache_beam.examples.snippets.transforms.aggregation.max_test.MaxTest ‑ test_max_per_key
apache_beam.examples.snippets.transforms.aggregation.mean_test.MeanTest ‑ test_mean_globally
apache_beam.examples.snippets.transforms.aggregation.mean_test.MeanTest ‑ test_mean_per_key
apache_beam.examples.snippets.transforms.aggregation.min_test.MinTest ‑ test_min_globally
apache_beam.examples.snippets.transforms.aggregation.min_test.MinTest ‑ test_min_per_key
apache_beam.examples.snippets.transforms.aggregation.sample_test.SampleTest ‑ test_sample_fixed_size_globally
apache_beam.examples.snippets.transforms.aggregation.sample_test.SampleTest ‑ test_sample_fixed_size_per_key
apache_beam.examples.snippets.transforms.aggregation.sum_test.SumTest ‑ test_sum_globally
apache_beam.examples.snippets.transforms.aggregation.sum_test.SumTest ‑ test_sum_per_key
apache_beam.examples.snippets.transforms.aggregation.tolist_test.BatchElementsTest ‑ test_tolist
apache_beam.examples.snippets.transforms.aggregation.top_test.TopTest ‑ test_top_largest
apache_beam.examples.snippets.transforms.aggregation.top_test.TopTest ‑ test_top_largest_per_key
apache_beam.examples.snippets.transforms.aggregation.top_test.TopTest ‑ test_top_of
apache_beam.examples.snippets.transforms.aggregation.top_test.TopTest ‑ test_top_per_key
apache_beam.examples.snippets.transforms.aggregation.top_test.TopTest ‑ test_top_smallest
apache_beam.examples.snippets.transforms.aggregation.top_test.TopTest ‑ test_top_smallest_per_key
apache_beam.examples.snippets.transforms.elementwise.enrichment_test
apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest ‑ test_enrichment_with_bigtable
apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest ‑ test_enrichment_with_vertex_ai
apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest ‑ test_enrichment_with_vertex_ai_legacy
apache_beam.examples.snippets.transforms.elementwise.filter_test.FilterTest ‑ test_filter_function
apache_beam.examples.snippets.transforms.elementwise.filter_test.FilterTest ‑ test_filter_lambda
apache_beam.examples.snippets.transforms.elementwise.filter_test.FilterTest ‑ test_filter_multiple_arguments
apache_beam.examples.snippets.transforms.elementwise.filter_test.FilterTest ‑ test_filter_side_inputs_dict
apache_beam.examples.snippets.transforms.elementwise.filter_test.FilterTest ‑ test_filter_side_inputs_iter
apache_beam.examples.snippets.transforms.elementwise.filter_test.FilterTest ‑ test_filter_side_inputs_singleton
apache_beam.examples.snippets.transforms.elementwise.flatmap_test.FlatMapTest ‑ test_flatmap_function
apache_beam.examples.snippets.transforms.elementwise.flatmap_test.FlatMapTest ‑ test_flatmap_generator
apache_beam.examples.snippets.transforms.elementwise.flatmap_test.FlatMapTest ‑ test_flatmap_lambda
apache_beam.examples.snippets.transforms.elementwise.flatmap_test.FlatMapTest ‑ test_flatmap_multiple_arguments
apache_beam.examples.snippets.transforms.elementwise.flatmap_test.FlatMapTest ‑ test_flatmap_nofunction
apache_beam.examples.snippets.transforms.elementwise.flatmap_test.FlatMapTest ‑ test_flatmap_side_inputs_dict
apache_beam.examples.snippets.transforms.elementwise.flatmap_test.FlatMapTest ‑ test_flatmap_side_inputs_iter
apache_beam.examples.snippets.transforms.elementwise.flatmap_test.FlatMapTest ‑ test_flatmap_side_inputs_singleton
apache_beam.examples.snippets.transforms.elementwise.flatmap_test.FlatMapTest ‑ test_flatmap_simple
apache_beam.examples.snippets.transforms.elementwise.flatmap_test.FlatMapTest ‑ test_flatmap_tuple
apache_beam.examples.snippets.transforms.elementwise.keys_test.KeysTest ‑ test_keys
apache_beam.examples.snippets.transforms.elementwise.kvswap_test.KvSwapTest ‑ test_kvswap
apache_beam.examples.snippets.transforms.elementwise.map_test.MapTest ‑ test_map_context
apache_beam.examples.snippets.transforms.elementwise.map_test.MapTest ‑ test_map_function
apache_beam.examples.snippets.transforms.elementwise.map_test.MapTest ‑ test_map_lambda
apache_beam.examples.snippets.transforms.elementwise.map_test.MapTest ‑ test_map_multiple_arguments
apache_beam.examples.snippets.transforms.elementwise.map_test.MapTest ‑ test_map_side_inputs_dict
apache_beam.examples.snippets.transforms.elementwise.map_test.MapTest ‑ test_map_side_inputs_iter
apache_beam.examples.snippets.transforms.elementwise.map_test.MapTest ‑ test_map_side_inputs_singleton
apache_beam.examples.snippets.transforms.elementwise.map_test.MapTest ‑ test_map_simple
apache_beam.examples.snippets.transforms.elementwise.map_test.MapTest ‑ test_map_tuple
apache_beam.examples.snippets.transforms.elementwise.mltransform_test
apache_beam.examples.snippets.transforms.elementwise.pardo_test.ParDoStdoutTest ‑ test_pardo_dofn_methods
apache_beam.examples.snippets.transforms.elementwise.pardo_test.ParDoTest ‑ test_pardo_dofn
apache_beam.examples.snippets.transforms.elementwise.pardo_test.ParDoTest ‑ test_pardo_dofn_params
apache_beam.examples.snippets.transforms.elementwise.partition_test.PartitionTest ‑ test_partition_function
apache_beam.examples.snippets.transforms.elementwise.partition_test.PartitionTest ‑ test_partition_lambda
apache_beam.examples.snippets.transforms.elementwise.partition_test.PartitionTest ‑ test_partition_multiple_arguments
apache_beam.examples.snippets.transforms.elementwise.regex_test.RegexTest ‑ test_all_matches
apache_beam.examples.snippets.transforms.elementwise.regex_test.RegexTest ‑ test_find
apache_beam.examples.snippets.transforms.elementwise.regex_test.RegexTest ‑ test_find_all
apache_beam.examples.snippets.transforms.elementwise.regex_test.RegexTest ‑ test_find_kv
apache_beam.examples.snippets.transforms.elementwise.regex_test.RegexTest ‑ test_matches
apache_beam.examples.snippets.transforms.elementwise.regex_test.RegexTest ‑ test_matches_kv
apache_beam.examples.snippets.transforms.elementwise.regex_test.RegexTest ‑ test_replace_all
apache_beam.examples.snippets.transforms.elementwise.regex_test.RegexTest ‑ test_replace_first
apache_beam.examples.snippets.transforms.elementwise.regex_test.RegexTest ‑ test_split
apache_beam.examples.snippets.transforms.elementwise.runinference_test
apache_beam.examples.snippets.transforms.elementwise.tostring_test.ToStringTest ‑ test_tostring_element
apache_beam.examples.snippets.transforms.elementwise.tostring_test.ToStringTest ‑ test_tostring_iterables
apache_beam.examples.snippets.transforms.elementwise.tostring_test.ToStringTest ‑ test_tostring_kvs
apache_beam.examples.snippets.transforms.elementwise.values_test.ValuesTest ‑ test_values
apache_beam.examples.snippets.transforms.elementwise.withtimestamps_test.WithTimestampsTest ‑ test_datetime2unix_time
apache_beam.examples.snippets.transforms.elementwise.withtimestamps_test.WithTimestampsTest ‑ test_event_time
apache_beam.examples.snippets.transforms.elementwise.withtimestamps_test.WithTimestampsTest ‑ test_logical_clock
apache_beam.examples.snippets.transforms.elementwise.withtimestamps_test.WithTimestampsTest ‑ test_processing_time
apache_beam.examples.snippets.transforms.elementwise.withtimestamps_test.WithTimestampsTest ‑ test_time_tuple2unix_time
apache_beam.examples.snippets.transforms.other.create_test.CreateTest ‑ test_create
apache_beam.examples.snippets.transforms.other.flatten_test.FlattenTest ‑ test_flatten
apache_beam.examples.snippets.transforms.other.window_test.WindowTest ‑ test_window
apache_beam.examples.snippets.util_test.UtilTest ‑ test_assert_matches_stdout_object
apache_beam.examples.snippets.util_test.UtilTest ‑ test_assert_matches_stdout_sorted_keys
apache_beam.examples.snippets.util_test.UtilTest ‑ test_assert_matches_stdout_string
apache_beam.examples.snippets.util_test.UtilTest ‑ test_run_shell_commands
apache_beam.examples.streaming_wordcount_debugging_it_test.StreamingWordcountDebuggingIT ‑ test_streaming_wordcount_debugging_it
apache_beam.examples.streaming_wordcount_debugging_test.StreamingWordcountDebugging ‑ test_streaming_wordcount_debugging
apache_beam.examples.streaming_wordcount_it_test.StreamingWordCountIT ‑ test_streaming_wordcount_it
apache_beam.examples.wordcount_debugging_test.WordCountDebuggingTest ‑ test_basics
apache_beam.examples.wordcount_it_test.WordCountIT ‑ test_wordcount_impersonation_it
apache_beam.examples.wordcount_it_test.WordCountIT ‑ test_wordcount_it
apache_beam.examples.wordcount_it_test.WordCountIT ‑ test_wordcount_it_with_prebuilt_sdk_container_cloud_build
apache_beam.examples.wordcount_it_test.WordCountIT ‑ test_wordcount_it_with_prebuilt_sdk_container_local_docker
apache_beam.examples.wordcount_minimal_test.WordCountMinimalTest ‑ test_basics
apache_beam.examples.wordcount_test.WordCountTest ‑ test_basics