Use proper coders in interactive cache. #26870
GitHub Actions / Test Results
failed
Aug 27, 2024 in 0s
1 fail, 46 skipped, 207 pass in 1m 28s
4 files + 4 4 suites +4 1m 28s ⏱️ + 1m 28s
254 tests +254 207 ✅ +207 46 💤 + 46 1 ❌ +1
511 runs +511 408 ✅ +408 102 💤 +102 1 ❌ +1
Results for commit f8bda18. ± Comparison against earlier commit 10ddfbc2.
Annotations
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 0s]
Raw output
google.api_core.exceptions.ServiceUnavailable: 503 The service is currently unavailable. [while running 'Enrich W/ Vertex AI/Enrichment-RRIO/_Call/ParDo(_CallDoFn)']
args = (feature_view: "projects/apache-beam-testing/locations/us-central1/featureOnlineStores/vertexai_enrichment_example/featureViews/users"
data_key {
key: "21422"
}
data_format: PROTO_STRUCT
,)
kwargs = {'metadata': [('x-goog-request-params', 'feature_view=projects/apache-beam-testing/locations/us-central1/featureOnline...richment_example/featureViews/users'), ('x-goog-api-client', 'gl-python/3.10.14 grpc/1.66.0 gax/2.19.1 gapic/1.63.0')]}
@functools.wraps(callable_)
def error_remapped_callable(*args, **kwargs):
try:
> return callable_(*args, **kwargs)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/google/api_core/grpc_helpers.py:76:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/grpc/_channel.py:1181: in __call__
return _end_unary_response_blocking(state, call, False, None)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
state = <grpc._channel._RPCState object at 0x7e132f759c30>
call = <grpc._cython.cygrpc.SegregatedCall object at 0x7e132f81c540>
with_call = False, deadline = None
def _end_unary_response_blocking(
state: _RPCState,
call: cygrpc.SegregatedCall,
with_call: bool,
deadline: Optional[float],
) -> Union[ResponseType, Tuple[ResponseType, grpc.Call]]:
if state.code is grpc.StatusCode.OK:
if with_call:
rendezvous = _MultiThreadedRendezvous(state, call, None, deadline)
return state.response, rendezvous
else:
return state.response
else:
> raise _InactiveRpcError(state) # pytype: disable=not-instantiable
E grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
E status = StatusCode.UNAVAILABLE
E details = "The service is currently unavailable."
E debug_error_string = "UNKNOWN:Error received from peer ipv4:209.85.200.95:443 {grpc_message:"The service is currently unavailable.", grpc_status:14, created_time:"2024-08-27T17:04:15.666165611+00:00"}"
E >
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/grpc/_channel.py:1006: _InactiveRpcError
The above exception was the direct cause of the following exception:
> return self.do_fn_invoker.invoke_process(windowed_value)
apache_beam/runners/common.py:1495:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
apache_beam/runners/common.py:687: in apache_beam.runners.common.SimpleInvoker.invoke_process
self.output_handler.handle_process_outputs(
apache_beam/runners/common.py:1671: in apache_beam.runners.common._OutputHandler.handle_process_outputs
for result in results:
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/io/requestresponse.py:379: in process
raise e
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/io/requestresponse.py:373: in process
response = self._repeater.repeat(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/utils/retry.py:298: in wrapper
return fun(*args, **kwargs)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/io/requestresponse.py:244: in repeat
return _execute_request(caller, request, timeout, metrics_collector)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/io/requestresponse.py:194: in _execute_request
return future.result(timeout=timeout)
/opt/hostedtoolcache/Python/3.10.14/x64/lib/python3.10/concurrent/futures/_base.py:458: in result
return self.__get_result()
/opt/hostedtoolcache/Python/3.10.14/x64/lib/python3.10/concurrent/futures/_base.py:403: in __get_result
raise self._exception
/opt/hostedtoolcache/Python/3.10.14/x64/lib/python3.10/concurrent/futures/thread.py:58: in run
result = self.fn(*self.args, **self.kwargs)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/transforms/enrichment_handlers/vertex_ai_feature_store.py:165: in __call__
response = self.client.fetch_feature_values(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/google/cloud/aiplatform_v1/services/feature_online_store_service/client.py:805: in fetch_feature_values
response = rpc(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/google/api_core/gapic_v1/method.py:131: in __call__
return wrapped_func(*args, **kwargs)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
args = (feature_view: "projects/apache-beam-testing/locations/us-central1/featureOnlineStores/vertexai_enrichment_example/featureViews/users"
data_key {
key: "21422"
}
data_format: PROTO_STRUCT
,)
kwargs = {'metadata': [('x-goog-request-params', 'feature_view=projects/apache-beam-testing/locations/us-central1/featureOnline...richment_example/featureViews/users'), ('x-goog-api-client', 'gl-python/3.10.14 grpc/1.66.0 gax/2.19.1 gapic/1.63.0')]}
@functools.wraps(callable_)
def error_remapped_callable(*args, **kwargs):
try:
return callable_(*args, **kwargs)
except grpc.RpcError as exc:
> raise exceptions.from_grpc_error(exc) from exc
E google.api_core.exceptions.ServiceUnavailable: 503 The service is currently unavailable.
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/google/api_core/grpc_helpers.py:78: ServiceUnavailable
During handling of the above exception, another exception occurred:
self = <apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest testMethod=test_enrichment_with_vertex_ai>
mock_stdout = <_io.StringIO object at 0x7e132fa1aa70>
def test_enrichment_with_vertex_ai(self, mock_stdout):
> enrichment_with_vertex_ai()
apache_beam/examples/snippets/transforms/elementwise/enrichment_test.py:72:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/examples/snippets/transforms/elementwise/enrichment.py:78: in enrichment_with_vertex_ai
with beam.Pipeline() as p:
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/pipeline.py:620: in __exit__
self.result = self.run()
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/pipeline.py:594: 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:128: 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:195: 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:221: 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:468: 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:793: 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:1032: 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:1358: 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:384: 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:656: 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:694: 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:1119: 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: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:1497: in apache_beam.runners.common.DoFnRunner.process
self._reraise_augmented(exn, windowed_value)
apache_beam/runners/common.py:1586: in apache_beam.runners.common.DoFnRunner._reraise_augmented
raise 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:687: in apache_beam.runners.common.SimpleInvoker.invoke_process
self.output_handler.handle_process_outputs(
apache_beam/runners/common.py:1681: in apache_beam.runners.common._OutputHandler.handle_process_outputs
self._write_value_to_tag(tag, windowed_value, watermark_estimator)
apache_beam/runners/common.py:1794: 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:1497: in apache_beam.runners.common.DoFnRunner.process
self._reraise_augmented(exn, windowed_value)
apache_beam/runners/common.py:1586: in apache_beam.runners.common.DoFnRunner._reraise_augmented
raise 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:687: in apache_beam.runners.common.SimpleInvoker.invoke_process
self.output_handler.handle_process_outputs(
apache_beam/runners/common.py:1681: in apache_beam.runners.common._OutputHandler.handle_process_outputs
self._write_value_to_tag(tag, windowed_value, watermark_estimator)
apache_beam/runners/common.py:1794: 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:1497: in apache_beam.runners.common.DoFnRunner.process
self._reraise_augmented(exn, windowed_value)
apache_beam/runners/common.py:1586: in apache_beam.runners.common.DoFnRunner._reraise_augmented
raise 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:687: in apache_beam.runners.common.SimpleInvoker.invoke_process
self.output_handler.handle_process_outputs(
apache_beam/runners/common.py:1681: in apache_beam.runners.common._OutputHandler.handle_process_outputs
self._write_value_to_tag(tag, windowed_value, watermark_estimator)
apache_beam/runners/common.py:1794: 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:1497: in apache_beam.runners.common.DoFnRunner.process
self._reraise_augmented(exn, windowed_value)
apache_beam/runners/common.py:1607: 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:687: in apache_beam.runners.common.SimpleInvoker.invoke_process
self.output_handler.handle_process_outputs(
apache_beam/runners/common.py:1671: in apache_beam.runners.common._OutputHandler.handle_process_outputs
for result in results:
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/io/requestresponse.py:379: in process
raise e
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/io/requestresponse.py:373: in process
response = self._repeater.repeat(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/utils/retry.py:298: in wrapper
return fun(*args, **kwargs)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/io/requestresponse.py:244: in repeat
return _execute_request(caller, request, timeout, metrics_collector)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/io/requestresponse.py:194: in _execute_request
return future.result(timeout=timeout)
/opt/hostedtoolcache/Python/3.10.14/x64/lib/python3.10/concurrent/futures/_base.py:458: in result
return self.__get_result()
/opt/hostedtoolcache/Python/3.10.14/x64/lib/python3.10/concurrent/futures/_base.py:403: in __get_result
raise self._exception
/opt/hostedtoolcache/Python/3.10.14/x64/lib/python3.10/concurrent/futures/thread.py:58: in run
result = self.fn(*self.args, **self.kwargs)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/transforms/enrichment_handlers/vertex_ai_feature_store.py:165: in __call__
response = self.client.fetch_feature_values(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/google/cloud/aiplatform_v1/services/feature_online_store_service/client.py:805: in fetch_feature_values
response = rpc(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/google/api_core/gapic_v1/method.py:131: in __call__
return wrapped_func(*args, **kwargs)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
args = (feature_view: "projects/apache-beam-testing/locations/us-central1/featureOnlineStores/vertexai_enrichment_example/featureViews/users"
data_key {
key: "21422"
}
data_format: PROTO_STRUCT
,)
kwargs = {'metadata': [('x-goog-request-params', 'feature_view=projects/apache-beam-testing/locations/us-central1/featureOnline...richment_example/featureViews/users'), ('x-goog-api-client', 'gl-python/3.10.14 grpc/1.66.0 gax/2.19.1 gapic/1.63.0')]}
@functools.wraps(callable_)
def error_remapped_callable(*args, **kwargs):
try:
return callable_(*args, **kwargs)
except grpc.RpcError as exc:
> raise exceptions.from_grpc_error(exc) from exc
E google.api_core.exceptions.ServiceUnavailable: 503 The service is currently unavailable. [while running 'Enrich W/ Vertex AI/Enrichment-RRIO/_Call/ParDo(_CallDoFn)']
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/google/api_core/grpc_helpers.py:78: ServiceUnavailable
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
254 tests found
There are 254 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_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
Loading