Skip to content

Add google-cloud-kms dependency

921a7e2
Select commit
Loading
Failed to load commit list.
Sign in for the full log view
Closed

Fix PostCommit Python Arm job #36981

Add google-cloud-kms dependency
921a7e2
Select commit
Loading
Failed to load commit list.
GitHub Actions / Python 3.10 Test Results (self-hosted, ubuntu-20.04, main) failed Dec 3, 2025 in 0s

11 fail, 124 skipped, 442 pass in 28m 19s

  2 files  +  2    2 suites  +2   28m 19s ⏱️ + 28m 19s
577 tests +577  442 ✅ +442  124 💤 +124  11 ❌ +11 
581 runs  +581  442 ✅ +442  128 💤 +128  11 ❌ +11 

Results for commit 921a7e2. ± Comparison against earlier commit 53c6aa0.

Annotations

Check warning on line 0 in apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest

See this annotation in the file changed.

@github-actions github-actions / Python 3.10 Test Results (self-hosted, ubuntu-20.04, main)

test_embeddings_with_inference_args (apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest) failed

sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-ml_no_xdist.xml [took 5m 3s]
Raw output
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.DEADLINE_EXCEEDED
	details = "Deadline Exceeded"
	debug_error_string = "UNKNOWN:Error received from peer  {created_time:"2025-12-03T18:26:47.562700507+00:00", grpc_status:4, grpc_message:"Deadline Exceeded"}"
>
self = <apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest testMethod=test_embeddings_with_inference_args>

    def test_embeddings_with_inference_args(self):
      model_name = DEFAULT_MODEL_NAME
    
      inference_args = {'convert_to_numpy': False}
      embedding_config = SentenceTransformerEmbeddings(
          model_name=model_name,
          columns=[test_query_column],
          inference_args=inference_args)
>     with beam.Pipeline() as pipeline:

apache_beam/ml/transforms/embeddings/huggingface_test.py:235: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/pipeline.py:648: in __exit__
    self.result.wait_until_finish()
target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/portability/portable_runner.py:571: in wait_until_finish
    raise self._runtime_exception
target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/portability/portable_runner.py:580: in _observe_state
    for state_response in self._state_stream:
target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/grpc/_channel.py:543: in __next__
    return self._next()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.DEADLINE_EXCEEDED
	details = "Deadline Exc...ved from peer  {created_time:"2025-12-03T18:26:47.562700507+00:00", grpc_status:4, grpc_message:"Deadline Exceeded"}"
>

    def _next(self) -> Any:
        with self._state.condition:
            if self._state.code is None:
                event_handler = _event_handler(
                    self._state, self._response_deserializer
                )
                self._state.due.add(cygrpc.OperationType.receive_message)
                operating = self._call.operate(
                    (cygrpc.ReceiveMessageOperation(_EMPTY_FLAGS),),
                    event_handler,
                )
                if not operating:
                    self._state.due.remove(cygrpc.OperationType.receive_message)
            elif self._state.code is grpc.StatusCode.OK:
                raise StopIteration()
            else:
                raise self
    
            def _response_ready():
                return self._state.response is not None or (
                    cygrpc.OperationType.receive_message not in self._state.due
                    and self._state.code is not None
                )
    
            _common.wait(self._state.condition.wait, _response_ready)
            if self._state.response is not None:
                response = self._state.response
                self._state.response = None
                return response
            elif cygrpc.OperationType.receive_message not in self._state.due:
                if self._state.code is grpc.StatusCode.OK:
                    raise StopIteration()
                elif self._state.code is not None:
>                   raise self
E                   grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
E                   	status = StatusCode.DEADLINE_EXCEEDED
E                   	details = "Deadline Exceeded"
E                   	debug_error_string = "UNKNOWN:Error received from peer  {created_time:"2025-12-03T18:26:47.562700507+00:00", grpc_status:4, grpc_message:"Deadline Exceeded"}"
E                   >

target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/grpc/_channel.py:969: _MultiThreadedRendezvous

Check warning on line 0 in apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest

See this annotation in the file changed.

@github-actions github-actions / Python 3.10 Test Results (self-hosted, ubuntu-20.04, main)

test_embeddings_with_read_artifact_location_1 (apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest) failed

sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-ml_no_xdist.xml [took 3m 22s]
Raw output
RuntimeError: Pipeline job-004 failed in state FAILED: bundle inst003 stage-005 failed:Traceback (most recent call last):
  File "apache_beam/runners/common.py", line 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device.

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 701, in process_bundle
    bundle_processor = self.bundle_processor_cache.get(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 517, in get
    processor = bundle_processor.BundleProcessor(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1163, in __init__
    op.setup(self.data_sampler)
  File "apache_beam/runners/worker/operations.py", line 878, in apache_beam.runners.worker.operations.DoOperation.setup
    with self.scoped_start_state:
  File "apache_beam/runners/worker/operations.py", line 928, in apache_beam.runners.worker.operations.DoOperation.setup
    self.dofn_runner.setup()
  File "apache_beam/runners/common.py", line 1568, in apache_beam.runners.common.DoFnRunner.setup
    self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
  File "apache_beam/runners/common.py", line 1564, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    self._reraise_augmented(exn)
  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 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device. [while running 'MLTransform/RunInference/BeamML_RunInference']
a = (<apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest testMethod=test_embeddings_with_read_artifact_location_1>,)
kw = {}

    @wraps(func)
    def standalone_func(*a, **kw):
>       return func(*(a + p.args), **p.kwargs, **kw)

target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/parameterized/parameterized.py:620: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/ml/transforms/embeddings/huggingface_test.py:157: in test_embeddings_with_read_artifact_location
    with beam.Pipeline() as p:
target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/pipeline.py:648: in __exit__
    self.result.wait_until_finish()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.portability.portable_runner.PipelineResult object at 0x78bf9ddc2800>
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-004 failed in state FAILED: bundle inst003 stage-005 failed:Traceback (most recent call last):
E         File "apache_beam/runners/common.py", line 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           lifecycle_method()
E         File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
E           self.signature.setup_lifecycle_method.method_value()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
E           self._model = self._load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
E           model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
E           return _shared_map.acquire(self._key, constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
E           result = control_block.acquire(constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
E           result = constructor_fn()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
E           model = self._model_handler.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
E           model = self._underlying.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
E           model = self._model_class(self.model_name, **self._load_model_args)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
E           self.to(device)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
E           return self._apply(convert)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         [Previous line repeated 1 more time]
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
E           param_applied = fn(param)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
E           raise NotImplementedError(
E       NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device.
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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 316, in _execute
E           response = task()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 390, in <lambda>
E           lambda: self.create_worker().do_instruction(request), request)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 669, in do_instruction
E           return getattr(self, request_type)(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 701, in process_bundle
E           bundle_processor = self.bundle_processor_cache.get(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 517, in get
E           processor = bundle_processor.BundleProcessor(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1163, in __init__
E           op.setup(self.data_sampler)
E         File "apache_beam/runners/worker/operations.py", line 878, in apache_beam.runners.worker.operations.DoOperation.setup
E           with self.scoped_start_state:
E         File "apache_beam/runners/worker/operations.py", line 928, in apache_beam.runners.worker.operations.DoOperation.setup
E           self.dofn_runner.setup()
E         File "apache_beam/runners/common.py", line 1568, in apache_beam.runners.common.DoFnRunner.setup
E           self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
E         File "apache_beam/runners/common.py", line 1564, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           self._reraise_augmented(exn)
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 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           lifecycle_method()
E         File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
E           self.signature.setup_lifecycle_method.method_value()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
E           self._model = self._load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
E           model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
E           return _shared_map.acquire(self._key, constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
E           result = control_block.acquire(constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
E           result = constructor_fn()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
E           model = self._model_handler.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
E           model = self._underlying.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
E           model = self._model_class(self.model_name, **self._load_model_args)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
E           self.to(device)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
E           return self._apply(convert)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         [Previous line repeated 1 more time]
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
E           param_applied = fn(param)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
E           raise NotImplementedError(
E       NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device. [while running 'MLTransform/RunInference/BeamML_RunInference']

target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/portability/portable_runner.py:571: RuntimeError

Check warning on line 0 in apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest

See this annotation in the file changed.

@github-actions github-actions / Python 3.10 Test Results (self-hosted, ubuntu-20.04, main)

test_embeddings_with_read_artifact_location_2 (apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest) failed

sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-ml_no_xdist.xml [took 4s]
Raw output
RuntimeError: Pipeline job-005 failed in state FAILED: bundle inst004 stage-009 failed:Traceback (most recent call last):
  File "apache_beam/runners/common.py", line 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device.

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 701, in process_bundle
    bundle_processor = self.bundle_processor_cache.get(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 517, in get
    processor = bundle_processor.BundleProcessor(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1163, in __init__
    op.setup(self.data_sampler)
  File "apache_beam/runners/worker/operations.py", line 878, in apache_beam.runners.worker.operations.DoOperation.setup
    with self.scoped_start_state:
  File "apache_beam/runners/worker/operations.py", line 928, in apache_beam.runners.worker.operations.DoOperation.setup
    self.dofn_runner.setup()
  File "apache_beam/runners/common.py", line 1568, in apache_beam.runners.common.DoFnRunner.setup
    self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
  File "apache_beam/runners/common.py", line 1564, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    self._reraise_augmented(exn)
  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 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device. [while running 'MLTransform/RunInference/BeamML_RunInference']
a = (<apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest testMethod=test_embeddings_with_read_artifact_location_2>,)
kw = {}

    @wraps(func)
    def standalone_func(*a, **kw):
>       return func(*(a + p.args), **p.kwargs, **kw)

target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/parameterized/parameterized.py:620: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/ml/transforms/embeddings/huggingface_test.py:157: in test_embeddings_with_read_artifact_location
    with beam.Pipeline() as p:
target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/pipeline.py:648: in __exit__
    self.result.wait_until_finish()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.portability.portable_runner.PipelineResult object at 0x78bf9dbddba0>
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-005 failed in state FAILED: bundle inst004 stage-009 failed:Traceback (most recent call last):
E         File "apache_beam/runners/common.py", line 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           lifecycle_method()
E         File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
E           self.signature.setup_lifecycle_method.method_value()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
E           self._model = self._load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
E           model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
E           return _shared_map.acquire(self._key, constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
E           result = control_block.acquire(constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
E           result = constructor_fn()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
E           model = self._model_handler.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
E           model = self._underlying.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
E           model = self._model_class(self.model_name, **self._load_model_args)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
E           self.to(device)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
E           return self._apply(convert)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         [Previous line repeated 1 more time]
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
E           param_applied = fn(param)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
E           raise NotImplementedError(
E       NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device.
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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 316, in _execute
E           response = task()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 390, in <lambda>
E           lambda: self.create_worker().do_instruction(request), request)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 669, in do_instruction
E           return getattr(self, request_type)(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 701, in process_bundle
E           bundle_processor = self.bundle_processor_cache.get(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 517, in get
E           processor = bundle_processor.BundleProcessor(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1163, in __init__
E           op.setup(self.data_sampler)
E         File "apache_beam/runners/worker/operations.py", line 878, in apache_beam.runners.worker.operations.DoOperation.setup
E           with self.scoped_start_state:
E         File "apache_beam/runners/worker/operations.py", line 928, in apache_beam.runners.worker.operations.DoOperation.setup
E           self.dofn_runner.setup()
E         File "apache_beam/runners/common.py", line 1568, in apache_beam.runners.common.DoFnRunner.setup
E           self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
E         File "apache_beam/runners/common.py", line 1564, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           self._reraise_augmented(exn)
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 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           lifecycle_method()
E         File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
E           self.signature.setup_lifecycle_method.method_value()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
E           self._model = self._load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
E           model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
E           return _shared_map.acquire(self._key, constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
E           result = control_block.acquire(constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
E           result = constructor_fn()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
E           model = self._model_handler.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
E           model = self._underlying.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
E           model = self._model_class(self.model_name, **self._load_model_args)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
E           self.to(device)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
E           return self._apply(convert)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         [Previous line repeated 1 more time]
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
E           param_applied = fn(param)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
E           raise NotImplementedError(
E       NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device. [while running 'MLTransform/RunInference/BeamML_RunInference']

target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/portability/portable_runner.py:571: RuntimeError

Check warning on line 0 in apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest

See this annotation in the file changed.

@github-actions github-actions / Python 3.10 Test Results (self-hosted, ubuntu-20.04, main)

test_embeddings_with_scale_to_0_1 (apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest) failed

sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-ml_no_xdist.xml [took 3s]
Raw output
RuntimeError: Pipeline job-006 failed in state FAILED: bundle inst010 stage-031 failed:Traceback (most recent call last):
  File "apache_beam/runners/common.py", line 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device.

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 701, in process_bundle
    bundle_processor = self.bundle_processor_cache.get(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 517, in get
    processor = bundle_processor.BundleProcessor(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1163, in __init__
    op.setup(self.data_sampler)
  File "apache_beam/runners/worker/operations.py", line 878, in apache_beam.runners.worker.operations.DoOperation.setup
    with self.scoped_start_state:
  File "apache_beam/runners/worker/operations.py", line 928, in apache_beam.runners.worker.operations.DoOperation.setup
    self.dofn_runner.setup()
  File "apache_beam/runners/common.py", line 1568, in apache_beam.runners.common.DoFnRunner.setup
    self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
  File "apache_beam/runners/common.py", line 1564, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    self._reraise_augmented(exn)
  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 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device. [while running 'MLTransform/RunInference/BeamML_RunInference']
self = <apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest testMethod=test_embeddings_with_scale_to_0_1>

    @unittest.skipIf(tft is None, 'Tensorflow Transform is not installed.')
    def test_embeddings_with_scale_to_0_1(self):
      model_name = DEFAULT_MODEL_NAME
      embedding_config = SentenceTransformerEmbeddings(
          model_name=model_name,
          columns=[test_query_column],
      )
>     with beam.Pipeline() as pipeline:

apache_beam/ml/transforms/embeddings/huggingface_test.py:135: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/pipeline.py:648: in __exit__
    self.result.wait_until_finish()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.portability.portable_runner.PipelineResult object at 0x78c08c235030>
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-006 failed in state FAILED: bundle inst010 stage-031 failed:Traceback (most recent call last):
E         File "apache_beam/runners/common.py", line 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           lifecycle_method()
E         File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
E           self.signature.setup_lifecycle_method.method_value()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
E           self._model = self._load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
E           model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
E           return _shared_map.acquire(self._key, constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
E           result = control_block.acquire(constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
E           result = constructor_fn()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
E           model = self._model_handler.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
E           model = self._underlying.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
E           model = self._model_class(self.model_name, **self._load_model_args)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
E           self.to(device)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
E           return self._apply(convert)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         [Previous line repeated 1 more time]
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
E           param_applied = fn(param)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
E           raise NotImplementedError(
E       NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device.
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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 316, in _execute
E           response = task()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 390, in <lambda>
E           lambda: self.create_worker().do_instruction(request), request)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 669, in do_instruction
E           return getattr(self, request_type)(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 701, in process_bundle
E           bundle_processor = self.bundle_processor_cache.get(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 517, in get
E           processor = bundle_processor.BundleProcessor(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1163, in __init__
E           op.setup(self.data_sampler)
E         File "apache_beam/runners/worker/operations.py", line 878, in apache_beam.runners.worker.operations.DoOperation.setup
E           with self.scoped_start_state:
E         File "apache_beam/runners/worker/operations.py", line 928, in apache_beam.runners.worker.operations.DoOperation.setup
E           self.dofn_runner.setup()
E         File "apache_beam/runners/common.py", line 1568, in apache_beam.runners.common.DoFnRunner.setup
E           self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
E         File "apache_beam/runners/common.py", line 1564, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           self._reraise_augmented(exn)
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 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           lifecycle_method()
E         File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
E           self.signature.setup_lifecycle_method.method_value()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
E           self._model = self._load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
E           model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
E           return _shared_map.acquire(self._key, constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
E           result = control_block.acquire(constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
E           result = constructor_fn()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
E           model = self._model_handler.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
E           model = self._underlying.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
E           model = self._model_class(self.model_name, **self._load_model_args)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
E           self.to(device)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
E           return self._apply(convert)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         [Previous line repeated 1 more time]
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
E           param_applied = fn(param)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
E           raise NotImplementedError(
E       NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device. [while running 'MLTransform/RunInference/BeamML_RunInference']

target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/portability/portable_runner.py:571: RuntimeError

Check warning on line 0 in apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest

See this annotation in the file changed.

@github-actions github-actions / Python 3.10 Test Results (self-hosted, ubuntu-20.04, main)

test_sentence_transformer_embeddings (apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest) failed

sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-ml_no_xdist.xml [took 3s]
Raw output
RuntimeError: Pipeline job-007 failed in state FAILED: bundle inst001 stage-003 failed:Traceback (most recent call last):
  File "apache_beam/runners/common.py", line 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device.

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 701, in process_bundle
    bundle_processor = self.bundle_processor_cache.get(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 517, in get
    processor = bundle_processor.BundleProcessor(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1163, in __init__
    op.setup(self.data_sampler)
  File "apache_beam/runners/worker/operations.py", line 878, in apache_beam.runners.worker.operations.DoOperation.setup
    with self.scoped_start_state:
  File "apache_beam/runners/worker/operations.py", line 928, in apache_beam.runners.worker.operations.DoOperation.setup
    self.dofn_runner.setup()
  File "apache_beam/runners/common.py", line 1568, in apache_beam.runners.common.DoFnRunner.setup
    self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
  File "apache_beam/runners/common.py", line 1564, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    self._reraise_augmented(exn)
  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 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device. [while running 'MLTransform/RunInference/BeamML_RunInference']
self = <apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest testMethod=test_sentence_transformer_embeddings>

    def test_sentence_transformer_embeddings(self):
      model_name = DEFAULT_MODEL_NAME
      embedding_config = SentenceTransformerEmbeddings(
          model_name=model_name, columns=[test_query_column])
>     with beam.Pipeline() as pipeline:

apache_beam/ml/transforms/embeddings/huggingface_test.py:113: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/pipeline.py:648: in __exit__
    self.result.wait_until_finish()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.portability.portable_runner.PipelineResult object at 0x78c03b1b92d0>
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-007 failed in state FAILED: bundle inst001 stage-003 failed:Traceback (most recent call last):
E         File "apache_beam/runners/common.py", line 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           lifecycle_method()
E         File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
E           self.signature.setup_lifecycle_method.method_value()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
E           self._model = self._load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
E           model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
E           return _shared_map.acquire(self._key, constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
E           result = control_block.acquire(constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
E           result = constructor_fn()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
E           model = self._model_handler.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
E           model = self._underlying.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
E           model = self._model_class(self.model_name, **self._load_model_args)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
E           self.to(device)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
E           return self._apply(convert)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         [Previous line repeated 1 more time]
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
E           param_applied = fn(param)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
E           raise NotImplementedError(
E       NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device.
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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 316, in _execute
E           response = task()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 390, in <lambda>
E           lambda: self.create_worker().do_instruction(request), request)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 669, in do_instruction
E           return getattr(self, request_type)(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 701, in process_bundle
E           bundle_processor = self.bundle_processor_cache.get(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 517, in get
E           processor = bundle_processor.BundleProcessor(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1163, in __init__
E           op.setup(self.data_sampler)
E         File "apache_beam/runners/worker/operations.py", line 878, in apache_beam.runners.worker.operations.DoOperation.setup
E           with self.scoped_start_state:
E         File "apache_beam/runners/worker/operations.py", line 928, in apache_beam.runners.worker.operations.DoOperation.setup
E           self.dofn_runner.setup()
E         File "apache_beam/runners/common.py", line 1568, in apache_beam.runners.common.DoFnRunner.setup
E           self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
E         File "apache_beam/runners/common.py", line 1564, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           self._reraise_augmented(exn)
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 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           lifecycle_method()
E         File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
E           self.signature.setup_lifecycle_method.method_value()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
E           self._model = self._load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
E           model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
E           return _shared_map.acquire(self._key, constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
E           result = control_block.acquire(constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
E           result = constructor_fn()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
E           model = self._model_handler.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
E           model = self._underlying.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
E           model = self._model_class(self.model_name, **self._load_model_args)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
E           self.to(device)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
E           return self._apply(convert)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         [Previous line repeated 1 more time]
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
E           param_applied = fn(param)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
E           raise NotImplementedError(
E       NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device. [while running 'MLTransform/RunInference/BeamML_RunInference']

target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/portability/portable_runner.py:571: RuntimeError

Check warning on line 0 in apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest

See this annotation in the file changed.

@github-actions github-actions / Python 3.10 Test Results (self-hosted, ubuntu-20.04, main)

test_sentence_transformer_image_embeddings (apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest) failed

sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-ml_no_xdist.xml [took 5m 0s]
Raw output
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.DEADLINE_EXCEEDED
	details = "Deadline Exceeded"
	debug_error_string = "UNKNOWN:Error received from peer  {created_time:"2025-12-03T18:35:37.830993849+00:00", grpc_status:4, grpc_message:"Deadline Exceeded"}"
>
self = <apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest testMethod=test_sentence_transformer_image_embeddings>

    @unittest.skipIf(Image is None, 'Pillow is not installed.')
    def test_sentence_transformer_image_embeddings(self):
      embedding_config = SentenceTransformerEmbeddings(
          model_name=IMAGE_MODEL_NAME,
          columns=[test_query_column],
          image_model=True)
      img = self.generateRandomImage(256)
>     with beam.Pipeline() as pipeline:

apache_beam/ml/transforms/embeddings/huggingface_test.py:301: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/pipeline.py:648: in __exit__
    self.result.wait_until_finish()
target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/portability/portable_runner.py:571: in wait_until_finish
    raise self._runtime_exception
target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/portability/portable_runner.py:580: in _observe_state
    for state_response in self._state_stream:
target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/grpc/_channel.py:543: in __next__
    return self._next()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.DEADLINE_EXCEEDED
	details = "Deadline Exc...ved from peer  {created_time:"2025-12-03T18:35:37.830993849+00:00", grpc_status:4, grpc_message:"Deadline Exceeded"}"
>

    def _next(self) -> Any:
        with self._state.condition:
            if self._state.code is None:
                event_handler = _event_handler(
                    self._state, self._response_deserializer
                )
                self._state.due.add(cygrpc.OperationType.receive_message)
                operating = self._call.operate(
                    (cygrpc.ReceiveMessageOperation(_EMPTY_FLAGS),),
                    event_handler,
                )
                if not operating:
                    self._state.due.remove(cygrpc.OperationType.receive_message)
            elif self._state.code is grpc.StatusCode.OK:
                raise StopIteration()
            else:
                raise self
    
            def _response_ready():
                return self._state.response is not None or (
                    cygrpc.OperationType.receive_message not in self._state.due
                    and self._state.code is not None
                )
    
            _common.wait(self._state.condition.wait, _response_ready)
            if self._state.response is not None:
                response = self._state.response
                self._state.response = None
                return response
            elif cygrpc.OperationType.receive_message not in self._state.due:
                if self._state.code is grpc.StatusCode.OK:
                    raise StopIteration()
                elif self._state.code is not None:
>                   raise self
E                   grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
E                   	status = StatusCode.DEADLINE_EXCEEDED
E                   	details = "Deadline Exceeded"
E                   	debug_error_string = "UNKNOWN:Error received from peer  {created_time:"2025-12-03T18:35:37.830993849+00:00", grpc_status:4, grpc_message:"Deadline Exceeded"}"
E                   >

target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/grpc/_channel.py:969: _MultiThreadedRendezvous

Check warning on line 0 in apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest

See this annotation in the file changed.

@github-actions github-actions / Python 3.10 Test Results (self-hosted, ubuntu-20.04, main)

test_sentence_transformer_images_with_str_data_types (apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest) failed

sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-ml_no_xdist.xml [took 5m 0s]
Raw output
AssertionError: "Embeddings can only be generated" does not match "<_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.DEADLINE_EXCEEDED
	details = "Deadline Exceeded"
	debug_error_string = "UNKNOWN:Error received from peer  {created_time:"2025-12-03T18:40:38.161477056+00:00", grpc_status:4, grpc_message:"Deadline Exceeded"}"
>"
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.DEADLINE_EXCEEDED
	details = "Deadline Exceeded"
	debug_error_string = "UNKNOWN:Error received from peer  {created_time:"2025-12-03T18:40:38.161477056+00:00", grpc_status:4, grpc_message:"Deadline Exceeded"}"
>

During handling of the above exception, another exception occurred:

self = <apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest testMethod=test_sentence_transformer_images_with_str_data_types>

    def test_sentence_transformer_images_with_str_data_types(self):
      embedding_config = SentenceTransformerEmbeddings(
          model_name=IMAGE_MODEL_NAME,
          columns=[test_query_column],
          image_model=True)
>     with self.assertRaisesRegex(Exception, "Embeddings can only be generated"):
E     AssertionError: "Embeddings can only be generated" does not match "<_MultiThreadedRendezvous of RPC that terminated with:
E     	status = StatusCode.DEADLINE_EXCEEDED
E     	details = "Deadline Exceeded"
E     	debug_error_string = "UNKNOWN:Error received from peer  {created_time:"2025-12-03T18:40:38.161477056+00:00", grpc_status:4, grpc_message:"Deadline Exceeded"}"
E     >"

apache_beam/ml/transforms/embeddings/huggingface_test.py:321: AssertionError

Check warning on line 0 in apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest

See this annotation in the file changed.

@github-actions github-actions / Python 3.10 Test Results (self-hosted, ubuntu-20.04, main)

test_sentence_transformer_with_int_data_types (apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest) failed

sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-ml_no_xdist.xml [took 1s]
Raw output
AssertionError: "Embeddings can only be generated" does not match "Pipeline job-010 failed in state FAILED: bundle inst002 stage-003 failed:Traceback (most recent call last):
  File "apache_beam/runners/common.py", line 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device.

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 701, in process_bundle
    bundle_processor = self.bundle_processor_cache.get(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 517, in get
    processor = bundle_processor.BundleProcessor(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1163, in __init__
    op.setup(self.data_sampler)
  File "apache_beam/runners/worker/operations.py", line 878, in apache_beam.runners.worker.operations.DoOperation.setup
    with self.scoped_start_state:
  File "apache_beam/runners/worker/operations.py", line 928, in apache_beam.runners.worker.operations.DoOperation.setup
    self.dofn_runner.setup()
  File "apache_beam/runners/common.py", line 1568, in apache_beam.runners.common.DoFnRunner.setup
    self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
  File "apache_beam/runners/common.py", line 1564, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    self._reraise_augmented(exn)
  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 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device. [while running 'MLTransform/RunInference/BeamML_RunInference']
"
RuntimeError: Pipeline job-010 failed in state FAILED: bundle inst002 stage-003 failed:Traceback (most recent call last):
  File "apache_beam/runners/common.py", line 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device.

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 701, in process_bundle
    bundle_processor = self.bundle_processor_cache.get(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 517, in get
    processor = bundle_processor.BundleProcessor(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1163, in __init__
    op.setup(self.data_sampler)
  File "apache_beam/runners/worker/operations.py", line 878, in apache_beam.runners.worker.operations.DoOperation.setup
    with self.scoped_start_state:
  File "apache_beam/runners/worker/operations.py", line 928, in apache_beam.runners.worker.operations.DoOperation.setup
    self.dofn_runner.setup()
  File "apache_beam/runners/common.py", line 1568, in apache_beam.runners.common.DoFnRunner.setup
    self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
  File "apache_beam/runners/common.py", line 1564, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    self._reraise_augmented(exn)
  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 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device. [while running 'MLTransform/RunInference/BeamML_RunInference']


During handling of the above exception, another exception occurred:

self = <apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest testMethod=test_sentence_transformer_with_int_data_types>

    def test_sentence_transformer_with_int_data_types(self):
      model_name = DEFAULT_MODEL_NAME
      embedding_config = SentenceTransformerEmbeddings(
          model_name=model_name, columns=[test_query_column])
>     with self.assertRaisesRegex(Exception, "Embeddings can only be generated"):
E     AssertionError: "Embeddings can only be generated" does not match "Pipeline job-010 failed in state FAILED: bundle inst002 stage-003 failed:Traceback (most recent call last):
E       File "apache_beam/runners/common.py", line 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E         lifecycle_method()
E       File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
E         self.signature.setup_lifecycle_method.method_value()
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
E         self._model = self._load_model()
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
E         model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
E         return _shared_map.acquire(self._key, constructor_fn, tag)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
E         result = control_block.acquire(constructor_fn, tag)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
E         result = constructor_fn()
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
E         model = self._model_handler.load_model()
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
E         model = self._underlying.load_model()
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
E         model = self._model_class(self.model_name, **self._load_model_args)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
E         self.to(device)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
E         return self._apply(convert)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E         module._apply(fn)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E         module._apply(fn)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E         module._apply(fn)
E       [Previous line repeated 1 more time]
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
E         param_applied = fn(param)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
E         raise NotImplementedError(
E     NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device.
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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 316, in _execute
E         response = task()
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 390, in <lambda>
E         lambda: self.create_worker().do_instruction(request), request)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 669, in do_instruction
E         return getattr(self, request_type)(
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 701, in process_bundle
E         bundle_processor = self.bundle_processor_cache.get(
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 517, in get
E         processor = bundle_processor.BundleProcessor(
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1163, in __init__
E         op.setup(self.data_sampler)
E       File "apache_beam/runners/worker/operations.py", line 878, in apache_beam.runners.worker.operations.DoOperation.setup
E         with self.scoped_start_state:
E       File "apache_beam/runners/worker/operations.py", line 928, in apache_beam.runners.worker.operations.DoOperation.setup
E         self.dofn_runner.setup()
E       File "apache_beam/runners/common.py", line 1568, in apache_beam.runners.common.DoFnRunner.setup
E         self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
E       File "apache_beam/runners/common.py", line 1564, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E         self._reraise_augmented(exn)
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 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E         lifecycle_method()
E       File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
E         self.signature.setup_lifecycle_method.method_value()
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
E         self._model = self._load_model()
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
E         model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
E         return _shared_map.acquire(self._key, constructor_fn, tag)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
E         result = control_block.acquire(constructor_fn, tag)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
E         result = constructor_fn()
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
E         model = self._model_handler.load_model()
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
E         model = self._underlying.load_model()
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
E         model = self._model_class(self.model_name, **self._load_model_args)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
E         self.to(device)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
E         return self._apply(convert)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E         module._apply(fn)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E         module._apply(fn)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E         module._apply(fn)
E       [Previous line repeated 1 more time]
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
E         param_applied = fn(param)
E       File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
E         raise NotImplementedError(
E     NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device. [while running 'MLTransform/RunInference/BeamML_RunInference']
E     "

apache_beam/ml/transforms/embeddings/huggingface_test.py:186: AssertionError

Check warning on line 0 in apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest

See this annotation in the file changed.

@github-actions github-actions / Python 3.10 Test Results (self-hosted, ubuntu-20.04, main)

test_with_gcs_artifact_location_0 (apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest) failed

sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-ml_no_xdist.xml [took 2s]
Raw output
RuntimeError: Pipeline job-011 failed in state FAILED: bundle inst004 stage-009 failed:Traceback (most recent call last):
  File "apache_beam/runners/common.py", line 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device.

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 701, in process_bundle
    bundle_processor = self.bundle_processor_cache.get(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 517, in get
    processor = bundle_processor.BundleProcessor(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1163, in __init__
    op.setup(self.data_sampler)
  File "apache_beam/runners/worker/operations.py", line 878, in apache_beam.runners.worker.operations.DoOperation.setup
    with self.scoped_start_state:
  File "apache_beam/runners/worker/operations.py", line 928, in apache_beam.runners.worker.operations.DoOperation.setup
    self.dofn_runner.setup()
  File "apache_beam/runners/common.py", line 1568, in apache_beam.runners.common.DoFnRunner.setup
    self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
  File "apache_beam/runners/common.py", line 1564, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    self._reraise_augmented(exn)
  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 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device. [while running 'MLTransform/RunInference/BeamML_RunInference']
a = (<apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest testMethod=test_with_gcs_artifact_location_0>,)
kw = {}

    @wraps(func)
    def standalone_func(*a, **kw):
>       return func(*(a + p.args), **p.kwargs, **kw)

target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/parameterized/parameterized.py:620: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/ml/transforms/embeddings/huggingface_test.py:202: in test_with_gcs_artifact_location
    with beam.Pipeline() as p:
target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/pipeline.py:648: in __exit__
    self.result.wait_until_finish()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.portability.portable_runner.PipelineResult object at 0x78c03b3e4520>
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-011 failed in state FAILED: bundle inst004 stage-009 failed:Traceback (most recent call last):
E         File "apache_beam/runners/common.py", line 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           lifecycle_method()
E         File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
E           self.signature.setup_lifecycle_method.method_value()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
E           self._model = self._load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
E           model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
E           return _shared_map.acquire(self._key, constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
E           result = control_block.acquire(constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
E           result = constructor_fn()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
E           model = self._model_handler.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
E           model = self._underlying.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
E           model = self._model_class(self.model_name, **self._load_model_args)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
E           self.to(device)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
E           return self._apply(convert)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         [Previous line repeated 1 more time]
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
E           param_applied = fn(param)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
E           raise NotImplementedError(
E       NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device.
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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 316, in _execute
E           response = task()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 390, in <lambda>
E           lambda: self.create_worker().do_instruction(request), request)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 669, in do_instruction
E           return getattr(self, request_type)(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 701, in process_bundle
E           bundle_processor = self.bundle_processor_cache.get(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 517, in get
E           processor = bundle_processor.BundleProcessor(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1163, in __init__
E           op.setup(self.data_sampler)
E         File "apache_beam/runners/worker/operations.py", line 878, in apache_beam.runners.worker.operations.DoOperation.setup
E           with self.scoped_start_state:
E         File "apache_beam/runners/worker/operations.py", line 928, in apache_beam.runners.worker.operations.DoOperation.setup
E           self.dofn_runner.setup()
E         File "apache_beam/runners/common.py", line 1568, in apache_beam.runners.common.DoFnRunner.setup
E           self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
E         File "apache_beam/runners/common.py", line 1564, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           self._reraise_augmented(exn)
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 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           lifecycle_method()
E         File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
E           self.signature.setup_lifecycle_method.method_value()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
E           self._model = self._load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
E           model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
E           return _shared_map.acquire(self._key, constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
E           result = control_block.acquire(constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
E           result = constructor_fn()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
E           model = self._model_handler.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
E           model = self._underlying.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
E           model = self._model_class(self.model_name, **self._load_model_args)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
E           self.to(device)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
E           return self._apply(convert)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         [Previous line repeated 1 more time]
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
E           param_applied = fn(param)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
E           raise NotImplementedError(
E       NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device. [while running 'MLTransform/RunInference/BeamML_RunInference']

target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/portability/portable_runner.py:571: RuntimeError

Check warning on line 0 in apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest

See this annotation in the file changed.

@github-actions github-actions / Python 3.10 Test Results (self-hosted, ubuntu-20.04, main)

test_with_gcs_artifact_location_1 (apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest) failed

sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-ml_no_xdist.xml [took 2s]
Raw output
RuntimeError: Pipeline job-012 failed in state FAILED: bundle inst003 stage-005 failed:Traceback (most recent call last):
  File "apache_beam/runners/common.py", line 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device.

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 701, in process_bundle
    bundle_processor = self.bundle_processor_cache.get(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 517, in get
    processor = bundle_processor.BundleProcessor(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1163, in __init__
    op.setup(self.data_sampler)
  File "apache_beam/runners/worker/operations.py", line 878, in apache_beam.runners.worker.operations.DoOperation.setup
    with self.scoped_start_state:
  File "apache_beam/runners/worker/operations.py", line 928, in apache_beam.runners.worker.operations.DoOperation.setup
    self.dofn_runner.setup()
  File "apache_beam/runners/common.py", line 1568, in apache_beam.runners.common.DoFnRunner.setup
    self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
  File "apache_beam/runners/common.py", line 1564, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    self._reraise_augmented(exn)
  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 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device. [while running 'MLTransform/RunInference/BeamML_RunInference']
a = (<apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest testMethod=test_with_gcs_artifact_location_1>,)
kw = {}

    @wraps(func)
    def standalone_func(*a, **kw):
>       return func(*(a + p.args), **p.kwargs, **kw)

target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/parameterized/parameterized.py:620: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/ml/transforms/embeddings/huggingface_test.py:202: in test_with_gcs_artifact_location
    with beam.Pipeline() as p:
target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/pipeline.py:648: in __exit__
    self.result.wait_until_finish()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.portability.portable_runner.PipelineResult object at 0x78bff7d53640>
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-012 failed in state FAILED: bundle inst003 stage-005 failed:Traceback (most recent call last):
E         File "apache_beam/runners/common.py", line 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           lifecycle_method()
E         File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
E           self.signature.setup_lifecycle_method.method_value()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
E           self._model = self._load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
E           model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
E           return _shared_map.acquire(self._key, constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
E           result = control_block.acquire(constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
E           result = constructor_fn()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
E           model = self._model_handler.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
E           model = self._underlying.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
E           model = self._model_class(self.model_name, **self._load_model_args)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
E           self.to(device)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
E           return self._apply(convert)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         [Previous line repeated 1 more time]
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
E           param_applied = fn(param)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
E           raise NotImplementedError(
E       NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device.
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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 316, in _execute
E           response = task()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 390, in <lambda>
E           lambda: self.create_worker().do_instruction(request), request)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 669, in do_instruction
E           return getattr(self, request_type)(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 701, in process_bundle
E           bundle_processor = self.bundle_processor_cache.get(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 517, in get
E           processor = bundle_processor.BundleProcessor(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1163, in __init__
E           op.setup(self.data_sampler)
E         File "apache_beam/runners/worker/operations.py", line 878, in apache_beam.runners.worker.operations.DoOperation.setup
E           with self.scoped_start_state:
E         File "apache_beam/runners/worker/operations.py", line 928, in apache_beam.runners.worker.operations.DoOperation.setup
E           self.dofn_runner.setup()
E         File "apache_beam/runners/common.py", line 1568, in apache_beam.runners.common.DoFnRunner.setup
E           self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
E         File "apache_beam/runners/common.py", line 1564, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           self._reraise_augmented(exn)
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 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           lifecycle_method()
E         File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
E           self.signature.setup_lifecycle_method.method_value()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
E           self._model = self._load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
E           model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
E           return _shared_map.acquire(self._key, constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
E           result = control_block.acquire(constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
E           result = constructor_fn()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
E           model = self._model_handler.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
E           model = self._underlying.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
E           model = self._model_class(self.model_name, **self._load_model_args)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
E           self.to(device)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
E           return self._apply(convert)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         [Previous line repeated 1 more time]
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
E           param_applied = fn(param)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
E           raise NotImplementedError(
E       NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device. [while running 'MLTransform/RunInference/BeamML_RunInference']

target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/portability/portable_runner.py:571: RuntimeError

Check warning on line 0 in apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest

See this annotation in the file changed.

@github-actions github-actions / Python 3.10 Test Results (self-hosted, ubuntu-20.04, main)

test_with_gcs_artifact_location_2 (apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest) failed

sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-ml_no_xdist.xml [took 4s]
Raw output
RuntimeError: Pipeline job-013 failed in state FAILED: bundle inst004 stage-009 failed:Traceback (most recent call last):
  File "apache_beam/runners/common.py", line 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device.

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 701, in process_bundle
    bundle_processor = self.bundle_processor_cache.get(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 517, in get
    processor = bundle_processor.BundleProcessor(
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1163, in __init__
    op.setup(self.data_sampler)
  File "apache_beam/runners/worker/operations.py", line 878, in apache_beam.runners.worker.operations.DoOperation.setup
    with self.scoped_start_state:
  File "apache_beam/runners/worker/operations.py", line 928, in apache_beam.runners.worker.operations.DoOperation.setup
    self.dofn_runner.setup()
  File "apache_beam/runners/common.py", line 1568, in apache_beam.runners.common.DoFnRunner.setup
    self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
  File "apache_beam/runners/common.py", line 1564, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    self._reraise_augmented(exn)
  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 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
    lifecycle_method()
  File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
    self.signature.setup_lifecycle_method.method_value()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
    self._model = self._load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
    model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
    return _shared_map.acquire(self._key, constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
    result = control_block.acquire(constructor_fn, tag)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
    result = constructor_fn()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
    model = self._model_handler.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
    model = self._underlying.load_model()
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
    model = self._model_class(self.model_name, **self._load_model_args)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
    self.to(device)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
    return self._apply(convert)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
    module._apply(fn)
  [Previous line repeated 1 more time]
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
    param_applied = fn(param)
  File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
    raise NotImplementedError(
NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device. [while running 'MLTransform/RunInference/BeamML_RunInference']
a = (<apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest testMethod=test_with_gcs_artifact_location_2>,)
kw = {}

    @wraps(func)
    def standalone_func(*a, **kw):
>       return func(*(a + p.args), **p.kwargs, **kw)

target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/parameterized/parameterized.py:620: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/ml/transforms/embeddings/huggingface_test.py:202: in test_with_gcs_artifact_location
    with beam.Pipeline() as p:
target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/pipeline.py:648: in __exit__
    self.result.wait_until_finish()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.portability.portable_runner.PipelineResult object at 0x78bff7fbc610>
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-013 failed in state FAILED: bundle inst004 stage-009 failed:Traceback (most recent call last):
E         File "apache_beam/runners/common.py", line 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           lifecycle_method()
E         File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
E           self.signature.setup_lifecycle_method.method_value()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
E           self._model = self._load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
E           model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
E           return _shared_map.acquire(self._key, constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
E           result = control_block.acquire(constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
E           result = constructor_fn()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
E           model = self._model_handler.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
E           model = self._underlying.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
E           model = self._model_class(self.model_name, **self._load_model_args)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
E           self.to(device)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
E           return self._apply(convert)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         [Previous line repeated 1 more time]
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
E           param_applied = fn(param)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
E           raise NotImplementedError(
E       NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device.
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/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 316, in _execute
E           response = task()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 390, in <lambda>
E           lambda: self.create_worker().do_instruction(request), request)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 669, in do_instruction
E           return getattr(self, request_type)(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 701, in process_bundle
E           bundle_processor = self.bundle_processor_cache.get(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py", line 517, in get
E           processor = bundle_processor.BundleProcessor(
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1163, in __init__
E           op.setup(self.data_sampler)
E         File "apache_beam/runners/worker/operations.py", line 878, in apache_beam.runners.worker.operations.DoOperation.setup
E           with self.scoped_start_state:
E         File "apache_beam/runners/worker/operations.py", line 928, in apache_beam.runners.worker.operations.DoOperation.setup
E           self.dofn_runner.setup()
E         File "apache_beam/runners/common.py", line 1568, in apache_beam.runners.common.DoFnRunner.setup
E           self._invoke_lifecycle_method(self.do_fn_invoker.invoke_setup)
E         File "apache_beam/runners/common.py", line 1564, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           self._reraise_augmented(exn)
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 1562, in apache_beam.runners.common.DoFnRunner._invoke_lifecycle_method
E           lifecycle_method()
E         File "apache_beam/runners/common.py", line 602, in apache_beam.runners.common.DoFnInvoker.invoke_setup
E           self.signature.setup_lifecycle_method.method_value()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1877, in setup
E           self._model = self._load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1843, in _load_model
E           model = self._shared_model_handle.acquire(load, tag=self._cur_tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 289, in acquire
E           return _shared_map.acquire(self._key, constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 236, in acquire
E           result = control_block.acquire(constructor_fn, tag)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/utils/shared.py", line 133, in acquire
E           result = constructor_fn()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/inference/base.py", line 1817, in load
E           model = self._model_handler.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/base.py", line 694, in load_model
E           model = self._underlying.load_model()
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/ml/transforms/embeddings/huggingface.py", line 87, in load_model
E           model = self._model_class(self.model_name, **self._load_model_args)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/sentence_transformers/SentenceTransformer.py", line 367, in __init__
E           self.to(device)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1371, in to
E           return self._apply(convert)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 930, in _apply
E           module._apply(fn)
E         [Previous line repeated 1 more time]
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 957, in _apply
E           param_applied = fn(param)
E         File "/runner/_work/beam/beam/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/torch/nn/modules/module.py", line 1364, in convert
E           raise NotImplementedError(
E       NotImplementedError: Cannot copy out of meta tensor; no data! Please use torch.nn.Module.to_empty() instead of torch.nn.Module.to() when moving module from meta to a different device. [while running 'MLTransform/RunInference/BeamML_RunInference']

target/.tox-py310-ml/py310-ml/lib/python3.10/site-packages/apache_beam/runners/portability/portable_runner.py:571: RuntimeError

Check notice on line 0 in .github

See this annotation in the file changed.

@github-actions github-actions / Python 3.10 Test Results (self-hosted, ubuntu-20.04, main)

124 skipped tests found

There are 124 skipped tests, see "Raw output" for the full list of skipped tests.
Raw output
apache_beam.ml.gcp.cloud_dlp_it_test.CloudDLPIT ‑ test_deidentification
apache_beam.ml.gcp.cloud_dlp_it_test.CloudDLPIT ‑ test_inspection
apache_beam.ml.gcp.naturallanguageml_test_it.NaturalLanguageMlTestIT ‑ test_analyzing_syntax
apache_beam.ml.gcp.recommendations_ai_test_it.RecommendationAIIT ‑ test_create_catalog_item
apache_beam.ml.gcp.recommendations_ai_test_it.RecommendationAIIT ‑ test_create_user_event
apache_beam.ml.gcp.recommendations_ai_test_it.RecommendationAIIT ‑ test_predict
apache_beam.ml.gcp.videointelligenceml_test_it.VideoIntelligenceMlTestIT ‑ test_label_detection_with_video_context
apache_beam.ml.gcp.visionml_test_it.VisionMlTestIT ‑ test_text_detection_with_language_hint
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_timeout_does_garbage_collection
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_with_side_inputin_streaming
apache_beam.ml.inference.gemini_inference_it_test.GeminiInference ‑ test_gemini_text_classification
apache_beam.ml.inference.huggingface_inference_it_test.HuggingFaceInference ‑ test_hf_language_modeling
apache_beam.ml.inference.huggingface_inference_it_test.HuggingFaceInference ‑ test_hf_language_modeling_large_model
apache_beam.ml.inference.huggingface_inference_it_test.HuggingFaceInference ‑ test_hf_pipeline
apache_beam.ml.inference.onnx_inference_it_test.OnnxInference ‑ test_onnx_run_inference_roberta_sentiment_classification
apache_beam.ml.inference.onnx_inference_test
apache_beam.ml.inference.pytorch_inference_it_test.PyTorchInference ‑ test_torch_run_inference_bert_for_masked_lm
apache_beam.ml.inference.pytorch_inference_it_test.PyTorchInference ‑ test_torch_run_inference_bert_for_masked_lm_large_model
apache_beam.ml.inference.pytorch_inference_it_test.PyTorchInference ‑ test_torch_run_inference_coco_maskrcnn_resnet50_fpn
apache_beam.ml.inference.pytorch_inference_it_test.PyTorchInference ‑ test_torch_run_inference_coco_maskrcnn_resnet50_fpn_v1_and_v2
apache_beam.ml.inference.pytorch_inference_it_test.PyTorchInference ‑ test_torch_run_inference_imagenet_mobilenetv2
apache_beam.ml.inference.sklearn_inference_it_test.SklearnInference ‑ test_sklearn_mnist_classification
apache_beam.ml.inference.sklearn_inference_it_test.SklearnInference ‑ test_sklearn_mnist_classification_large_model
apache_beam.ml.inference.sklearn_inference_it_test.SklearnInference ‑ test_sklearn_regression
apache_beam.ml.inference.tensorflow_inference_it_test.TensorflowInference ‑ test_tf_imagenet_image_segmentation
apache_beam.ml.inference.tensorflow_inference_it_test.TensorflowInference ‑ test_tf_mnist_classification
apache_beam.ml.inference.tensorflow_inference_it_test.TensorflowInference ‑ test_tf_mnist_classification_large_model
apache_beam.ml.inference.tensorflow_inference_it_test.TensorflowInference ‑ test_tf_mnist_with_weights_classification
apache_beam.ml.inference.tensorrt_inference_test
apache_beam.ml.inference.vertex_ai_inference_it_test.VertexAIInference ‑ test_vertex_ai_run_flower_image_classification
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_datatable_multi_batch
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_datatable_single_batch
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_numpy_multi_batch
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_numpy_single_batch
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_numpy_single_batch_large_model
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_pandas_multi_batch
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_pandas_single_batch
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_scipy_multi_batch
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_scipy_single_batch
apache_beam.ml.inference.xgboost_inference_test
apache_beam.ml.rag.chunking.langchain_test.LangChainChunkingTest ‑ test_empty_document_field
apache_beam.ml.rag.chunking.langchain_test.LangChainChunkingTest ‑ test_empty_text
apache_beam.ml.rag.chunking.langchain_test.LangChainChunkingTest ‑ test_huggingface_tokenizer_splitter
apache_beam.ml.rag.chunking.langchain_test.LangChainChunkingTest ‑ test_invalid_document_field
apache_beam.ml.rag.chunking.langchain_test.LangChainChunkingTest ‑ test_invalid_text_splitter
apache_beam.ml.rag.chunking.langchain_test.LangChainChunkingTest ‑ test_multiple_metadata_fields
apache_beam.ml.rag.chunking.langchain_test.LangChainChunkingTest ‑ test_no_metadata_fields
apache_beam.ml.rag.chunking.langchain_test.LangChainChunkingTest ‑ test_recursive_splitter_no_overlap
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_basic_vector_search
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_batched_metadata_filter_vector_search
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_condition_batching
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_empty_input
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_euclidean_distance_search
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_include_distance
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_metadata_filter_leakage
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_no_metadata_restriction
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_price_range_filter_with_callable
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_conflict_resolution_default_ignore
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_conflict_resolution_default_update_fields
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_conflict_resolution_update
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_custom_specs
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_default_id_embedding_specs
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_default_schema
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_defaults_with_args_specs
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_language_connector
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_metadata_spec_and_conflicts
apache_beam.ml.rag.ingestion.bigquery_it_test.BigQueryVectorWriterConfigTest ‑ test_custom_schema
apache_beam.ml.rag.ingestion.bigquery_it_test.BigQueryVectorWriterConfigTest ‑ test_default_schema
apache_beam.ml.rag.ingestion.bigquery_it_test.BigQueryVectorWriterConfigTest ‑ test_default_schema_missing_embedding
apache_beam.ml.rag.ingestion.bigquery_it_test.BigQueryVectorWriterConfigTest ‑ test_streaming_default_schema
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_composite_unique_constraint_conflicts_0
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_composite_unique_constraint_conflicts_1
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_conflict_resolution_0
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_conflict_resolution_1
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_conflict_resolution_2
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_conflict_resolution_3
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_conflict_resolution_4
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_conflict_resolution_5
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_custom_column_names_and_value_functions_0
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_custom_column_names_and_value_functions_1
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_custom_type_conversion_with_default_columns_0
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_custom_type_conversion_with_default_columns_1
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_default_config_0
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_default_config_1
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_default_id_embedding_specs_0
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_default_id_embedding_specs_1
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_metadata_field_extraction_0
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_metadata_field_extraction_1
apache_beam.ml.rag.ingestion.postgres_it_test.PostgresVectorWriterConfigTest ‑ test_conflict_resolution_default_ignore
apache_beam.ml.rag.ingestion.postgres_it_test.PostgresVectorWriterConfigTest ‑ test_conflict_resolution_default_update_fields
apache_beam.ml.rag.ingestion.postgres_it_test.PostgresVectorWriterConfigTest ‑ test_conflict_resolution_update
apache_beam.ml.rag.ingestion.postgres_it_test.PostgresVectorWriterConfigTest ‑ test_custom_specs
apache_beam.ml.rag.ingestion.postgres_it_test.PostgresVectorWriterConfigTest ‑ test_default_id_embedding_specs
apache_beam.ml.rag.ingestion.postgres_it_test.PostgresVectorWriterConfigTest ‑ test_default_schema
apache_beam.ml.rag.ingestion.postgres_it_test.PostgresVectorWriterConfigTest ‑ test_defaults_with_args_specs
apache_beam.ml.rag.ingestion.postgres_it_test.PostgresVectorWriterConfigTest ‑ test_metadata_spec_and_conflicts
apache_beam.ml.rag.ingestion.spanner_it_test.SpannerVectorWriterTest ‑ test_write_custom_column
apache_beam.ml.rag.ingestion.spanner_it_test.SpannerVectorWriterTest ‑ test_write_default_schema
apache_beam.ml.rag.ingestion.spanner_it_test.SpannerVectorWriterTest ‑ test_write_flattened_metadata
apache_beam.ml.rag.ingestion.spanner_it_test.SpannerVectorWriterTest ‑ test_write_minimal_schema
apache_beam.ml.rag.ingestion.spanner_it_test.SpannerVectorWriterTest ‑ test_write_update_mode
apache_beam.ml.rag.ingestion.spanner_it_test.SpannerVectorWriterTest ‑ test_write_with_converter
apache_beam.ml.rag.ingestion.spanner_it_test.SpannerVectorWriterTest ‑ test_write_with_timestamp
apache_beam.ml.transforms.embeddings.huggingface_test.HuggingfaceInferenceAPIGCSLocationTest ‑ test_embeddings_with_inference_api
apache_beam.ml.transforms.embeddings.huggingface_test.HuggingfaceInferenceAPIGCSLocationTest ‑ test_get_api_url_and_when_model_name_not_provided
apache_beam.ml.transforms.embeddings.huggingface_test.HuggingfaceInferenceAPITest ‑ test_embeddings_with_inference_api
apache_beam.ml.transforms.embeddings.huggingface_test.HuggingfaceInferenceAPITest ‑ test_get_api_url_and_when_model_name_not_provided
apache_beam.ml.transforms.embeddings.open_ai_it_test.OpenAIEmbeddingsTest ‑ test_embeddings_with_dimensions
apache_beam.ml.transforms.embeddings.open_ai_it_test.OpenAIEmbeddingsTest ‑ test_embeddings_with_read_artifact_location
apache_beam.ml.transforms.embeddings.open_ai_it_test.OpenAIEmbeddingsTest ‑ test_embeddings_with_scale_to_0_1
apache_beam.ml.transforms.embeddings.open_ai_it_test.OpenAIEmbeddingsTest ‑ test_mltransform_to_ptransform_with_openai
apache_beam.ml.transforms.embeddings.open_ai_it_test.OpenAIEmbeddingsTest ‑ test_openai_text_embeddings
apache_beam.ml.transforms.embeddings.open_ai_it_test.OpenAIEmbeddingsTest ‑ test_with_artifact_location
apache_beam.ml.transforms.embeddings.open_ai_it_test.OpenAIEmbeddingsTest ‑ test_with_int_data_types
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubEmbeddingsGCSArtifactLocationTest ‑ test_embeddings_with_read_artifact_location
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubEmbeddingsGCSArtifactLocationTest ‑ test_embeddings_with_scale_to_0_1
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubEmbeddingsGCSArtifactLocationTest ‑ test_tfhub_text_embeddings
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubEmbeddingsGCSArtifactLocationTest ‑ test_with_int_data_types
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubEmbeddingsTest ‑ test_embeddings_with_read_artifact_location
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubEmbeddingsTest ‑ test_embeddings_with_scale_to_0_1
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubEmbeddingsTest ‑ test_tfhub_text_embeddings
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubEmbeddingsTest ‑ test_with_int_data_types
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubImageEmbeddingsTest ‑ test_sentence_transformer_image_embeddings
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubImageEmbeddingsTest ‑ test_with_str_data_types

Check notice on line 0 in .github

See this annotation in the file changed.

@github-actions github-actions / Python 3.10 Test Results (self-hosted, ubuntu-20.04, main)

577 tests found

There are 577 tests, see "Raw output" for the full list of tests.
Raw output
apache_beam.ml.anomaly.aggregations_test.AllVoteTest ‑ test_default
apache_beam.ml.anomaly.aggregations_test.AnyVoteTest ‑ test_default
apache_beam.ml.anomaly.aggregations_test.AverageScoreTest ‑ test_default
apache_beam.ml.anomaly.aggregations_test.LabelAggTestWithMissingOrError ‑ test_default
apache_beam.ml.anomaly.aggregations_test.MajorityVoteTest ‑ test_default
apache_beam.ml.anomaly.aggregations_test.MajorityVoteTest ‑ test_tie_breaker
apache_beam.ml.anomaly.aggregations_test.MaxScoreTest ‑ test_default
apache_beam.ml.anomaly.aggregations_test.ScoreAggTestWithMissingOrError ‑ test_default
apache_beam.ml.anomaly.base_test.TestAnomalyDetector ‑ test_model_id_and_spec_0
apache_beam.ml.anomaly.base_test.TestAnomalyDetector ‑ test_model_id_and_spec_1
apache_beam.ml.anomaly.base_test.TestAnomalyDetector ‑ test_model_id_and_spec_2
apache_beam.ml.anomaly.base_test.TestAnomalyDetector ‑ test_model_id_and_spec_3
apache_beam.ml.anomaly.base_test.TestEnsembleAnomalyDetector ‑ test_model_id_and_spec_0
apache_beam.ml.anomaly.base_test.TestEnsembleAnomalyDetector ‑ test_model_id_and_spec_1
apache_beam.ml.anomaly.base_test.TestEnsembleAnomalyDetector ‑ test_model_id_and_spec_2
apache_beam.ml.anomaly.base_test.TestEnsembleAnomalyDetector ‑ test_model_id_and_spec_3
apache_beam.ml.anomaly.detectors.iqr_test.IQRTest ‑ test_with_default_trackers
apache_beam.ml.anomaly.detectors.pyod_adapter_test.PyODIForestTest ‑ test_scoring_with_matched_features_0
apache_beam.ml.anomaly.detectors.pyod_adapter_test.PyODIForestTest ‑ test_scoring_with_matched_features_1
apache_beam.ml.anomaly.detectors.pyod_adapter_test.PyODIForestTest ‑ test_scoring_with_unmatched_features
apache_beam.ml.anomaly.detectors.robust_zscore_test.RobustZScoreTest ‑ test_with_default_trackers
apache_beam.ml.anomaly.detectors.zscore_test.ZScoreTest ‑ test_with_custom_mean_tracker
apache_beam.ml.anomaly.detectors.zscore_test.ZScoreTest ‑ test_with_default_trackers
apache_beam.ml.anomaly.specifiable_test.TestClassAsArgument ‑ test_normal_class
apache_beam.ml.anomaly.specifiable_test.TestFunctionAsArgument ‑ test_lambda_function
apache_beam.ml.anomaly.specifiable_test.TestFunctionAsArgument ‑ test_normal_function
apache_beam.ml.anomaly.specifiable_test.TestInitCallCount ‑ test_just_in_time_init
apache_beam.ml.anomaly.specifiable_test.TestInitCallCount ‑ test_on_demand_and_just_in_time_init
apache_beam.ml.anomaly.specifiable_test.TestInitCallCount ‑ test_on_demand_init
apache_beam.ml.anomaly.specifiable_test.TestInitCallCount ‑ test_on_dill_pickle
apache_beam.ml.anomaly.specifiable_test.TestInitCallCount ‑ test_on_pickle
apache_beam.ml.anomaly.specifiable_test.TestNestedSpecifiable ‑ test_error_in_child
apache_beam.ml.anomaly.specifiable_test.TestNestedSpecifiable ‑ test_nested_specifiable_0
apache_beam.ml.anomaly.specifiable_test.TestNestedSpecifiable ‑ test_nested_specifiable_1
apache_beam.ml.anomaly.specifiable_test.TestNestedSpecifiable ‑ test_nested_specifiable_2
apache_beam.ml.anomaly.specifiable_test.TestNestedSpecifiable ‑ test_nested_specifiable_3
apache_beam.ml.anomaly.specifiable_test.TestNestedSpecifiable ‑ test_nested_specifiable_4
apache_beam.ml.anomaly.specifiable_test.TestNestedSpecifiable ‑ test_nested_specifiable_5
apache_beam.ml.anomaly.specifiable_test.TestSpecifiable ‑ test_decorator_in_function_form
apache_beam.ml.anomaly.specifiable_test.TestSpecifiable ‑ test_decorator_in_syntactic_sugar_form
apache_beam.ml.anomaly.specifiable_test.TestSpecifiable ‑ test_from_spec_and_to_spec_0
apache_beam.ml.anomaly.specifiable_test.TestSpecifiable ‑ test_from_spec_and_to_spec_1
apache_beam.ml.anomaly.specifiable_test.TestSpecifiable ‑ test_from_spec_and_to_spec_2
apache_beam.ml.anomaly.specifiable_test.TestSpecifiable ‑ test_from_spec_and_to_spec_3
apache_beam.ml.anomaly.specifiable_test.TestSpecifiable ‑ test_from_spec_on_unknown_spec_type
apache_beam.ml.anomaly.specifiable_test.TestSpecifiable ‑ test_init_params_in_specifiable
apache_beam.ml.anomaly.specifiable_test.TestUncommonUsages ‑ test_double_specifiable
apache_beam.ml.anomaly.specifiable_test.TestUncommonUsages ‑ test_unspecifiable
apache_beam.ml.anomaly.thresholds_test.TestFixedThreshold ‑ test_apply_only
apache_beam.ml.anomaly.thresholds_test.TestQuantileThreshold ‑ test_apply_only
apache_beam.ml.anomaly.thresholds_test.TestQuantileThreshold ‑ test_quantile_tracker
apache_beam.ml.anomaly.transforms_test.TestAnomalyDetection ‑ test_multiple_detectors_without_aggregation_0
apache_beam.ml.anomaly.transforms_test.TestAnomalyDetection ‑ test_multiple_detectors_without_aggregation_1
apache_beam.ml.anomaly.transforms_test.TestAnomalyDetection ‑ test_multiple_sub_detectors_with_aggregation_0
apache_beam.ml.anomaly.transforms_test.TestAnomalyDetection ‑ test_multiple_sub_detectors_with_aggregation_1
apache_beam.ml.anomaly.transforms_test.TestAnomalyDetection ‑ test_one_detector_0
apache_beam.ml.anomaly.transforms_test.TestAnomalyDetection ‑ test_one_detector_1
apache_beam.ml.anomaly.transforms_test.TestOfflineDetector ‑ test_default_inference_fn_0
apache_beam.ml.anomaly.transforms_test.TestOfflineDetector ‑ test_default_inference_fn_1
apache_beam.ml.anomaly.transforms_test.TestOfflineDetector ‑ test_run_inference_args
apache_beam.ml.anomaly.transforms_test.TestStatefulThresholdDoFn ‑ test_dofn_on_single_prediction
apache_beam.ml.anomaly.transforms_test.TestStatelessThresholdDoFn ‑ test_dofn_on_multiple_predictions
apache_beam.ml.anomaly.transforms_test.TestStatelessThresholdDoFn ‑ test_dofn_on_single_prediction
apache_beam.ml.anomaly.univariate.mad_test.MadTest ‑ test_default_tracker
apache_beam.ml.anomaly.univariate.mean_test.LandmarkMeanTest ‑ test_accuracy_fuzz
apache_beam.ml.anomaly.univariate.mean_test.LandmarkMeanTest ‑ test_with_float64_max
apache_beam.ml.anomaly.univariate.mean_test.LandmarkMeanTest ‑ test_with_nan
apache_beam.ml.anomaly.univariate.mean_test.LandmarkMeanTest ‑ test_without_nan
apache_beam.ml.anomaly.univariate.mean_test.SlidingMeanTest ‑ test_accuracy_fuzz
apache_beam.ml.anomaly.univariate.mean_test.SlidingMeanTest ‑ test_with_float64_max_0
apache_beam.ml.anomaly.univariate.mean_test.SlidingMeanTest ‑ test_with_float64_max_1
apache_beam.ml.anomaly.univariate.mean_test.SlidingMeanTest ‑ test_with_nan_0
apache_beam.ml.anomaly.univariate.mean_test.SlidingMeanTest ‑ test_with_nan_1
apache_beam.ml.anomaly.univariate.mean_test.SlidingMeanTest ‑ test_without_nan_0
apache_beam.ml.anomaly.univariate.mean_test.SlidingMeanTest ‑ test_without_nan_1
apache_beam.ml.anomaly.univariate.median_test.MedianTest ‑ test_custom_tracker
apache_beam.ml.anomaly.univariate.median_test.MedianTest ‑ test_default_tracker
apache_beam.ml.anomaly.univariate.median_test.MedianTest ‑ test_wrong_tracker
apache_beam.ml.anomaly.univariate.perf_test.PerfTest ‑ test_mean_perf
apache_beam.ml.anomaly.univariate.perf_test.PerfTest ‑ test_quantile_perf
apache_beam.ml.anomaly.univariate.perf_test.PerfTest ‑ test_stdev_perf
apache_beam.ml.anomaly.univariate.quantile_test.LandmarkQuantileTest ‑ test_accuracy_fuzz
apache_beam.ml.anomaly.univariate.quantile_test.LandmarkQuantileTest ‑ test_with_nan
apache_beam.ml.anomaly.univariate.quantile_test.LandmarkQuantileTest ‑ test_without_nan
apache_beam.ml.anomaly.univariate.quantile_test.SlidingQuantileTest ‑ test_accuracy_fuzz
apache_beam.ml.anomaly.univariate.quantile_test.SlidingQuantileTest ‑ test_with_nan_0
apache_beam.ml.anomaly.univariate.quantile_test.SlidingQuantileTest ‑ test_with_nan_1
apache_beam.ml.anomaly.univariate.quantile_test.SlidingQuantileTest ‑ test_without_nan_0
apache_beam.ml.anomaly.univariate.stdev_test.LandmarkStdevTest ‑ test_accuracy_fuzz
apache_beam.ml.anomaly.univariate.stdev_test.LandmarkStdevTest ‑ test_with_nan
apache_beam.ml.anomaly.univariate.stdev_test.LandmarkStdevTest ‑ test_without_nan
apache_beam.ml.anomaly.univariate.stdev_test.SlidingStdevTest ‑ test_accuracy_fuzz
apache_beam.ml.anomaly.univariate.stdev_test.SlidingStdevTest ‑ test_stdev_with_nan_0
apache_beam.ml.anomaly.univariate.stdev_test.SlidingStdevTest ‑ test_stdev_with_nan_1
apache_beam.ml.anomaly.univariate.stdev_test.SlidingStdevTest ‑ test_without_nan_0
apache_beam.ml.anomaly.univariate.stdev_test.SlidingStdevTest ‑ test_without_nan_1
apache_beam.ml.gcp.cloud_dlp_it_test.CloudDLPIT ‑ test_deidentification
apache_beam.ml.gcp.cloud_dlp_it_test.CloudDLPIT ‑ test_inspection
apache_beam.ml.gcp.cloud_dlp_test.TestDeidentifyFn ‑ test_deidentify_called
apache_beam.ml.gcp.cloud_dlp_test.TestDeidentifyText ‑ test_exception_raised_when_no_config_is_provided
apache_beam.ml.gcp.cloud_dlp_test.TestInspectFn ‑ test_inspect_called
apache_beam.ml.gcp.cloud_dlp_test.TestInspectText ‑ test_exception_raised_then_no_config_provided
apache_beam.ml.gcp.naturallanguageml_test.NaturalLanguageMlTest ‑ test_document_source
apache_beam.ml.gcp.naturallanguageml_test_it.NaturalLanguageMlTestIT ‑ test_analyzing_syntax
apache_beam.ml.gcp.recommendations_ai_test.RecommendationsAICatalogItemTest ‑ test_CreateCatalogItem
apache_beam.ml.gcp.recommendations_ai_test.RecommendationsAICatalogItemTest ‑ test_ImportCatalogItems
apache_beam.ml.gcp.recommendations_ai_test.RecommendationsAIPredictTest ‑ test_Predict
apache_beam.ml.gcp.recommendations_ai_test.RecommendationsAIUserEventTest ‑ test_CreateUserEvent
apache_beam.ml.gcp.recommendations_ai_test.RecommendationsAIUserEventTest ‑ test_ImportUserEvents
apache_beam.ml.gcp.recommendations_ai_test_it.RecommendationAIIT ‑ test_create_catalog_item
apache_beam.ml.gcp.recommendations_ai_test_it.RecommendationAIIT ‑ test_create_user_event
apache_beam.ml.gcp.recommendations_ai_test_it.RecommendationAIIT ‑ test_predict
apache_beam.ml.gcp.videointelligenceml_test.VideoIntelligenceTest ‑ test_AnnotateVideoWithContext_b64_content
apache_beam.ml.gcp.videointelligenceml_test.VideoIntelligenceTest ‑ test_AnnotateVideoWithContext_bad_input
apache_beam.ml.gcp.videointelligenceml_test.VideoIntelligenceTest ‑ test_AnnotateVideo_URIs
apache_beam.ml.gcp.videointelligenceml_test.VideoIntelligenceTest ‑ test_AnnotateVideo_b64_content
apache_beam.ml.gcp.videointelligenceml_test.VideoIntelligenceTest ‑ test_AnnotateVideo_bad_input
apache_beam.ml.gcp.videointelligenceml_test.VideoIntelligenceTest ‑ test_AnnotateVideo_with_side_input_context
apache_beam.ml.gcp.videointelligenceml_test_it.VideoIntelligenceMlTestIT ‑ test_label_detection_with_video_context
apache_beam.ml.gcp.visionml_test.VisionTest ‑ test_AnnotateImageWithContext_URIs
apache_beam.ml.gcp.visionml_test.VisionTest ‑ test_AnnotateImageWithContext_bad_input
apache_beam.ml.gcp.visionml_test.VisionTest ‑ test_AnnotateImage_URI_with_side_input_context
apache_beam.ml.gcp.visionml_test.VisionTest ‑ test_AnnotateImage_URIs
apache_beam.ml.gcp.visionml_test.VisionTest ‑ test_AnnotateImage_URIs_large_batch
apache_beam.ml.gcp.visionml_test.VisionTest ‑ test_AnnotateImage_b64_content
apache_beam.ml.gcp.visionml_test.VisionTest ‑ test_AnnotateImage_bad_input
apache_beam.ml.gcp.visionml_test_it.VisionMlTestIT ‑ test_text_detection_with_language_hint
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_child_class_without_env_vars
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_counted_metrics
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_env_vars_set_correctly
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_failed_batches_counter_no_failures
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_forwards_batch_args
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_increment_failed_batches_counter
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_keyed_many_model_handlers_validation
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_keyed_model_handler_get_num_bytes
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_keyed_model_handler_multiple_models_get_num_bytes
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_model_handler_compatibility
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_model_manager_evicts_correct_num_of_models_after_being_incremented
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_model_manager_evicts_models
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_model_manager_evicts_models_after_update
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_model_manager_loads_shared_model
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_model_status_provides_valid_garbage_collection
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_model_status_provides_valid_tags
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_empty_side_input
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_impl_dlq
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_impl_inference_args
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_impl_keyed_mps_incrementing_multi_copy
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_impl_mps_nobatch_incrementing_multi_copy
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_impl_multi_process_shared_incrementing_multi_copy
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_impl_simple_examples
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_impl_simple_examples_multi_process_shared
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_impl_simple_examples_multi_process_shared_multi_copy
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_impl_with_keyed_examples
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_impl_with_keyed_examples_many_mhs_max_models_hint
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_impl_with_keyed_examples_many_model_handlers
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_impl_with_keyed_examples_many_model_handlers_metrics
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_impl_with_keyed_examples_multi_process_shared
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_impl_with_maybe_keyed_examples
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_impl_with_maybe_keyed_examples_multi_process_shared
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_keyed_examples_with_unkeyed_model_handler
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_keyed_pre_and_post_processing
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_loads_different_models
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_loads_different_models_multi_process_shared
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_maybe_keyed_pre_and_post_processing
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_metrics_with_custom_namespace
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_postprocessing
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_postprocessing_dlq
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_postprocessing_multiple_fns
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_pre_and_post_processing_dlq
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_prebatched
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_prediction_result_with_model_id
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_preprocessing
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_preprocessing_dlq
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_preprocessing_multiple_fns
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_side_input_in_batch
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_side_input_in_batch_multi_process_shared
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_side_input_in_batch_per_key_models
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_side_input_in_batch_per_key_models_split_cohort
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_timeout_does_garbage_collection
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_timeout_not_hit
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_timeout_on_inference_dlq
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_timeout_on_load_dlq
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_unkeyed_examples_with_keyed_model_handler
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_watch_file_pattern_keyword_arg_side_input_label
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_watch_file_pattern_side_input_label
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_with_iterable_side_input
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_with_iterable_side_input_multi_process_shared
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_run_inference_with_side_inputin_streaming
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_runinference_loads_same_model_with_identifier_multi_process_shared
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_timing_metrics
apache_beam.ml.inference.base_test.RunInferenceBaseTest ‑ test_unexpected_inference_args_passed
apache_beam.ml.inference.base_test.RunInferenceRemoteTest ‑ test_exception_on_load_model_override
apache_beam.ml.inference.base_test.RunInferenceRemoteTest ‑ test_exception_on_run_inference_override
apache_beam.ml.inference.base_test.RunInferenceRemoteTest ‑ test_normal_model_execution
apache_beam.ml.inference.base_test.RunInferenceRemoteTest ‑ test_repeated_requests_fail
apache_beam.ml.inference.base_test.RunInferenceRemoteTest ‑ test_works_on_retry
apache_beam.ml.inference.gemini_inference_it_test.GeminiInference ‑ test_gemini_image_generation
apache_beam.ml.inference.gemini_inference_it_test.GeminiInference ‑ test_gemini_text_classification
apache_beam.ml.inference.gemini_inference_test.ModelHandlerArgConditions ‑ test_all_params_set
apache_beam.ml.inference.gemini_inference_test.ModelHandlerArgConditions ‑ test_missing_all_params
apache_beam.ml.inference.gemini_inference_test.ModelHandlerArgConditions ‑ test_missing_vertex_location_param
apache_beam.ml.inference.gemini_inference_test.ModelHandlerArgConditions ‑ test_missing_vertex_project_param
apache_beam.ml.inference.gemini_inference_test.RetryOnClientErrorTest ‑ test_retry_on_client_error_negative
apache_beam.ml.inference.gemini_inference_test.RetryOnClientErrorTest ‑ test_retry_on_client_error_positive
apache_beam.ml.inference.gemini_inference_test.RetryOnClientErrorTest ‑ test_retry_on_server_error
apache_beam.ml.inference.huggingface_inference_it_test.HuggingFaceInference ‑ test_hf_language_modeling
apache_beam.ml.inference.huggingface_inference_it_test.HuggingFaceInference ‑ test_hf_language_modeling_large_model
apache_beam.ml.inference.huggingface_inference_it_test.HuggingFaceInference ‑ test_hf_pipeline
apache_beam.ml.inference.huggingface_inference_test.HuggingFaceInferenceTest ‑ test_convert_to_result_batch_processing
apache_beam.ml.inference.huggingface_inference_test.HuggingFaceInferenceTest ‑ test_framework_detection_tensorflow
apache_beam.ml.inference.huggingface_inference_test.HuggingFaceInferenceTest ‑ test_framework_detection_torch
apache_beam.ml.inference.huggingface_inference_test.HuggingFaceInferenceTest ‑ test_predict_tensor
apache_beam.ml.inference.huggingface_inference_test.HuggingFaceInferenceTest ‑ test_predict_tensor_with_inference_args
apache_beam.ml.inference.onnx_inference_it_test.OnnxInference ‑ test_onnx_run_inference_roberta_sentiment_classification
apache_beam.ml.inference.onnx_inference_test
apache_beam.ml.inference.pytorch_inference_it_test.PyTorchInference ‑ test_torch_run_inference_bert_for_masked_lm
apache_beam.ml.inference.pytorch_inference_it_test.PyTorchInference ‑ test_torch_run_inference_bert_for_masked_lm_large_model
apache_beam.ml.inference.pytorch_inference_it_test.PyTorchInference ‑ test_torch_run_inference_coco_maskrcnn_resnet50_fpn
apache_beam.ml.inference.pytorch_inference_it_test.PyTorchInference ‑ test_torch_run_inference_coco_maskrcnn_resnet50_fpn_v1_and_v2
apache_beam.ml.inference.pytorch_inference_it_test.PyTorchInference ‑ test_torch_run_inference_imagenet_mobilenetv2
apache_beam.ml.inference.pytorch_inference_test.PytorchInferenceTestWithMocks ‑ test_load_model_args_keyed_tensor
apache_beam.ml.inference.pytorch_inference_test.PytorchInferenceTestWithMocks ‑ test_load_model_args_tensor
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_env_vars_set_correctly_keyed_tensor_handler
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_env_vars_set_correctly_tensor_handler
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_gpu_auto_convert_to_cpu
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_inference_torch_script_model
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_invalid_input_type
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_load_torch_script_model
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_pipeline_gcs_model
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_pipeline_gcs_model_control_batching
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_pipeline_local_model_extra_inference_args
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_pipeline_local_model_extra_inference_args_batching_args
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_pipeline_local_model_extra_inference_args_large
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_pipeline_local_model_large
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_pipeline_local_model_simple
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_prediction_result_model_id_with_torch_model
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_prediction_result_model_id_with_torch_script_model
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_specify_torch_script_path_and_state_dict_path
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_torch_model_class_none
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferencePipelineTest ‑ test_torch_model_state_dict_none
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferenceTest ‑ test_inference_runner_inference_args
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferenceTest ‑ test_namespace
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferenceTest ‑ test_num_bytes
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferenceTest ‑ test_run_inference_custom
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferenceTest ‑ test_run_inference_helper
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferenceTest ‑ test_run_inference_keyed
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferenceTest ‑ test_run_inference_keyed_dict_output
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferenceTest ‑ test_run_inference_keyed_helper
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferenceTest ‑ test_run_inference_multiple_tensor_features
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferenceTest ‑ test_run_inference_multiple_tensor_features_dict_output
apache_beam.ml.inference.pytorch_inference_test.PytorchRunInferenceTest ‑ test_run_inference_single_tensor_feature
apache_beam.ml.inference.sklearn_inference_it_test.SklearnInference ‑ test_sklearn_mnist_classification
apache_beam.ml.inference.sklearn_inference_it_test.SklearnInference ‑ test_sklearn_mnist_classification_large_model
apache_beam.ml.inference.sklearn_inference_it_test.SklearnInference ‑ test_sklearn_regression
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_bad_file_raises
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_bad_input_type_raises
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_custom_inference_fn
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_data_vectorized
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_env_vars_set_correctly_numpy
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_infer_too_many_rows_in_dataframe
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_num_bytes_numpy
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_pipeline_joblib
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_pipeline_pandas
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_pipeline_pandas_custom_batching
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_pipeline_pandas_custom_inference
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_pipeline_pandas_dict_out
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_pipeline_pandas_env_vars_set_correctly
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_pipeline_pandas_joblib
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_pipeline_pandas_large_model
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_pipeline_pandas_with_keys
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_pipeline_pickled
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_pipeline_pickled_custom_batching
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_pipeline_pickled_large_model
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_predict_output
apache_beam.ml.inference.sklearn_inference_test.SkLearnRunInferenceTest ‑ test_predict_output_dict
apache_beam.ml.inference.tensorflow_inference_it_test.TensorflowInference ‑ test_tf_imagenet_image_segmentation
apache_beam.ml.inference.tensorflow_inference_it_test.TensorflowInference ‑ test_tf_mnist_classification
apache_beam.ml.inference.tensorflow_inference_it_test.TensorflowInference ‑ test_tf_mnist_classification_large_model
apache_beam.ml.inference.tensorflow_inference_it_test.TensorflowInference ‑ test_tf_mnist_with_weights_classification
apache_beam.ml.inference.tensorflow_inference_test.TFRunInferenceTest ‑ test_load_model_exception
apache_beam.ml.inference.tensorflow_inference_test.TFRunInferenceTest ‑ test_predict_keyed_numpy
apache_beam.ml.inference.tensorflow_inference_test.TFRunInferenceTest ‑ test_predict_keyed_tensor
apache_beam.ml.inference.tensorflow_inference_test.TFRunInferenceTest ‑ test_predict_numpy
apache_beam.ml.inference.tensorflow_inference_test.TFRunInferenceTest ‑ test_predict_numpy_with_batch_size
apache_beam.ml.inference.tensorflow_inference_test.TFRunInferenceTest ‑ test_predict_numpy_with_large_model
apache_beam.ml.inference.tensorflow_inference_test.TFRunInferenceTest ‑ test_predict_tensor
apache_beam.ml.inference.tensorflow_inference_test.TFRunInferenceTest ‑ test_predict_tensor_with_args
apache_beam.ml.inference.tensorflow_inference_test.TFRunInferenceTest ‑ test_predict_tensor_with_batch_size
apache_beam.ml.inference.tensorflow_inference_test.TFRunInferenceTest ‑ test_predict_tensor_with_large_model
apache_beam.ml.inference.tensorflow_inference_test.TFRunInferenceTestWithMocks ‑ test_env_vars_set_correctly_numpy
apache_beam.ml.inference.tensorflow_inference_test.TFRunInferenceTestWithMocks ‑ test_env_vars_set_correctly_tensor
apache_beam.ml.inference.tensorflow_inference_test.TFRunInferenceTestWithMocks ‑ test_load_model_args
apache_beam.ml.inference.tensorflow_inference_test.TFRunInferenceTestWithMocks ‑ test_load_model_with_args_and_custom_weights
apache_beam.ml.inference.tensorrt_inference_test
apache_beam.ml.inference.utils_test.WatchFilePatternTest ‑ test_emitting_singleton_output
apache_beam.ml.inference.utils_test.WatchFilePatternTest ‑ test_latest_file_by_timestamp_default_value
apache_beam.ml.inference.utils_test.WatchFilePatternTest ‑ test_latest_file_with_timestamp_after_pipeline_construction_time
apache_beam.ml.inference.vertex_ai_inference_it_test.VertexAIInference ‑ test_vertex_ai_run_flower_image_classification
apache_beam.ml.inference.vertex_ai_inference_test.ModelHandlerArgConditions ‑ test_exception_on_private_without_network
apache_beam.ml.inference.vertex_ai_inference_test.RetryOnClientErrorTest ‑ test_retry_on_client_error_negative
apache_beam.ml.inference.vertex_ai_inference_test.RetryOnClientErrorTest ‑ test_retry_on_client_error_positive
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_datatable_multi_batch
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_datatable_single_batch
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_numpy_multi_batch
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_numpy_single_batch
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_numpy_single_batch_large_model
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_pandas_multi_batch
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_pandas_single_batch
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_scipy_multi_batch
apache_beam.ml.inference.xgboost_inference_it_test.XGBoostInference ‑ test_iris_classification_scipy_single_batch
apache_beam.ml.inference.xgboost_inference_test
apache_beam.ml.rag.chunking.base_test.ChunkingTransformProviderTest ‑ test_chunking_transform
apache_beam.ml.rag.chunking.base_test.ChunkingTransformProviderTest ‑ test_custom_chunk_id_fn
apache_beam.ml.rag.chunking.base_test.ChunkingTransformProviderTest ‑ test_doesnt_override_get_text_splitter_transform
apache_beam.ml.rag.chunking.langchain_test.LangChainChunkingTest ‑ test_empty_document_field
apache_beam.ml.rag.chunking.langchain_test.LangChainChunkingTest ‑ test_empty_text
apache_beam.ml.rag.chunking.langchain_test.LangChainChunkingTest ‑ test_huggingface_tokenizer_splitter
apache_beam.ml.rag.chunking.langchain_test.LangChainChunkingTest ‑ test_invalid_document_field
apache_beam.ml.rag.chunking.langchain_test.LangChainChunkingTest ‑ test_invalid_text_splitter
apache_beam.ml.rag.chunking.langchain_test.LangChainChunkingTest ‑ test_multiple_metadata_fields
apache_beam.ml.rag.chunking.langchain_test.LangChainChunkingTest ‑ test_no_metadata_fields
apache_beam.ml.rag.chunking.langchain_test.LangChainChunkingTest ‑ test_recursive_splitter_no_overlap
apache_beam.ml.rag.embeddings.base_test.RAGBaseEmbeddingsTest ‑ test_adapter_input_conversion
apache_beam.ml.rag.embeddings.base_test.RAGBaseEmbeddingsTest ‑ test_adapter_input_conversion_missing_text_content
apache_beam.ml.rag.embeddings.base_test.RAGBaseEmbeddingsTest ‑ test_adapter_output_conversion
apache_beam.ml.rag.embeddings.huggingface_test.HuggingfaceTextEmbeddingsTest ‑ test_embedding_pipeline
apache_beam.ml.rag.embeddings.vertex_ai_test.VertexAITextEmbeddingsTest ‑ test_embedding_pipeline
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_basic_vector_search
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_batched_metadata_filter_vector_search
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_condition_batching
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_empty_input
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_euclidean_distance_search
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_include_distance
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_invalid_query
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_metadata_filter_leakage
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_missing_embedding
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_no_metadata_restriction
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_price_range_filter_with_callable
apache_beam.ml.rag.enrichment.milvus_search_test.TestMilvusHybridSearchEnrichment ‑ test_invalid_search_parameters_0
apache_beam.ml.rag.enrichment.milvus_search_test.TestMilvusHybridSearchEnrichment ‑ test_invalid_search_parameters_1
apache_beam.ml.rag.enrichment.milvus_search_test.TestMilvusHybridSearchEnrichment ‑ test_invalid_search_parameters_2
apache_beam.ml.rag.enrichment.milvus_search_test.TestMilvusHybridSearchEnrichment ‑ test_invalid_search_parameters_3
apache_beam.ml.rag.enrichment.milvus_search_test.TestMilvusKeywordSearchEnrichment ‑ test_invalid_search_parameters_0
apache_beam.ml.rag.enrichment.milvus_search_test.TestMilvusKeywordSearchEnrichment ‑ test_invalid_search_parameters_1
apache_beam.ml.rag.enrichment.milvus_search_test.TestMilvusKeywordSearchEnrichment ‑ test_missing_sparse_embedding_only
apache_beam.ml.rag.enrichment.milvus_search_test.TestMilvusKeywordSearchEnrichment ‑ test_missing_text_content_and_sparse_embedding
apache_beam.ml.rag.enrichment.milvus_search_test.TestMilvusKeywordSearchEnrichment ‑ test_missing_text_content_only
apache_beam.ml.rag.enrichment.milvus_search_test.TestMilvusSearchEnrichment ‑ test_invalid_connection_parameters
apache_beam.ml.rag.enrichment.milvus_search_test.TestMilvusSearchEnrichment ‑ test_invalid_search_parameters_0
apache_beam.ml.rag.enrichment.milvus_search_test.TestMilvusSearchEnrichment ‑ test_invalid_search_parameters_1
apache_beam.ml.rag.enrichment.milvus_search_test.TestMilvusSearchEnrichment ‑ test_unpack_dataclass_with_kwargs
apache_beam.ml.rag.enrichment.milvus_search_test.TestMilvusVectorSearchEnrichment ‑ test_invalid_search_parameters_0
apache_beam.ml.rag.enrichment.milvus_search_test.TestMilvusVectorSearchEnrichment ‑ test_invalid_search_parameters_1
apache_beam.ml.rag.enrichment.milvus_search_test.TestMilvusVectorSearchEnrichment ‑ test_missing_dense_embedding
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_conflict_resolution_default_ignore
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_conflict_resolution_default_update_fields
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_conflict_resolution_update
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_custom_specs
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_default_id_embedding_specs
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_default_schema
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_defaults_with_args_specs
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_language_connector
apache_beam.ml.rag.ingestion.alloydb_it_test.AlloydbVectorWriterConfigTest ‑ test_metadata_spec_and_conflicts
apache_beam.ml.rag.ingestion.base_test.VectorDatabaseBaseTest ‑ test_invalid_config
apache_beam.ml.rag.ingestion.base_test.VectorDatabaseBaseTest ‑ test_pipeline_integration
apache_beam.ml.rag.ingestion.base_test.VectorDatabaseBaseTest ‑ test_write_transform_creation
apache_beam.ml.rag.ingestion.bigquery_it_test.BigQueryVectorWriterConfigTest ‑ test_custom_schema
apache_beam.ml.rag.ingestion.bigquery_it_test.BigQueryVectorWriterConfigTest ‑ test_default_schema
apache_beam.ml.rag.ingestion.bigquery_it_test.BigQueryVectorWriterConfigTest ‑ test_default_schema_missing_embedding
apache_beam.ml.rag.ingestion.bigquery_it_test.BigQueryVectorWriterConfigTest ‑ test_streaming_default_schema
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_composite_unique_constraint_conflicts_0
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_composite_unique_constraint_conflicts_1
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_conflict_resolution_0
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_conflict_resolution_1
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_conflict_resolution_2
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_conflict_resolution_3
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_conflict_resolution_4
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_conflict_resolution_5
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_custom_column_names_and_value_functions_0
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_custom_column_names_and_value_functions_1
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_custom_type_conversion_with_default_columns_0
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_custom_type_conversion_with_default_columns_1
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_default_config_0
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_default_config_1
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_default_id_embedding_specs_0
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_default_id_embedding_specs_1
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_metadata_field_extraction_0
apache_beam.ml.rag.ingestion.cloudsql_it_test.CloudSQLVectorWriterConfigTest ‑ test_metadata_field_extraction_1
apache_beam.ml.rag.ingestion.milvus_search_test.TestMilvusVectorWriterConfig ‑ test_create_converter_returns_callable
apache_beam.ml.rag.ingestion.milvus_search_test.TestMilvusVectorWriterConfig ‑ test_create_write_transform_returns_ptransform
apache_beam.ml.rag.ingestion.milvus_search_test.TestMilvusVectorWriterConfig ‑ test_default_column_specs_has_expected_fields
apache_beam.ml.rag.ingestion.milvus_search_test.TestMilvusVectorWriterConfig ‑ test_invalid_configuration_parameters_0
apache_beam.ml.rag.ingestion.milvus_search_test.TestMilvusVectorWriterConfig ‑ test_invalid_configuration_parameters_1
apache_beam.ml.rag.ingestion.milvus_search_test.TestMilvusVectorWriterConfig ‑ test_valid_config_creation
apache_beam.ml.rag.ingestion.milvus_search_test.TestMilvusWriteConfig ‑ test_empty_collection_name_raises_error
apache_beam.ml.rag.ingestion.milvus_search_test.TestMilvusWriteConfig ‑ test_none_collection_name_raises_error
apache_beam.ml.rag.ingestion.postgres_it_test.PostgresVectorWriterConfigTest ‑ test_conflict_resolution_default_ignore
apache_beam.ml.rag.ingestion.postgres_it_test.PostgresVectorWriterConfigTest ‑ test_conflict_resolution_default_update_fields
apache_beam.ml.rag.ingestion.postgres_it_test.PostgresVectorWriterConfigTest ‑ test_conflict_resolution_update
apache_beam.ml.rag.ingestion.postgres_it_test.PostgresVectorWriterConfigTest ‑ test_custom_specs
apache_beam.ml.rag.ingestion.postgres_it_test.PostgresVectorWriterConfigTest ‑ test_default_id_embedding_specs
apache_beam.ml.rag.ingestion.postgres_it_test.PostgresVectorWriterConfigTest ‑ test_default_schema
apache_beam.ml.rag.ingestion.postgres_it_test.PostgresVectorWriterConfigTest ‑ test_defaults_with_args_specs
apache_beam.ml.rag.ingestion.postgres_it_test.PostgresVectorWriterConfigTest ‑ test_metadata_spec_and_conflicts
apache_beam.ml.rag.ingestion.spanner_it_test.SpannerVectorWriterTest ‑ test_write_custom_column
apache_beam.ml.rag.ingestion.spanner_it_test.SpannerVectorWriterTest ‑ test_write_default_schema
apache_beam.ml.rag.ingestion.spanner_it_test.SpannerVectorWriterTest ‑ test_write_flattened_metadata
apache_beam.ml.rag.ingestion.spanner_it_test.SpannerVectorWriterTest ‑ test_write_minimal_schema
apache_beam.ml.rag.ingestion.spanner_it_test.SpannerVectorWriterTest ‑ test_write_update_mode
apache_beam.ml.rag.ingestion.spanner_it_test.SpannerVectorWriterTest ‑ test_write_with_converter
apache_beam.ml.rag.ingestion.spanner_it_test.SpannerVectorWriterTest ‑ test_write_with_timestamp
apache_beam.ml.transforms.base_test.BaseMLTransformTest ‑ test_ml_transform_appends_transforms_to_process_handler_correctly
apache_beam.ml.transforms.base_test.BaseMLTransformTest ‑ test_ml_transform_dict_output_pcoll_schema_0
apache_beam.ml.transforms.base_test.BaseMLTransformTest ‑ test_ml_transform_dict_output_pcoll_schema_1
apache_beam.ml.transforms.base_test.BaseMLTransformTest ‑ test_ml_transform_dict_output_pcoll_schema_2
apache_beam.ml.transforms.base_test.BaseMLTransformTest ‑ test_ml_transform_dict_output_pcoll_schema_3
apache_beam.ml.transforms.base_test.BaseMLTransformTest ‑ test_ml_transform_fail_for_non_global_windows_in_produce_mode
apache_beam.ml.transforms.base_test.BaseMLTransformTest ‑ test_ml_transform_no_read_or_write_artifact_lcoation
apache_beam.ml.transforms.base_test.BaseMLTransformTest ‑ test_ml_transform_on_dict
apache_beam.ml.transforms.base_test.BaseMLTransformTest ‑ test_ml_transform_on_list_dict
apache_beam.ml.transforms.base_test.BaseMLTransformTest ‑ test_ml_transform_on_multiple_columns_single_transform
apache_beam.ml.transforms.base_test.BaseMLTransformTest ‑ test_ml_transforms_on_multiple_columns_multiple_transforms
apache_beam.ml.transforms.base_test.BaseMLTransformTest ‑ test_mltransform_with_counter
apache_beam.ml.transforms.base_test.BaseMLTransformTest ‑ test_non_ptransfrom_provider_class_to_mltransform
apache_beam.ml.transforms.base_test.BaseMLTransformTest ‑ test_read_mode_with_transforms
apache_beam.ml.transforms.base_test.MLTransformDLQTest ‑ test_dlq_with_embeddings
apache_beam.ml.transforms.base_test.MLTransformDLQTest ‑ test_mltransform_with_dlq_and_extract_tranform_name
apache_beam.ml.transforms.base_test.TestImageEmbeddingHandler ‑ test_handler_with_dict_inputs
apache_beam.ml.transforms.base_test.TestImageEmbeddingHandler ‑ test_handler_with_non_dict_datatype
apache_beam.ml.transforms.base_test.TestImageEmbeddingHandler ‑ test_handler_with_non_image_datatype
apache_beam.ml.transforms.base_test.TestJsonPickleTransformAttributeManager ‑ test_mltransform_to_ptransform_wrapper
apache_beam.ml.transforms.base_test.TestJsonPickleTransformAttributeManager ‑ test_save_and_load_run_inference
apache_beam.ml.transforms.base_test.TestJsonPickleTransformAttributeManager ‑ test_save_run_inference
apache_beam.ml.transforms.base_test.TestJsonPickleTransformAttributeManager ‑ test_save_tft_process_handler
apache_beam.ml.transforms.base_test.TestJsonPickleTransformAttributeManager ‑ test_with_gcs_location_with_none_options
apache_beam.ml.transforms.base_test.TestJsonPickleTransformAttributeManager ‑ test_with_same_local_artifact_location
apache_beam.ml.transforms.base_test.TestMultiModalEmbeddingHandler ‑ test_handler_with_dict_inputs
apache_beam.ml.transforms.base_test.TestMultiModalEmbeddingHandler ‑ test_handler_with_incorrect_datatype
apache_beam.ml.transforms.base_test.TestMultiModalEmbeddingHandler ‑ test_handler_with_non_dict_datatype
apache_beam.ml.transforms.base_test.TestUtilFunctions ‑ test_dict_input_fn_normal
apache_beam.ml.transforms.base_test.TestUtilFunctions ‑ test_dict_input_fn_on_list_inputs
apache_beam.ml.transforms.base_test.TestUtilFunctions ‑ test_dict_output_fn_normal
apache_beam.ml.transforms.base_test.TestUtilFunctions ‑ test_dict_output_fn_on_list_inputs
apache_beam.ml.transforms.base_test.TextEmbeddingHandlerTest ‑ test_handler_on_columns_not_exist_in_input_data
apache_beam.ml.transforms.base_test.TextEmbeddingHandlerTest ‑ test_handler_on_multiple_columns
apache_beam.ml.transforms.base_test.TextEmbeddingHandlerTest ‑ test_handler_with_batch_sizes
apache_beam.ml.transforms.base_test.TextEmbeddingHandlerTest ‑ test_handler_with_dict_inputs
apache_beam.ml.transforms.base_test.TextEmbeddingHandlerTest ‑ test_handler_with_incompatible_datatype
apache_beam.ml.transforms.base_test.TextEmbeddingHandlerTest ‑ test_handler_with_inconsistent_keys
apache_beam.ml.transforms.base_test.TextEmbeddingHandlerTest ‑ test_handler_with_list_data
apache_beam.ml.transforms.base_test.TextEmbeddingHandlerTest ‑ test_no_columns_or_type_adapter
apache_beam.ml.transforms.embeddings.huggingface_test.HuggingfaceInferenceAPIGCSLocationTest ‑ test_embeddings_with_inference_api
apache_beam.ml.transforms.embeddings.huggingface_test.HuggingfaceInferenceAPIGCSLocationTest ‑ test_get_api_url_and_when_model_name_not_provided
apache_beam.ml.transforms.embeddings.huggingface_test.HuggingfaceInferenceAPITest ‑ test_embeddings_with_inference_api
apache_beam.ml.transforms.embeddings.huggingface_test.HuggingfaceInferenceAPITest ‑ test_get_api_url_and_when_model_name_not_provided
apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest ‑ test_embeddings_with_inference_args
apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest ‑ test_embeddings_with_read_artifact_location_0
apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest ‑ test_embeddings_with_read_artifact_location_1
apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest ‑ test_embeddings_with_read_artifact_location_2
apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest ‑ test_embeddings_with_scale_to_0_1
apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest ‑ test_mltransform_to_ptransform_with_sentence_transformer
apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest ‑ test_sentence_transformer_embeddings
apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest ‑ test_sentence_transformer_image_embeddings
apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest ‑ test_sentence_transformer_images_with_str_data_types
apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest ‑ test_sentence_transformer_with_int_data_types
apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest ‑ test_with_gcs_artifact_location_0
apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest ‑ test_with_gcs_artifact_location_1
apache_beam.ml.transforms.embeddings.huggingface_test.SentenceTransformerEmbeddingsTest ‑ test_with_gcs_artifact_location_2
apache_beam.ml.transforms.embeddings.open_ai_it_test.OpenAIEmbeddingsTest ‑ test_embeddings_with_dimensions
apache_beam.ml.transforms.embeddings.open_ai_it_test.OpenAIEmbeddingsTest ‑ test_embeddings_with_read_artifact_location
apache_beam.ml.transforms.embeddings.open_ai_it_test.OpenAIEmbeddingsTest ‑ test_embeddings_with_scale_to_0_1
apache_beam.ml.transforms.embeddings.open_ai_it_test.OpenAIEmbeddingsTest ‑ test_mltransform_to_ptransform_with_openai
apache_beam.ml.transforms.embeddings.open_ai_it_test.OpenAIEmbeddingsTest ‑ test_openai_text_embeddings
apache_beam.ml.transforms.embeddings.open_ai_it_test.OpenAIEmbeddingsTest ‑ test_with_artifact_location
apache_beam.ml.transforms.embeddings.open_ai_it_test.OpenAIEmbeddingsTest ‑ test_with_int_data_types
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubEmbeddingsGCSArtifactLocationTest ‑ test_embeddings_with_read_artifact_location
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubEmbeddingsGCSArtifactLocationTest ‑ test_embeddings_with_scale_to_0_1
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubEmbeddingsGCSArtifactLocationTest ‑ test_tfhub_text_embeddings
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubEmbeddingsGCSArtifactLocationTest ‑ test_with_int_data_types
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubEmbeddingsTest ‑ test_embeddings_with_read_artifact_location
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubEmbeddingsTest ‑ test_embeddings_with_scale_to_0_1
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubEmbeddingsTest ‑ test_tfhub_text_embeddings
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubEmbeddingsTest ‑ test_with_int_data_types
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubImageEmbeddingsTest ‑ test_sentence_transformer_image_embeddings
apache_beam.ml.transforms.embeddings.tensorflow_hub_test.TFHubImageEmbeddingsTest ‑ test_with_str_data_types
apache_beam.ml.transforms.embeddings.vertex_ai_test.VertexAIEmbeddingsTest ‑ test_embeddings_with_read_artifact_location
apache_beam.ml.transforms.embeddings.vertex_ai_test.VertexAIEmbeddingsTest ‑ test_embeddings_with_scale_to_0_1
apache_beam.ml.transforms.embeddings.vertex_ai_test.VertexAIEmbeddingsTest ‑ test_mltransform_to_ptransform_with_vertex
apache_beam.ml.transforms.embeddings.vertex_ai_test.VertexAIEmbeddingsTest ‑ test_vertex_ai_text_embeddings
apache_beam.ml.transforms.embeddings.vertex_ai_test.VertexAIEmbeddingsTest ‑ test_with_gcs_artifact_location
apache_beam.ml.transforms.embeddings.vertex_ai_test.VertexAIEmbeddingsTest ‑ test_with_int_data_types
apache_beam.ml.transforms.embeddings.vertex_ai_test.VertexAIImageEmbeddingsTest ‑ test_improper_dimension
apache_beam.ml.transforms.embeddings.vertex_ai_test.VertexAIImageEmbeddingsTest ‑ test_vertex_ai_image_embedding
apache_beam.ml.transforms.embeddings.vertex_ai_test.VertexAIMultiModalEmbeddingsTest ‑ test_improper_dimension
apache_beam.ml.transforms.embeddings.vertex_ai_test.VertexAIMultiModalEmbeddingsTest ‑ test_improper_video_dimension
apache_beam.ml.transforms.embeddings.vertex_ai_test.VertexAIMultiModalEmbeddingsTest ‑ test_missing_columns
apache_beam.ml.transforms.embeddings.vertex_ai_test.VertexAIMultiModalEmbeddingsTest ‑ test_vertex_ai_multimodal_embedding_img_and_text
apache_beam.ml.transforms.embeddings.vertex_ai_test.VertexAIMultiModalEmbeddingsTest ‑ test_vertex_ai_multimodal_embedding_video
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_consume_mode_with_extra_columns_in_the_input
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_handler_with_same_input_elements
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_input_type_from_named_tuple_pcoll_numpy
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_input_type_from_row_type_pcoll
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_input_type_from_row_type_pcoll_list
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_input_type_from_schema_named_tuple_pcoll
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_input_type_from_schema_named_tuple_pcoll_list
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_tensorflow_raw_data_metadata_dtypes
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_tensorflow_raw_data_metadata_numpy_types
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_tensorflow_raw_data_metadata_primitive_native_container_types
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_tensorflow_raw_data_metadata_primitive_types
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_tensorflow_raw_data_metadata_primitive_types_in_containers
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_tensorflow_raw_data_metadata_union_type_in_single_column
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_tft_operation_preprocessing_fn_0
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_tft_operation_preprocessing_fn_1
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_tft_process_handler_default_transform_types
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_tft_process_handler_transformed_data_schema
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_tft_process_handler_unused_column
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTest ‑ test_tft_process_handler_verify_artifacts
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_consume_mode_with_extra_columns_in_the_input
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_handler_with_same_input_elements
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_input_type_from_named_tuple_pcoll_numpy
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_input_type_from_row_type_pcoll
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_input_type_from_row_type_pcoll_list
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_input_type_from_schema_named_tuple_pcoll
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_input_type_from_schema_named_tuple_pcoll_list
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_tensorflow_raw_data_metadata_dtypes
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_tensorflow_raw_data_metadata_numpy_types
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_tensorflow_raw_data_metadata_primitive_native_container_types
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_tensorflow_raw_data_metadata_primitive_types
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_tensorflow_raw_data_metadata_primitive_types_in_containers
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_tensorflow_raw_data_metadata_union_type_in_single_column
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_tft_operation_preprocessing_fn_0
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_tft_operation_preprocessing_fn_1
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_tft_process_handler_default_transform_types
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_tft_process_handler_transformed_data_schema
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_tft_process_handler_unused_column
apache_beam.ml.transforms.handlers_test.TFTProcessHandlerTestWithGCSLocation ‑ test_tft_process_handler_verify_artifacts
apache_beam.ml.transforms.tft_test.ApplyBucketsTest ‑ test_apply_buckets_0
apache_beam.ml.transforms.tft_test.ApplyBucketsTest ‑ test_apply_buckets_1
apache_beam.ml.transforms.tft_test.ApplyBucketsWithInterpolationTest ‑ test_apply_buckets_0
apache_beam.ml.transforms.tft_test.ApplyBucketsWithInterpolationTest ‑ test_apply_buckets_1
apache_beam.ml.transforms.tft_test.BagOfWordsTest ‑ test_bag_of_words_on_by_splitting_input_text
apache_beam.ml.transforms.tft_test.BagOfWordsTest ‑ test_bag_of_words_on_list_seperated_words_custom_ngrams
apache_beam.ml.transforms.tft_test.BagOfWordsTest ‑ test_bag_of_words_on_list_seperated_words_default_ngrams
apache_beam.ml.transforms.tft_test.BagOfWordsTest ‑ test_bag_of_words_on_numpy_data
apache_beam.ml.transforms.tft_test.BagOfWordsTest ‑ test_count_per_key_on_list
apache_beam.ml.transforms.tft_test.BucketizeTest ‑ test_bucketize
apache_beam.ml.transforms.tft_test.BucketizeTest ‑ test_bucketize_list
apache_beam.ml.transforms.tft_test.ComputeAndApplyVocabTest ‑ test_compute_and_apply_vocabulary
apache_beam.ml.transforms.tft_test.ComputeAndApplyVocabTest ‑ test_compute_and_apply_vocabulary_inputs
apache_beam.ml.transforms.tft_test.ComputeAndApplyVocabTest ‑ test_multiple_columns_with_default_vocab_name
apache_beam.ml.transforms.tft_test.ComputeAndApplyVocabTest ‑ test_multiple_columns_with_vocab_name
apache_beam.ml.transforms.tft_test.ComputeAndApplyVocabTest ‑ test_string_split_with_multiple_delimiters
apache_beam.ml.transforms.tft_test.ComputeAndApplyVocabTest ‑ test_string_split_with_single_delimiter
apache_beam.ml.transforms.tft_test.ComputeAndApplyVocabTest ‑ test_with_basic_example_list
apache_beam.ml.transforms.tft_test.DeduplicateTensorPerRowTest ‑ test_deduplicate
apache_beam.ml.transforms.tft_test.DeduplicateTensorPerRowTest ‑ test_deduplicate_different_output_sizes
apache_beam.ml.transforms.tft_test.DeduplicateTensorPerRowTest ‑ test_deduplicate_no_op
apache_beam.ml.transforms.tft_test.HashStringsTest ‑ test_multi_bucket_one_string
apache_beam.ml.transforms.tft_test.HashStringsTest ‑ test_multi_buckets_multi_string
apache_beam.ml.transforms.tft_test.HashStringsTest ‑ test_one_bucket_multi_string
apache_beam.ml.transforms.tft_test.HashStringsTest ‑ test_single_bucket
apache_beam.ml.transforms.tft_test.HashStringsTest ‑ test_two_bucket_multi_string
apache_beam.ml.transforms.tft_test.NGramsTest ‑ test_ngrams_on_list_separated_words
apache_beam.ml.transforms.tft_test.NGramsTest ‑ test_ngrams_on_list_separated_words_default_args
apache_beam.ml.transforms.tft_test.NGramsTest ‑ test_with_multiple_string_delimiters
apache_beam.ml.transforms.tft_test.NGramsTest ‑ test_with_string_split_delimiter
apache_beam.ml.transforms.tft_test.ScaleTo01Test ‑ test_ScaleTo01
apache_beam.ml.transforms.tft_test.ScaleTo01Test ‑ test_ScaleTo01_list
apache_beam.ml.transforms.tft_test.ScaleToGaussianTest ‑ test_gaussian_list_skewed_distribution
apache_beam.ml.transforms.tft_test.ScaleToGaussianTest ‑ test_gaussian_list_uniform_distribution
apache_beam.ml.transforms.tft_test.ScaleToGaussianTest ‑ test_gaussian_skewed
apache_beam.ml.transforms.tft_test.ScaleToGaussianTest ‑ test_gaussian_uniform
apache_beam.ml.transforms.tft_test.ScaleToMinMaxTest ‑ test_fail_max_value_less_than_min
apache_beam.ml.transforms.tft_test.ScaleToMinMaxTest ‑ test_scale_to_min_max
apache_beam.ml.transforms.tft_test.ScaleZScoreTest ‑ test_z_score
apache_beam.ml.transforms.tft_test.ScaleZScoreTest ‑ test_z_score_list_data
apache_beam.ml.transforms.tft_test.TFIDIFTest ‑ test_tfidf_compute_vocab_size_during_runtime