Skip to content

Add issue link to disabled TensorRT integration test #6011

Add issue link to disabled TensorRT integration test

Add issue link to disabled TensorRT integration test #6011

GitHub Actions / Test Results failed Nov 11, 2024 in 0s

1 fail, 46 skipped, 209 pass in 1m 1s

  4 files    4 suites   1m 1s ⏱️
256 tests 209 ✅  46 💤 1 ❌
515 runs  411 ✅ 102 💤 2 ❌

Results for commit a90a100.

Annotations

Check warning on line 0 in apache_beam.examples.snippets.snippets_test.TypeHintsTest

See this annotation in the file changed.

@github-actions github-actions / Test Results

All 2 runs failed: test_runtime_checks_on (apache_beam.examples.snippets.snippets_test.TypeHintsTest)

sdks/python/test-suites/tox/py311/build/srcs/sdks/python/pytest_py311-cloud.xml [took 0s]
sdks/python/test-suites/tox/py311/build/srcs/sdks/python/pytest_py311.xml [took 0s]
Raw output
TypeError: Argument 'exn' has incorrect type (expected BaseException, got tuple)
type_constraint = <class 'str'>, datum = 3, is_input = False

    @staticmethod
    def type_check(type_constraint, datum, is_input):
      """Typecheck a PTransform related datum according to a type constraint.
    
      This function is used to optionally type-check either an input or an output
      to a PTransform.
    
      Args:
          type_constraint: An instance of a typehints.TypeContraint, one of the
            white-listed builtin Python types, or a custom user class.
          datum: An instance of a Python object.
          is_input: True if 'datum' is an input to a PTransform's DoFn. False
            otherwise.
    
      Raises:
        TypeError: If 'datum' fails to type-check according to 'type_constraint'.
      """
      datum_type = 'input' if is_input else 'output'
    
      try:
>       check_constraint(type_constraint, datum)

target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typecheck.py:201: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

type_constraint = <class 'str'>, object_instance = 3

    def check_constraint(type_constraint, object_instance):
      """Determine if the passed type instance satisfies the TypeConstraint.
    
      When examining a candidate type for constraint satisfaction in
      'type_check', all CompositeTypeHint's eventually call this function. This
      function may end up being called recursively if the hinted type of a
      CompositeTypeHint is another CompositeTypeHint.
    
      Args:
        type_constraint: An instance of a TypeConstraint or a built-in Python type.
        object_instance: An object instance.
    
      Raises:
        SimpleTypeHintError: If 'type_constraint' is a one of the allowed primitive
          Python types and 'object_instance' isn't an instance of this type.
        CompositeTypeHintError: If 'type_constraint' is a TypeConstraint object and
          'object_instance' does not satisfy its constraint.
      """
      if type_constraint is None and object_instance is None:
        return
      elif isinstance(type_constraint, TypeConstraint):
        type_constraint.type_check(object_instance)
      elif type_constraint is None:
        # TODO(robertwb): Fix uses of None for Any.
        pass
      elif not isinstance(type_constraint, type):
        raise RuntimeError("bad type: %s" % (type_constraint, ))
      elif not isinstance(object_instance, type_constraint):
>       raise SimpleTypeHintError
E       apache_beam.typehints.typehints.SimpleTypeHintError

target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typehints.py:436: SimpleTypeHintError

During handling of the above exception, another exception occurred:

self = <apache_beam.typehints.typecheck.OutputCheckWrapperDoFn object at 0x7b59ef4c0310>
method = <bound method TypeCheckWrapperDoFn.process of <apache_beam.typehints.typecheck.TypeCheckWrapperDoFn object at 0x7b59ef7cacd0>>
args = ('a',), kwargs = {}

    def wrapper(self, method, args, kwargs):
      try:
>       result = method(*args, **kwargs)

target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typecheck.py:95: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typecheck.py:151: in process
    return self._type_check_result(self.dofn.process(*args, **kwargs))
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typecheck.py:178: in _type_check_result
    type_check_output(o)
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typecheck.py:170: in type_check_output
    self.type_check(self._output_type_hint, x, is_input=False)
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typecheck.py:211: in type_check
    raise TypeCheckError(error_msg).with_traceback(tb)
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typecheck.py:201: in type_check
    check_constraint(type_constraint, datum)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

type_constraint = <class 'str'>, object_instance = 3

    def check_constraint(type_constraint, object_instance):
      """Determine if the passed type instance satisfies the TypeConstraint.
    
      When examining a candidate type for constraint satisfaction in
      'type_check', all CompositeTypeHint's eventually call this function. This
      function may end up being called recursively if the hinted type of a
      CompositeTypeHint is another CompositeTypeHint.
    
      Args:
        type_constraint: An instance of a TypeConstraint or a built-in Python type.
        object_instance: An object instance.
    
      Raises:
        SimpleTypeHintError: If 'type_constraint' is a one of the allowed primitive
          Python types and 'object_instance' isn't an instance of this type.
        CompositeTypeHintError: If 'type_constraint' is a TypeConstraint object and
          'object_instance' does not satisfy its constraint.
      """
      if type_constraint is None and object_instance is None:
        return
      elif isinstance(type_constraint, TypeConstraint):
        type_constraint.type_check(object_instance)
      elif type_constraint is None:
        # TODO(robertwb): Fix uses of None for Any.
        pass
      elif not isinstance(type_constraint, type):
        raise RuntimeError("bad type: %s" % (type_constraint, ))
      elif not isinstance(object_instance, type_constraint):
>       raise SimpleTypeHintError
E       apache_beam.typehints.decorators.TypeCheckError: According to type-hint expected output should be of type <class 'str'>. Instead, received '3', an instance of type <class 'int'>.

target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typehints.py:436: TypeCheckError

During handling of the above exception, another exception occurred:

>   return self.do_fn_invoker.invoke_process(windowed_value)

apache_beam/runners/common.py:1501: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/runners/common.py:690: in apache_beam.runners.common.SimpleInvoker.invoke_process
    windowed_value, self.process_method(windowed_value.value))
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typecheck.py:78: in process
    return self.wrapper(self.dofn.process, args, kwargs)
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typecheck.py:102: in wrapper
    raise TypeCheckError(error_msg).with_traceback(tb)
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typecheck.py:95: in wrapper
    result = method(*args, **kwargs)
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typecheck.py:151: in process
    return self._type_check_result(self.dofn.process(*args, **kwargs))
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typecheck.py:178: in _type_check_result
    type_check_output(o)
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typecheck.py:170: in type_check_output
    self.type_check(self._output_type_hint, x, is_input=False)
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typecheck.py:211: in type_check
    raise TypeCheckError(error_msg).with_traceback(tb)
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typecheck.py:201: in type_check
    check_constraint(type_constraint, datum)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

type_constraint = <class 'str'>, object_instance = 3

    def check_constraint(type_constraint, object_instance):
      """Determine if the passed type instance satisfies the TypeConstraint.
    
      When examining a candidate type for constraint satisfaction in
      'type_check', all CompositeTypeHint's eventually call this function. This
      function may end up being called recursively if the hinted type of a
      CompositeTypeHint is another CompositeTypeHint.
    
      Args:
        type_constraint: An instance of a TypeConstraint or a built-in Python type.
        object_instance: An object instance.
    
      Raises:
        SimpleTypeHintError: If 'type_constraint' is a one of the allowed primitive
          Python types and 'object_instance' isn't an instance of this type.
        CompositeTypeHintError: If 'type_constraint' is a TypeConstraint object and
          'object_instance' does not satisfy its constraint.
      """
      if type_constraint is None and object_instance is None:
        return
      elif isinstance(type_constraint, TypeConstraint):
        type_constraint.type_check(object_instance)
      elif type_constraint is None:
        # TODO(robertwb): Fix uses of None for Any.
        pass
      elif not isinstance(type_constraint, type):
        raise RuntimeError("bad type: %s" % (type_constraint, ))
      elif not isinstance(object_instance, type_constraint):
>       raise SimpleTypeHintError
E       apache_beam.typehints.decorators.TypeCheckError: Runtime type violation detected within ParDo(Map(<lambda at snippets_test.py:445>)): According to type-hint expected output should be of type <class 'str'>. Instead, received '3', an instance of type <class 'int'>.

target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/typehints/typehints.py:436: TypeCheckError

During handling of the above exception, another exception occurred:

>   return self.do_fn_invoker.invoke_process(windowed_value)

apache_beam/runners/common.py:1501: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/runners/common.py:689: in apache_beam.runners.common.SimpleInvoker.invoke_process
    self.output_handler.handle_process_outputs(
apache_beam/runners/common.py:1687: in apache_beam.runners.common._OutputHandler.handle_process_outputs
    self._write_value_to_tag(tag, windowed_value, watermark_estimator)
apache_beam/runners/common.py:1800: in apache_beam.runners.common._OutputHandler._write_value_to_tag
    self.main_receivers.receive(windowed_value)
apache_beam/runners/worker/operations.py:263: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    self.consumer.process(windowed_value)
apache_beam/runners/worker/operations.py:950: in apache_beam.runners.worker.operations.DoOperation.process
    with self.scoped_process_state:
apache_beam/runners/worker/operations.py:951: in apache_beam.runners.worker.operations.DoOperation.process
    delayed_applications = self.dofn_runner.process(o)
apache_beam/runners/common.py:1503: in apache_beam.runners.common.DoFnRunner.process
    self._reraise_augmented(exn, windowed_value)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

>   self._maybe_sample_exception(exc_info, windowed_value)
E   TypeError: Argument 'exn' has incorrect type (expected BaseException, got tuple)

apache_beam/runners/common.py:1611: TypeError

During handling of the above exception, another exception occurred:

>   return self.do_fn_invoker.invoke_process(windowed_value)

apache_beam/runners/common.py:1501: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/runners/common.py:689: in apache_beam.runners.common.SimpleInvoker.invoke_process
    self.output_handler.handle_process_outputs(
apache_beam/runners/common.py:1687: in apache_beam.runners.common._OutputHandler.handle_process_outputs
    self._write_value_to_tag(tag, windowed_value, watermark_estimator)
apache_beam/runners/common.py:1800: in apache_beam.runners.common._OutputHandler._write_value_to_tag
    self.main_receivers.receive(windowed_value)
apache_beam/runners/worker/operations.py:263: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    self.consumer.process(windowed_value)
apache_beam/runners/worker/operations.py:950: in apache_beam.runners.worker.operations.DoOperation.process
    with self.scoped_process_state:
apache_beam/runners/worker/operations.py:951: in apache_beam.runners.worker.operations.DoOperation.process
    delayed_applications = self.dofn_runner.process(o)
apache_beam/runners/common.py:1503: in apache_beam.runners.common.DoFnRunner.process
    self._reraise_augmented(exn, windowed_value)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

>   self._maybe_sample_exception(exc_info, windowed_value)
E   TypeError: Argument 'exn' has incorrect type (expected BaseException, got tuple)

apache_beam/runners/common.py:1611: TypeError

During handling of the above exception, another exception occurred:

self = <apache_beam.examples.snippets.snippets_test.TypeHintsTest testMethod=test_runtime_checks_on>

    def test_runtime_checks_on(self):
      # pylint: disable=expression-not-assigned
      with self.assertRaises(typehints.TypeCheckError):
        # [START type_hints_runtime_on]
        p = TestPipeline(options=PipelineOptions(runtime_type_check=True))
        p | beam.Create(['a']) | beam.Map(lambda x: 3).with_output_types(str)
>       p.run()

apache_beam/examples/snippets/snippets_test.py:446: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/testing/test_pipeline.py:115: in run
    result = super().run(
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/pipeline.py:594: in run
    return self.runner.run_pipeline(self, self._options)
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/direct/direct_runner.py:184: in run_pipeline
    return runner.run_pipeline(pipeline, options)
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:195: in run_pipeline
    self._latest_run_result = self.run_via_runner_api(
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:221: in run_via_runner_api
    return self.run_stages(stage_context, stages)
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:468: in run_stages
    bundle_results = self._execute_bundle(
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:793: in _execute_bundle
    self._run_bundle(
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:1032: in _run_bundle
    result, splits = bundle_manager.process_bundle(
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:1358: in process_bundle
    result_future = self._worker_handler.control_conn.push(process_bundle_req)
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/portability/fn_api_runner/worker_handlers.py:386: in push
    response = self.worker.do_instruction(request)
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/worker/sdk_worker.py:656: in do_instruction
    return getattr(self, request_type)(
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/worker/sdk_worker.py:694: in process_bundle
    bundle_processor.process_bundle(instruction_id))
target/.tox-py311-cloud/py311-cloud/lib/python3.11/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-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/worker/bundle_processor.py:237: in process_encoded
    self.output(decoded_value)
apache_beam/runners/worker/operations.py:567: in apache_beam.runners.worker.operations.Operation.output
    def output(self, windowed_value, output_index=0):
apache_beam/runners/worker/operations.py:569: in apache_beam.runners.worker.operations.Operation.output
    _cast_to_receiver(self.receivers[output_index]).receive(windowed_value)
apache_beam/runners/worker/operations.py:260: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    def receive(self, windowed_value):
apache_beam/runners/worker/operations.py:263: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    self.consumer.process(windowed_value)
apache_beam/runners/worker/operations.py:950: in apache_beam.runners.worker.operations.DoOperation.process
    with self.scoped_process_state:
apache_beam/runners/worker/operations.py:951: in apache_beam.runners.worker.operations.DoOperation.process
    delayed_applications = self.dofn_runner.process(o)
apache_beam/runners/common.py:1503: in apache_beam.runners.common.DoFnRunner.process
    self._reraise_augmented(exn, windowed_value)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

>   self._maybe_sample_exception(exc_info, windowed_value)
E   TypeError: Argument 'exn' has incorrect type (expected BaseException, got tuple)

apache_beam/runners/common.py:1611: TypeError

Check notice on line 0 in .github

See this annotation in the file changed.

@github-actions 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

See this annotation in the file changed.

@github-actions github-actions / Test Results

256 tests found

There are 256 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.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