GitHub Actions / Test Results
failed
Nov 10, 2025 in 0s
1 fail, 46 skipped, 270 pass in 4m 20s
4 files 4 suites 4m 20s ⏱️
317 tests 270 ✅ 46 💤 1 ❌
632 runs 529 ✅ 102 💤 1 ❌
Results for commit 029fc7a.
Annotations
github-actions / Test Results
test_enrichment_with_vertex_ai_legacy (apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest) failed
sdks/python/test-suites/tox/py311/build/srcs/sdks/python/pytest_py311-cloud.xml [took 1s]
Raw output
RuntimeError: Pipeline job-030 failed in state FAILED: bundle inst002 stage-005 failed:Traceback (most recent call last):
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/google/api_core/grpc_helpers.py", line 75, in error_remapped_callable
return callable_(*args, **kwargs)
^^^^^^^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/grpc/_interceptor.py", line 277, in __call__
response, ignored_call = self._with_call(
^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/grpc/_interceptor.py", line 332, in _with_call
return call.result(), call
^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/grpc/_channel.py", line 440, in result
raise self
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/grpc/_interceptor.py", line 315, in continuation
response, call = self._thunk(new_method).with_call(
^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/grpc/_channel.py", line 1198, in with_call
return _end_unary_response_blocking(state, call, True, None)
^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/grpc/_channel.py", line 1006, in _end_unary_response_blocking
raise _InactiveRpcError(state) # pytype: disable=not-instantiable
^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
status = StatusCode.UNAVAILABLE
details = "Request 'ReadFeatureValues' from role 'untrusted-http-proxy' throttled: Task is overloaded (memory-protection) go/tr-t (throttled by /bns/jv/borg/jv/bns/cloud-ml-featurestore/prod-us-central1.featurestore/0)."
debug_error_string = "UNKNOWN:Error received from peer {created_time:"2025-11-10T18:06:22.264376177+00:00", grpc_status:14, grpc_message:"Request \'ReadFeatureValues\' from role \'untrusted-http-proxy\' throttled: Task is overloaded (memory-protection) go/tr-t (throttled by /bns/jv/borg/jv/bns/cloud-ml-featurestore/prod-us-central1.featurestore/0)."}"
>
The above exception was the direct cause of the following exception:
Traceback (most recent call last):
File "apache_beam/runners/common.py", line 1498, in apache_beam.runners.common.DoFnRunner.process
return self.do_fn_invoker.invoke_process(windowed_value)
File "apache_beam/runners/common.py", line 684, in apache_beam.runners.common.SimpleInvoker.invoke_process
self.output_handler.handle_process_outputs(
File "apache_beam/runners/common.py", line 1673, in apache_beam.runners.common._OutputHandler.handle_process_outputs
for result in results:
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/io/requestresponse.py", line 380, in process
raise e
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/io/requestresponse.py", line 374, in process
response = self._repeater.repeat(
^^^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/utils/retry.py", line 300, in wrapper
return fun(*args, **kwargs)
^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/io/requestresponse.py", line 245, in repeat
return _execute_request(caller, request, timeout, metrics_collector)
^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/io/requestresponse.py", line 195, in _execute_request
return future.result(timeout=timeout)
^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
File "/opt/hostedtoolcache/Python/3.11.12/x64/lib/python3.11/concurrent/futures/_base.py", line 456, in result
return self.__get_result()
^^^^^^^^^^^^^^^^^^^
File "/opt/hostedtoolcache/Python/3.11.12/x64/lib/python3.11/concurrent/futures/_base.py", line 401, in __get_result
raise self._exception
File "/opt/hostedtoolcache/Python/3.11.12/x64/lib/python3.11/concurrent/futures/thread.py", line 58, in run
result = self.fn(*self.args, **self.kwargs)
^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/transforms/enrichment_handlers/vertex_ai_feature_store.py", line 296, in __call__
response = self.client.read_feature_values(
^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/google/cloud/aiplatform_v1/services/featurestore_online_serving_service/client.py", line 901, in read_feature_values
response = rpc(
^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/google/api_core/gapic_v1/method.py", line 131, in __call__
return wrapped_func(*args, **kwargs)
^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/google/api_core/grpc_helpers.py", line 77, in error_remapped_callable
raise exceptions.from_grpc_error(exc) from exc
google.api_core.exceptions.ServiceUnavailable: 503 Request 'ReadFeatureValues' from role 'untrusted-http-proxy' throttled: Task is overloaded (memory-protection) go/tr-t (throttled by /bns/jv/borg/jv/bns/cloud-ml-featurestore/prod-us-central1.featurestore/0). [type_url: "type.googleapis.com/util.StatusProto"
value: "\010\002\022\nthrottling\032\320\001Request 'ReadFeatureValues' from role 'untrusted-http-proxy' throttled: Task is overloaded (memory-protection) go/tr-t (throttled by /bns/jv/borg/jv/bns/cloud-ml-featurestore/prod-us-central1.featurestore/0).0\016"
]
During handling of the above exception, another exception occurred:
Traceback (most recent call last):
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/worker/sdk_worker.py", line 316, in _execute
response = task()
^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/worker/sdk_worker.py", line 390, in <lambda>
lambda: self.create_worker().do_instruction(request), request)
^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/worker/sdk_worker.py", line 669, in do_instruction
return getattr(self, request_type)(
^^^^^^^^^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/worker/sdk_worker.py", line 707, in process_bundle
bundle_processor.process_bundle(instruction_id))
^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1300, in process_bundle
input_op_by_transform_id[element.transform_id].process_encoded(
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/worker/bundle_processor.py", line 240, in process_encoded
self.output(decoded_value)
File "apache_beam/runners/worker/operations.py", line 568, in apache_beam.runners.worker.operations.Operation.output
def output(self, windowed_value, output_index=0):
File "apache_beam/runners/worker/operations.py", line 570, in apache_beam.runners.worker.operations.Operation.output
_cast_to_receiver(self.receivers[output_index]).receive(windowed_value)
File "apache_beam/runners/worker/operations.py", line 260, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
def receive(self, windowed_value):
File "apache_beam/runners/worker/operations.py", line 263, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
self.consumer.process(windowed_value)
File "apache_beam/runners/worker/operations.py", line 951, in apache_beam.runners.worker.operations.DoOperation.process
with self.scoped_process_state:
File "apache_beam/runners/worker/operations.py", line 952, in apache_beam.runners.worker.operations.DoOperation.process
delayed_applications = self.dofn_runner.process(o)
File "apache_beam/runners/common.py", line 1500, in apache_beam.runners.common.DoFnRunner.process
self._reraise_augmented(exn, windowed_value)
File "apache_beam/runners/common.py", line 1588, in apache_beam.runners.common.DoFnRunner._reraise_augmented
raise exn
File "apache_beam/runners/common.py", line 1498, in apache_beam.runners.common.DoFnRunner.process
return self.do_fn_invoker.invoke_process(windowed_value)
File "apache_beam/runners/common.py", line 684, in apache_beam.runners.common.SimpleInvoker.invoke_process
self.output_handler.handle_process_outputs(
File "apache_beam/runners/common.py", line 1683, in apache_beam.runners.common._OutputHandler.handle_process_outputs
self._write_value_to_tag(tag, windowed_value, watermark_estimator)
File "apache_beam/runners/common.py", line 1796, in apache_beam.runners.common._OutputHandler._write_value_to_tag
self.main_receivers.receive(windowed_value)
File "apache_beam/runners/worker/operations.py", line 263, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
self.consumer.process(windowed_value)
File "apache_beam/runners/worker/operations.py", line 951, in apache_beam.runners.worker.operations.DoOperation.process
with self.scoped_process_state:
File "apache_beam/runners/worker/operations.py", line 952, in apache_beam.runners.worker.operations.DoOperation.process
delayed_applications = self.dofn_runner.process(o)
File "apache_beam/runners/common.py", line 1500, in apache_beam.runners.common.DoFnRunner.process
self._reraise_augmented(exn, windowed_value)
File "apache_beam/runners/common.py", line 1609, in apache_beam.runners.common.DoFnRunner._reraise_augmented
raise new_exn
File "apache_beam/runners/common.py", line 1498, in apache_beam.runners.common.DoFnRunner.process
return self.do_fn_invoker.invoke_process(windowed_value)
File "apache_beam/runners/common.py", line 684, in apache_beam.runners.common.SimpleInvoker.invoke_process
self.output_handler.handle_process_outputs(
File "apache_beam/runners/common.py", line 1673, in apache_beam.runners.common._OutputHandler.handle_process_outputs
for result in results:
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/io/requestresponse.py", line 380, in process
raise e
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/io/requestresponse.py", line 374, in process
response = self._repeater.repeat(
^^^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/utils/retry.py", line 300, in wrapper
return fun(*args, **kwargs)
^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/io/requestresponse.py", line 245, in repeat
return _execute_request(caller, request, timeout, metrics_collector)
^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/io/requestresponse.py", line 195, in _execute_request
return future.result(timeout=timeout)
^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
File "/opt/hostedtoolcache/Python/3.11.12/x64/lib/python3.11/concurrent/futures/_base.py", line 456, in result
return self.__get_result()
^^^^^^^^^^^^^^^^^^^
File "/opt/hostedtoolcache/Python/3.11.12/x64/lib/python3.11/concurrent/futures/_base.py", line 401, in __get_result
raise self._exception
File "/opt/hostedtoolcache/Python/3.11.12/x64/lib/python3.11/concurrent/futures/thread.py", line 58, in run
result = self.fn(*self.args, **self.kwargs)
^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/transforms/enrichment_handlers/vertex_ai_feature_store.py", line 296, in __call__
response = self.client.read_feature_values(
^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/google/cloud/aiplatform_v1/services/featurestore_online_serving_service/client.py", line 901, in read_feature_values
response = rpc(
^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/google/api_core/gapic_v1/method.py", line 131, in __call__
return wrapped_func(*args, **kwargs)
^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/google/api_core/grpc_helpers.py", line 77, in error_remapped_callable
raise exceptions.from_grpc_error(exc) from exc
google.api_core.exceptions.ServiceUnavailable: 503 Request 'ReadFeatureValues' from role 'untrusted-http-proxy' throttled: Task is overloaded (memory-protection) go/tr-t (throttled by /bns/jv/borg/jv/bns/cloud-ml-featurestore/prod-us-central1.featurestore/0). [while running 'Enrich W/ Vertex AI/Enrichment-RRIO/_Call/ParDo(_CallDoFn)']
self = <apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest testMethod=test_enrichment_with_vertex_ai_legacy>
mock_stdout = <_io.StringIO object at 0x7cbd5c766e60>
def test_enrichment_with_vertex_ai_legacy(self, mock_stdout):
> enrichment_with_vertex_ai_legacy()
apache_beam/examples/snippets/transforms/elementwise/enrichment_test.py:161:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
apache_beam/examples/snippets/transforms/elementwise/enrichment.py:112: in enrichment_with_vertex_ai_legacy
with beam.Pipeline() as p:
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/pipeline.py:673: in __exit__
self.result.wait_until_finish()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
self = <apache_beam.runners.portability.portable_runner.PipelineResult object at 0x7cbcd91dfd50>
duration = None
def wait_until_finish(self, duration=None):
"""
:param duration: The maximum time in milliseconds to wait for the result of
the execution. If None or zero, will wait until the pipeline finishes.
:return: The result of the pipeline, i.e. PipelineResult.
"""
last_error_text = None
def read_messages() -> None:
nonlocal last_error_text
previous_state = -1
for message in self._message_stream:
if message.HasField('message_response'):
mr = message.message_response
logging.log(MESSAGE_LOG_LEVELS[mr.importance], "%s", mr.message_text)
if mr.importance == beam_job_api_pb2.JobMessage.JOB_MESSAGE_ERROR:
last_error_text = mr.message_text
else:
current_state = message.state_response.state
if current_state != previous_state:
_LOGGER.info(
"Job state changed to %s",
self.runner_api_state_to_pipeline_state(current_state))
previous_state = current_state
self._messages.append(message)
message_thread = threading.Thread(
target=read_messages, name='wait_until_finish_read')
message_thread.daemon = True
message_thread.start()
if duration:
state_thread = threading.Thread(
target=functools.partial(self._observe_state, message_thread),
name='wait_until_finish_state_observer')
state_thread.daemon = True
state_thread.start()
start_time = time.time()
duration_secs = duration / 1000
while (time.time() - start_time < duration_secs and
state_thread.is_alive()):
time.sleep(1)
else:
self._observe_state(message_thread)
if self._runtime_exception:
> raise self._runtime_exception
E RuntimeError: Pipeline job-030 failed in state FAILED: bundle inst002 stage-005 failed:Traceback (most recent call last):
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/google/api_core/grpc_helpers.py", line 75, in error_remapped_callable
E return callable_(*args, **kwargs)
E ^^^^^^^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/grpc/_interceptor.py", line 277, in __call__
E response, ignored_call = self._with_call(
E ^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/grpc/_interceptor.py", line 332, in _with_call
E return call.result(), call
E ^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/grpc/_channel.py", line 440, in result
E raise self
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/grpc/_interceptor.py", line 315, in continuation
E response, call = self._thunk(new_method).with_call(
E ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/grpc/_channel.py", line 1198, in with_call
E return _end_unary_response_blocking(state, call, True, None)
E ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/grpc/_channel.py", line 1006, in _end_unary_response_blocking
E raise _InactiveRpcError(state) # pytype: disable=not-instantiable
E ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
E grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
E status = StatusCode.UNAVAILABLE
E details = "Request 'ReadFeatureValues' from role 'untrusted-http-proxy' throttled: Task is overloaded (memory-protection) go/tr-t (throttled by /bns/jv/borg/jv/bns/cloud-ml-featurestore/prod-us-central1.featurestore/0)."
E debug_error_string = "UNKNOWN:Error received from peer {created_time:"2025-11-10T18:06:22.264376177+00:00", grpc_status:14, grpc_message:"Request \'ReadFeatureValues\' from role \'untrusted-http-proxy\' throttled: Task is overloaded (memory-protection) go/tr-t (throttled by /bns/jv/borg/jv/bns/cloud-ml-featurestore/prod-us-central1.featurestore/0)."}"
E >
E
E The above exception was the direct cause of the following exception:
E
E Traceback (most recent call last):
E File "apache_beam/runners/common.py", line 1498, in apache_beam.runners.common.DoFnRunner.process
E return self.do_fn_invoker.invoke_process(windowed_value)
E File "apache_beam/runners/common.py", line 684, in apache_beam.runners.common.SimpleInvoker.invoke_process
E self.output_handler.handle_process_outputs(
E File "apache_beam/runners/common.py", line 1673, in apache_beam.runners.common._OutputHandler.handle_process_outputs
E for result in results:
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/io/requestresponse.py", line 380, in process
E raise e
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/io/requestresponse.py", line 374, in process
E response = self._repeater.repeat(
E ^^^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/utils/retry.py", line 300, in wrapper
E return fun(*args, **kwargs)
E ^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/io/requestresponse.py", line 245, in repeat
E return _execute_request(caller, request, timeout, metrics_collector)
E ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/io/requestresponse.py", line 195, in _execute_request
E return future.result(timeout=timeout)
E ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
E File "/opt/hostedtoolcache/Python/3.11.12/x64/lib/python3.11/concurrent/futures/_base.py", line 456, in result
E return self.__get_result()
E ^^^^^^^^^^^^^^^^^^^
E File "/opt/hostedtoolcache/Python/3.11.12/x64/lib/python3.11/concurrent/futures/_base.py", line 401, in __get_result
E raise self._exception
E File "/opt/hostedtoolcache/Python/3.11.12/x64/lib/python3.11/concurrent/futures/thread.py", line 58, in run
E result = self.fn(*self.args, **self.kwargs)
E ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/transforms/enrichment_handlers/vertex_ai_feature_store.py", line 296, in __call__
E response = self.client.read_feature_values(
E ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/google/cloud/aiplatform_v1/services/featurestore_online_serving_service/client.py", line 901, in read_feature_values
E response = rpc(
E ^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/google/api_core/gapic_v1/method.py", line 131, in __call__
E return wrapped_func(*args, **kwargs)
E ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/google/api_core/grpc_helpers.py", line 77, in error_remapped_callable
E raise exceptions.from_grpc_error(exc) from exc
E google.api_core.exceptions.ServiceUnavailable: 503 Request 'ReadFeatureValues' from role 'untrusted-http-proxy' throttled: Task is overloaded (memory-protection) go/tr-t (throttled by /bns/jv/borg/jv/bns/cloud-ml-featurestore/prod-us-central1.featurestore/0). [type_url: "type.googleapis.com/util.StatusProto"
E value: "\010\002\022\nthrottling\032\320\001Request 'ReadFeatureValues' from role 'untrusted-http-proxy' throttled: Task is overloaded (memory-protection) go/tr-t (throttled by /bns/jv/borg/jv/bns/cloud-ml-featurestore/prod-us-central1.featurestore/0).0\016"
E ]
E
E During handling of the above exception, another exception occurred:
E
E Traceback (most recent call last):
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/worker/sdk_worker.py", line 316, in _execute
E response = task()
E ^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/worker/sdk_worker.py", line 390, in <lambda>
E lambda: self.create_worker().do_instruction(request), request)
E ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/worker/sdk_worker.py", line 669, in do_instruction
E return getattr(self, request_type)(
E ^^^^^^^^^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/worker/sdk_worker.py", line 707, in process_bundle
E bundle_processor.process_bundle(instruction_id))
E ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1300, in process_bundle
E input_op_by_transform_id[element.transform_id].process_encoded(
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/worker/bundle_processor.py", line 240, in process_encoded
E self.output(decoded_value)
E File "apache_beam/runners/worker/operations.py", line 568, in apache_beam.runners.worker.operations.Operation.output
E def output(self, windowed_value, output_index=0):
E File "apache_beam/runners/worker/operations.py", line 570, in apache_beam.runners.worker.operations.Operation.output
E _cast_to_receiver(self.receivers[output_index]).receive(windowed_value)
E File "apache_beam/runners/worker/operations.py", line 260, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
E def receive(self, windowed_value):
E File "apache_beam/runners/worker/operations.py", line 263, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
E self.consumer.process(windowed_value)
E File "apache_beam/runners/worker/operations.py", line 951, in apache_beam.runners.worker.operations.DoOperation.process
E with self.scoped_process_state:
E File "apache_beam/runners/worker/operations.py", line 952, in apache_beam.runners.worker.operations.DoOperation.process
E delayed_applications = self.dofn_runner.process(o)
E File "apache_beam/runners/common.py", line 1500, in apache_beam.runners.common.DoFnRunner.process
E self._reraise_augmented(exn, windowed_value)
E File "apache_beam/runners/common.py", line 1588, in apache_beam.runners.common.DoFnRunner._reraise_augmented
E raise exn
E File "apache_beam/runners/common.py", line 1498, in apache_beam.runners.common.DoFnRunner.process
E return self.do_fn_invoker.invoke_process(windowed_value)
E File "apache_beam/runners/common.py", line 684, in apache_beam.runners.common.SimpleInvoker.invoke_process
E self.output_handler.handle_process_outputs(
E File "apache_beam/runners/common.py", line 1683, in apache_beam.runners.common._OutputHandler.handle_process_outputs
E self._write_value_to_tag(tag, windowed_value, watermark_estimator)
E File "apache_beam/runners/common.py", line 1796, in apache_beam.runners.common._OutputHandler._write_value_to_tag
E self.main_receivers.receive(windowed_value)
E File "apache_beam/runners/worker/operations.py", line 263, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
E self.consumer.process(windowed_value)
E File "apache_beam/runners/worker/operations.py", line 951, in apache_beam.runners.worker.operations.DoOperation.process
E with self.scoped_process_state:
E File "apache_beam/runners/worker/operations.py", line 952, in apache_beam.runners.worker.operations.DoOperation.process
E delayed_applications = self.dofn_runner.process(o)
E File "apache_beam/runners/common.py", line 1500, in apache_beam.runners.common.DoFnRunner.process
E self._reraise_augmented(exn, windowed_value)
E File "apache_beam/runners/common.py", line 1609, in apache_beam.runners.common.DoFnRunner._reraise_augmented
E raise new_exn
E File "apache_beam/runners/common.py", line 1498, in apache_beam.runners.common.DoFnRunner.process
E return self.do_fn_invoker.invoke_process(windowed_value)
E File "apache_beam/runners/common.py", line 684, in apache_beam.runners.common.SimpleInvoker.invoke_process
E self.output_handler.handle_process_outputs(
E File "apache_beam/runners/common.py", line 1673, in apache_beam.runners.common._OutputHandler.handle_process_outputs
E for result in results:
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/io/requestresponse.py", line 380, in process
E raise e
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/io/requestresponse.py", line 374, in process
E response = self._repeater.repeat(
E ^^^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/utils/retry.py", line 300, in wrapper
E return fun(*args, **kwargs)
E ^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/io/requestresponse.py", line 245, in repeat
E return _execute_request(caller, request, timeout, metrics_collector)
E ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/io/requestresponse.py", line 195, in _execute_request
E return future.result(timeout=timeout)
E ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
E File "/opt/hostedtoolcache/Python/3.11.12/x64/lib/python3.11/concurrent/futures/_base.py", line 456, in result
E return self.__get_result()
E ^^^^^^^^^^^^^^^^^^^
E File "/opt/hostedtoolcache/Python/3.11.12/x64/lib/python3.11/concurrent/futures/_base.py", line 401, in __get_result
E raise self._exception
E File "/opt/hostedtoolcache/Python/3.11.12/x64/lib/python3.11/concurrent/futures/thread.py", line 58, in run
E result = self.fn(*self.args, **self.kwargs)
E ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/transforms/enrichment_handlers/vertex_ai_feature_store.py", line 296, in __call__
E response = self.client.read_feature_values(
E ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/google/cloud/aiplatform_v1/services/featurestore_online_serving_service/client.py", line 901, in read_feature_values
E response = rpc(
E ^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/google/api_core/gapic_v1/method.py", line 131, in __call__
E return wrapped_func(*args, **kwargs)
E ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
E File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py311/build/srcs/sdks/python/target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/google/api_core/grpc_helpers.py", line 77, in error_remapped_callable
E raise exceptions.from_grpc_error(exc) from exc
E google.api_core.exceptions.ServiceUnavailable: 503 Request 'ReadFeatureValues' from role 'untrusted-http-proxy' throttled: Task is overloaded (memory-protection) go/tr-t (throttled by /bns/jv/borg/jv/bns/cloud-ml-featurestore/prod-us-central1.featurestore/0). [while running 'Enrich W/ Vertex AI/Enrichment-RRIO/_Call/ParDo(_CallDoFn)']
target/.tox-py311-cloud/py311-cloud/lib/python3.11/site-packages/apache_beam/runners/portability/portable_runner.py:571: RuntimeError
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_requirements_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
317 tests found
There are 317 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_requirements_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.cookbook.ordered_window_elements.batch_test.OrderedWindowElementsTest ‑ test_default
apache_beam.examples.cookbook.ordered_window_elements.batch_test.OrderedWindowElementsTest ‑ test_gaps_0
apache_beam.examples.cookbook.ordered_window_elements.batch_test.OrderedWindowElementsTest ‑ test_gaps_1
apache_beam.examples.cookbook.ordered_window_elements.batch_test.OrderedWindowElementsTest ‑ test_gaps_2
apache_beam.examples.cookbook.ordered_window_elements.batch_test.OrderedWindowElementsTest ‑ test_gaps_3
apache_beam.examples.cookbook.ordered_window_elements.batch_test.OrderedWindowElementsTest ‑ test_gaps_4
apache_beam.examples.cookbook.ordered_window_elements.batch_test.OrderedWindowElementsTest ‑ test_gaps_5
apache_beam.examples.cookbook.ordered_window_elements.batch_test.OrderedWindowElementsTest ‑ test_long_slide_0
apache_beam.examples.cookbook.ordered_window_elements.batch_test.OrderedWindowElementsTest ‑ test_long_slide_1
apache_beam.examples.cookbook.ordered_window_elements.batch_test.OrderedWindowElementsTest ‑ test_long_slide_2
apache_beam.examples.cookbook.ordered_window_elements.batch_test.OrderedWindowElementsTest ‑ test_long_slide_3
apache_beam.examples.cookbook.ordered_window_elements.batch_test.OrderedWindowElementsTest ‑ test_long_slide_4
apache_beam.examples.cookbook.ordered_window_elements.batch_test.OrderedWindowElementsTest ‑ test_long_slide_5
apache_beam.examples.cookbook.ordered_window_elements.batch_test.OrderedWindowElementsTest ‑ test_offset
apache_beam.examples.cookbook.ordered_window_elements.batch_test.OrderedWindowElementsTest ‑ test_slide_interval
apache_beam.examples.cookbook.ordered_window_elements.batch_test.OrderedWindowElementsTest ‑ test_timestamp_func
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_0 ‑ test_default
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_0 ‑ test_keyed_input
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_0 ‑ test_multiple_late_data_with_allowed_lateness
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_0 ‑ test_non_zero_offset_and_default_value_0
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_0 ‑ test_non_zero_offset_and_default_value_1
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_0 ‑ test_offset
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_0 ‑ test_ordered_data_with_gap_0
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_0 ‑ test_ordered_data_with_gap_1
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_0 ‑ test_reversed_ordered_data_with_allowed_lateness_0
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_0 ‑ test_reversed_ordered_data_with_allowed_lateness_1
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_0 ‑ test_single_late_data_with_allowed_lateness
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_0 ‑ test_single_late_data_with_no_allowed_lateness
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_0 ‑ test_slide_interval
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_1 ‑ test_default
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_1 ‑ test_keyed_input
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_1 ‑ test_multiple_late_data_with_allowed_lateness
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_1 ‑ test_non_zero_offset_and_default_value_0
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_1 ‑ test_non_zero_offset_and_default_value_1
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_1 ‑ test_offset
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_1 ‑ test_ordered_data_with_gap_0
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_1 ‑ test_ordered_data_with_gap_1
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_1 ‑ test_reversed_ordered_data_with_allowed_lateness_0
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_1 ‑ test_reversed_ordered_data_with_allowed_lateness_1
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_1 ‑ test_single_late_data_with_allowed_lateness
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_1 ‑ test_single_late_data_with_no_allowed_lateness
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_1 ‑ test_slide_interval
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_2 ‑ test_default
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_2 ‑ test_keyed_input
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_2 ‑ test_multiple_late_data_with_allowed_lateness
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_2 ‑ test_non_zero_offset_and_default_value_0
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_2 ‑ test_non_zero_offset_and_default_value_1
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_2 ‑ test_offset
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_2 ‑ test_ordered_data_with_gap_0
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_2 ‑ test_ordered_data_with_gap_1
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_2 ‑ test_reversed_ordered_data_with_allowed_lateness_0
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_2 ‑ test_reversed_ordered_data_with_allowed_lateness_1
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_2 ‑ test_single_late_data_with_allowed_lateness
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_2 ‑ test_single_late_data_with_no_allowed_lateness
apache_beam.examples.cookbook.ordered_window_elements.streaming_test.OrderedWindowElementsTest_2 ‑ test_slide_interval
apache_beam.examples.dataframe.flight_delays_it_test.FlightDelaysTest ‑ test_flight_delays
apache_beam.examples.dataframe.taxiride_it_test.TaxirideIT ‑ test_aggregation
apache_beam.examples.dataframe.taxiride_it_test.TaxirideIT ‑ test_enrich
apache_beam.examples.dataframe.taxiride_test.TaxiRideExampleTest ‑ test_aggregation
apache_beam.examples.dataframe.taxiride_test.TaxiRideExampleTest ‑ test_enrich
apache_beam.examples.dataframe.wordcount_test.WordCountTest ‑ test_basics
apache_beam.examples.fastavro_it_test.FastavroIT ‑ test_avro_it
apache_beam.examples.inference.tfx_bsl.tfx_bsl_inference_it_test.TFXRunInferenceTests ‑ test_tfx_run_inference_mobilenetv2
apache_beam.examples.matrix_power_test.MatrixPowerTest ‑ test_basics
apache_beam.examples.ml_transform.ml_transform_it_test
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_bounded_sum
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_combine_concat
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_combine_per_key
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_combine_reduce
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_combine_values
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_count
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_custom_average
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_global_sum
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_keys
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_setting_fixed_windows
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_setting_global_window
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_setting_session_windows
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_setting_sliding_windows
apache_beam.examples.snippets.snippets_test.CombineTest ‑ test_setting_timestamp
apache_beam.examples.snippets.snippets_test.PTransformTest ‑ test_composite
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_side_input
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_side_input_dofn
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_using_flatmap
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_using_flatmap_yield
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_using_map
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_with_label
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_with_tagged_outputs
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_with_undeclared_outputs
apache_beam.examples.snippets.snippets_test.ParDoTest ‑ test_pardo_yield
apache_beam.examples.snippets.snippets_test.SlowlyChangingSideInputsTest ‑ test_side_input_slow_update
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_construct_pipeline
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_examples_ptransforms_templated
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_examples_wordcount_0
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_examples_wordcount_1
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_examples_wordcount_2
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_examples_wordcount_3
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_examples_wordcount_debugging
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_examples_wordcount_streaming
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_bigqueryio
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_bigqueryio_xlang
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_co_group_by_key_tuple
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_composite_transform_example
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_composite_triggers
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_custom_sink
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_custom_source
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_datastoreio
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_early_late_triggers
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_group_by_key
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_join_using_side_inputs
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_multiple_pcollections_flatten
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_multiple_pcollections_flatten_with
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_multiple_pcollections_flatten_with_transform
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_multiple_pcollections_partition
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_other_composite_triggers
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_pcollection
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_pipelines
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_setting_trigger
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_textio
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_textio_compressed
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_model_use_and_query_metrics
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_pipeline_logging
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_pipeline_options_command_line
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_pipeline_options_local
apache_beam.examples.snippets.snippets_test.SnippetsTest ‑ test_pipeline_options_remote
apache_beam.examples.snippets.snippets_test.TypeHintsTest ‑ test_bad_types
apache_beam.examples.snippets.snippets_test.TypeHintsTest ‑ test_bad_types_annotations
apache_beam.examples.snippets.snippets_test.TypeHintsTest ‑ test_deterministic_key
apache_beam.examples.snippets.snippets_test.TypeHintsTest ‑ test_runtime_checks_off
apache_beam.examples.snippets.snippets_test.TypeHintsTest ‑ test_runtime_checks_on
apache_beam.examples.snippets.snippets_test.ValueProviderInfoTest ‑ test_accessing_valueprovider_info_after_run
apache_beam.examples.snippets.transforms.aggregation.approximatequantiles_test.ApproximateQuantilesTest ‑ test_approximatequantiles
apache_beam.examples.snippets.transforms.aggregation.approximateunique_test.ApproximateUniqueTest ‑ test_approximateunique
apache_beam.examples.snippets.transforms.aggregation.batchelements_test.BatchElementsTest ‑ test_batchelements
apache_beam.examples.snippets.transforms.aggregation.cogroupbykey_test.CoGroupByKeyTest ‑ test_cogroupbykey
apache_beam.examples.snippets.transforms.aggregation.combineglobally_test.CombineGloballyTest ‑ test_combineglobally_combinefn
apache_beam.examples.snippets.transforms.aggregation.combineglobally_test.CombineGloballyTest ‑ test_combineglobally_function
apache_beam.examples.snippets.transforms.aggregation.combineglobally_test.CombineGloballyTest ‑ test_combineglobally_lambda
apache_beam.examples.snippets.transforms.aggregation.combineglobally_test.CombineGloballyTest ‑ test_combineglobally_multiple_arguments
apache_beam.examples.snippets.transforms.aggregation.combineglobally_test.CombineGloballyTest ‑ test_combineglobally_side_inputs_singleton
apache_beam.examples.snippets.transforms.aggregation.combineperkey_test.CombinePerKeyTest ‑ test_combineperkey_combinefn
apache_beam.examples.snippets.transforms.aggregation.combineperkey_test.CombinePerKeyTest ‑ test_combineperkey_function
apache_beam.examples.snippets.transforms.aggregation.combineperkey_test.CombinePerKeyTest ‑ test_combineperkey_lambda
apache_beam.examples.snippets.transforms.aggregation.combineperkey_test.CombinePerKeyTest ‑ test_combineperkey_multiple_arguments
apache_beam.examples.snippets.transforms.aggregation.combineperkey_test.CombinePerKeyTest ‑ test_combineperkey_side_inputs_dict
apache_beam.examples.snippets.transforms.aggregation.combineperkey_test.CombinePerKeyTest ‑ test_combineperkey_side_inputs_iter
apache_beam.examples.snippets.transforms.aggregation.combineperkey_test.CombinePerKeyTest ‑ test_combineperkey_side_inputs_singleton
apache_beam.examples.snippets.transforms.aggregation.combineperkey_test.CombinePerKeyTest ‑ test_combineperkey_simple
apache_beam.examples.snippets.transforms.aggregation.combinevalues_test.CombineValuesTest ‑ test_combinevalues_combinefn
apache_beam.examples.snippets.transforms.aggregation.combinevalues_test.CombineValuesTest ‑ test_combinevalues_function
apache_beam.examples.snippets.transforms.aggregation.combinevalues_test.CombineValuesTest ‑ test_combinevalues_lambda
apache_beam.examples.snippets.transforms.aggregation.combinevalues_test.CombineValuesTest ‑ test_combinevalues_multiple_arguments
apache_beam.examples.snippets.transforms.aggregation.combinevalues_test.CombineValuesTest ‑ test_combinevalues_side_inputs_dict
apache_beam.examples.snippets.transforms.aggregation.combinevalues_test.CombineValuesTest ‑ test_combinevalues_side_inputs_iter
apache_beam.examples.snippets.transforms.aggregation.combinevalues_test.CombineValuesTest ‑ test_combinevalues_side_inputs_singleton
apache_beam.examples.snippets.transforms.aggregation.count_test.CountTest ‑ test_count_globally
apache_beam.examples.snippets.transforms.aggregation.count_test.CountTest ‑ test_count_per_element
apache_beam.examples.snippets.transforms.aggregation.count_test.CountTest ‑ test_count_per_key
apache_beam.examples.snippets.transforms.aggregation.distinct_test.DistinctTest ‑ test_distinct
apache_beam.examples.snippets.transforms.aggregation.groupby_test.GroupByTest ‑ test_expr_aggregate
apache_beam.examples.snippets.transforms.aggregation.groupby_test.GroupByTest ‑ test_global_aggregate
apache_beam.examples.snippets.transforms.aggregation.groupby_test.GroupByTest ‑ test_group_by_attr
apache_beam.examples.snippets.transforms.aggregation.groupby_test.GroupByTest ‑ test_group_by_attr_expr
apache_beam.examples.snippets.transforms.aggregation.groupby_test.GroupByTest ‑ test_groupby_expr
apache_beam.examples.snippets.transforms.aggregation.groupby_test.GroupByTest ‑ test_groupby_two_exprs
apache_beam.examples.snippets.transforms.aggregation.groupby_test.GroupByTest ‑ test_simple_aggregate
apache_beam.examples.snippets.transforms.aggregation.groupbykey_test.GroupByKeyTest ‑ test_groupbykey
apache_beam.examples.snippets.transforms.aggregation.groupintobatches_test.GroupIntoBatchesTest ‑ test_groupintobatches
apache_beam.examples.snippets.transforms.aggregation.latest_test.LatestTest ‑ test_latest_globally
apache_beam.examples.snippets.transforms.aggregation.latest_test.LatestTest ‑ test_latest_per_key
apache_beam.examples.snippets.transforms.aggregation.max_test.MaxTest ‑ test_max_globally
apache_beam.examples.snippets.transforms.aggregation.max_test.MaxTest ‑ test_max_per_key
apache_beam.examples.snippets.transforms.aggregation.mean_test.MeanTest ‑ test_mean_globally
apache_beam.examples.snippets.transforms.aggregation.mean_test.MeanTest ‑ test_mean_per_key
apache_beam.examples.snippets.transforms.aggregation.min_test.MinTest ‑ test_min_globally
apache_beam.examples.snippets.transforms.aggregation.min_test.MinTest ‑ test_min_per_key
apache_beam.examples.snippets.transforms.aggregation.sample_test.SampleTest ‑ test_sample_fixed_size_globally
apache_beam.examples.snippets.transforms.aggregation.sample_test.SampleTest ‑ test_sample_fixed_size_per_key
apache_beam.examples.snippets.transforms.aggregation.sum_test.SumTest ‑ test_sum_globally
apache_beam.examples.snippets.transforms.aggregation.sum_test.SumTest ‑ test_sum_per_key
apache_beam.examples.snippets.transforms.aggregation.tolist_test.BatchElementsTest ‑ test_tolist
apache_beam.examples.snippets.transforms.aggregation.top_test.TopTest ‑ test_top_largest
apache_beam.examples.snippets.transforms.aggregation.top_test.TopTest ‑ test_top_largest_per_key
apache_beam.examples.snippets.transforms.aggregation.top_test.TopTest ‑ test_top_of
apache_beam.examples.snippets.transforms.aggregation.top_test.TopTest ‑ test_top_per_key
apache_beam.examples.snippets.transforms.aggregation.top_test.TopTest ‑ test_top_smallest
apache_beam.examples.snippets.transforms.aggregation.top_test.TopTest ‑ test_top_smallest_per_key
apache_beam.examples.snippets.transforms.elementwise.enrichment_test
apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest ‑ test_enrichment_with_bigtable
apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest ‑ test_enrichment_with_external_mysql
apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest ‑ test_enrichment_with_external_pg
apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest ‑ test_enrichment_with_external_sqlserver
apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest ‑ test_enrichment_with_google_cloudsql_pg
apache_beam.examples.snippets.transforms.elementwise.enrichment_test.EnrichmentTest ‑ test_enrichment_with_milvus
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