Skip to content

Add rag enrichment and ingestion. #22334

Add rag enrichment and ingestion.

Add rag enrichment and ingestion. #22334

GitHub Actions / Test Results failed Dec 19, 2024 in 0s

4 errors, 65 skipped, 308 pass in 3m 10s

  2 files  +  2    2 suites  +2   3m 10s ⏱️ + 3m 10s
377 tests +377  308 ✅ +308  65 💤 +65  0 ❌ ±0  4 🔥 +4 
382 runs  +382  308 ✅ +308  70 💤 +70  0 ❌ ±0  4 🔥 +4 

Results for commit 3044d1d. ± Comparison against earlier commit 589023f.

Annotations

Check failure on line 0 in apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT

See this annotation in the file changed.

@github-actions github-actions / Test Results

test_basic_vector_search (apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT) with error

sdks/python/test-suites/tox/py39/build/srcs/sdks/python/pytest_py39-ml.xml [took 0s]
Raw output
failed on setup with "apitools.base.py.exceptions.HttpForbiddenError: HttpError accessing <https://bigquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets?alt=json>: response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 19 Dec 2024 21:25:44 GMT', 'server': 'ESF', 'cache-control': 'private', 'x-xss-protection': '0', 'x-frame-options': 'SAMEORIGIN', 'x-content-type-options': 'nosniff', 'transfer-encoding': 'chunked', 'status': '403', 'content-length': '450', '-content-encoding': 'gzip'}>, content <{
  "error": {
    "code": 403,
    "message": "Access Denied: Project dataflow-test: User does not have bigquery.datasets.create permission in project dataflow-test.",
    "errors": [
      {
        "message": "Access Denied: Project dataflow-test: User does not have bigquery.datasets.create permission in project dataflow-test.",
        "domain": "global",
        "reason": "accessDenied"
      }
    ],
    "status": "PERMISSION_DENIED"
  }
}
>"
self = <apache_beam.io.gcp.bigquery_tools.BigQueryWrapper object at 0x787844169190>
project_id = 'dataflow-test'
dataset_id = 'python_vector_search_test_17346435446a7aa2', location = None
labels = None

    @retry.with_exponential_backoff(
        num_retries=MAX_RETRIES,
        retry_filter=retry.retry_on_server_errors_and_timeout_filter)
    def get_or_create_dataset(
        self, project_id, dataset_id, location=None, labels=None):
      # Check if dataset already exists otherwise create it
      try:
>       dataset = self.client.datasets.Get(
            bigquery.BigqueryDatasetsGetRequest(
                projectId=project_id, datasetId=dataset_id))

target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/io/gcp/bigquery_tools.py:829: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/io/gcp/internal/clients/bigquery/bigquery_v2_client.py:133: in Get
    return self._RunMethod(config, request, global_params=global_params)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:731: in _RunMethod
    return self.ProcessHttpResponse(method_config, http_response, request)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:737: in ProcessHttpResponse
    self.__ProcessHttpResponse(method_config, http_response, request))
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.io.gcp.internal.clients.bigquery.bigquery_v2_client.BigqueryV2.DatasetsService object at 0x78784416cc10>
method_config = <ApiMethodInfo
 relative_path: 'projects/{projectId}/datasets/{datasetId}'
 method_id: 'bigquery.datasets.get'
 http_m...st_type_name: 'BigqueryDatasetsGetRequest'
 response_type_name: 'Dataset'
 request_field: ''
 supports_download: False>
http_response = Response(info={'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 1...gquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets/python_vector_search_test_17346435446a7aa2?alt=json')
request = <BigqueryDatasetsGetRequest
 datasetId: 'python_vector_search_test_17346435446a7aa2'
 projectId: 'dataflow-test'>

    def __ProcessHttpResponse(self, method_config, http_response, request):
        """Process the given http response."""
        if http_response.status_code not in (http_client.OK,
                                             http_client.CREATED,
                                             http_client.NO_CONTENT):
>           raise exceptions.HttpError.FromResponse(
                http_response, method_config=method_config, request=request)
E           apitools.base.py.exceptions.HttpNotFoundError: HttpError accessing <https://bigquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets/python_vector_search_test_17346435446a7aa2?alt=json>: response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 19 Dec 2024 21:25:44 GMT', 'server': 'ESF', 'cache-control': 'private', 'x-xss-protection': '0', 'x-frame-options': 'SAMEORIGIN', 'x-content-type-options': 'nosniff', 'transfer-encoding': 'chunked', 'status': '404', 'content-length': '352', '-content-encoding': 'gzip'}>, content <{
E             "error": {
E               "code": 404,
E               "message": "Not found: Dataset dataflow-test:python_vector_search_test_17346435446a7aa2",
E               "errors": [
E                 {
E                   "message": "Not found: Dataset dataflow-test:python_vector_search_test_17346435446a7aa2",
E                   "domain": "global",
E                   "reason": "notFound"
E                 }
E               ],
E               "status": "NOT_FOUND"
E             }
E           }
E           >

target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:603: HttpNotFoundError

During handling of the above exception, another exception occurred:

cls = <class 'apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT'>

    @classmethod
    def setUpClass(cls):
>     super().setUpClass()

apache_beam/ml/rag/enrichment/bigquery_vector_search_it_test.py:135: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/ml/rag/enrichment/bigquery_vector_search_it_test.py:53: in setUpClass
    cls.bigquery_client.get_or_create_dataset(cls.project, cls.dataset_id)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/utils/retry.py:298: in wrapper
    return fun(*args, **kwargs)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/io/gcp/bigquery_tools.py:851: in get_or_create_dataset
    response = self.client.datasets.Insert(request)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/io/gcp/internal/clients/bigquery/bigquery_v2_client.py:158: in Insert
    return self._RunMethod(config, request, global_params=global_params)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:731: in _RunMethod
    return self.ProcessHttpResponse(method_config, http_response, request)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:737: in ProcessHttpResponse
    self.__ProcessHttpResponse(method_config, http_response, request))
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.io.gcp.internal.clients.bigquery.bigquery_v2_client.BigqueryV2.DatasetsService object at 0x78784416cc10>
method_config = <ApiMethodInfo
 relative_path: 'projects/{projectId}/datasets'
 method_id: 'bigquery.datasets.insert'
 http_method: 'P...me: 'BigqueryDatasetsInsertRequest'
 response_type_name: 'Dataset'
 request_field: 'dataset'
 supports_download: False>
http_response = Response(info={'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 1...DENIED"\n  }\n}\n', request_url='https://bigquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets?alt=json')
request = <BigqueryDatasetsInsertRequest
 dataset: <Dataset
 access: []
 datasetReference: <DatasetReference
 datasetId: 'python_vector_search_test_17346435446a7aa2'
 projectId: 'dataflow-test'>>
 projectId: 'dataflow-test'>

    def __ProcessHttpResponse(self, method_config, http_response, request):
        """Process the given http response."""
        if http_response.status_code not in (http_client.OK,
                                             http_client.CREATED,
                                             http_client.NO_CONTENT):
>           raise exceptions.HttpError.FromResponse(
                http_response, method_config=method_config, request=request)
E           apitools.base.py.exceptions.HttpForbiddenError: HttpError accessing <https://bigquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets?alt=json>: response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 19 Dec 2024 21:25:44 GMT', 'server': 'ESF', 'cache-control': 'private', 'x-xss-protection': '0', 'x-frame-options': 'SAMEORIGIN', 'x-content-type-options': 'nosniff', 'transfer-encoding': 'chunked', 'status': '403', 'content-length': '450', '-content-encoding': 'gzip'}>, content <{
E             "error": {
E               "code": 403,
E               "message": "Access Denied: Project dataflow-test: User does not have bigquery.datasets.create permission in project dataflow-test.",
E               "errors": [
E                 {
E                   "message": "Access Denied: Project dataflow-test: User does not have bigquery.datasets.create permission in project dataflow-test.",
E                   "domain": "global",
E                   "reason": "accessDenied"
E                 }
E               ],
E               "status": "PERMISSION_DENIED"
E             }
E           }
E           >

target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:603: HttpForbiddenError

Check failure on line 0 in apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT

See this annotation in the file changed.

@github-actions github-actions / Test Results

test_batched_metadata_filter_vector_search (apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT) with error

sdks/python/test-suites/tox/py39/build/srcs/sdks/python/pytest_py39-ml.xml [took 0s]
Raw output
failed on setup with "apitools.base.py.exceptions.HttpForbiddenError: HttpError accessing <https://bigquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets?alt=json>: response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 19 Dec 2024 21:25:44 GMT', 'server': 'ESF', 'cache-control': 'private', 'x-xss-protection': '0', 'x-frame-options': 'SAMEORIGIN', 'x-content-type-options': 'nosniff', 'transfer-encoding': 'chunked', 'status': '403', 'content-length': '450', '-content-encoding': 'gzip'}>, content <{
  "error": {
    "code": 403,
    "message": "Access Denied: Project dataflow-test: User does not have bigquery.datasets.create permission in project dataflow-test.",
    "errors": [
      {
        "message": "Access Denied: Project dataflow-test: User does not have bigquery.datasets.create permission in project dataflow-test.",
        "domain": "global",
        "reason": "accessDenied"
      }
    ],
    "status": "PERMISSION_DENIED"
  }
}
>"
self = <apache_beam.io.gcp.bigquery_tools.BigQueryWrapper object at 0x787844169190>
project_id = 'dataflow-test'
dataset_id = 'python_vector_search_test_17346435446a7aa2', location = None
labels = None

    @retry.with_exponential_backoff(
        num_retries=MAX_RETRIES,
        retry_filter=retry.retry_on_server_errors_and_timeout_filter)
    def get_or_create_dataset(
        self, project_id, dataset_id, location=None, labels=None):
      # Check if dataset already exists otherwise create it
      try:
>       dataset = self.client.datasets.Get(
            bigquery.BigqueryDatasetsGetRequest(
                projectId=project_id, datasetId=dataset_id))

target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/io/gcp/bigquery_tools.py:829: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/io/gcp/internal/clients/bigquery/bigquery_v2_client.py:133: in Get
    return self._RunMethod(config, request, global_params=global_params)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:731: in _RunMethod
    return self.ProcessHttpResponse(method_config, http_response, request)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:737: in ProcessHttpResponse
    self.__ProcessHttpResponse(method_config, http_response, request))
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.io.gcp.internal.clients.bigquery.bigquery_v2_client.BigqueryV2.DatasetsService object at 0x78784416cc10>
method_config = <ApiMethodInfo
 relative_path: 'projects/{projectId}/datasets/{datasetId}'
 method_id: 'bigquery.datasets.get'
 http_m...st_type_name: 'BigqueryDatasetsGetRequest'
 response_type_name: 'Dataset'
 request_field: ''
 supports_download: False>
http_response = Response(info={'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 1...gquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets/python_vector_search_test_17346435446a7aa2?alt=json')
request = <BigqueryDatasetsGetRequest
 datasetId: 'python_vector_search_test_17346435446a7aa2'
 projectId: 'dataflow-test'>

    def __ProcessHttpResponse(self, method_config, http_response, request):
        """Process the given http response."""
        if http_response.status_code not in (http_client.OK,
                                             http_client.CREATED,
                                             http_client.NO_CONTENT):
>           raise exceptions.HttpError.FromResponse(
                http_response, method_config=method_config, request=request)
E           apitools.base.py.exceptions.HttpNotFoundError: HttpError accessing <https://bigquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets/python_vector_search_test_17346435446a7aa2?alt=json>: response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 19 Dec 2024 21:25:44 GMT', 'server': 'ESF', 'cache-control': 'private', 'x-xss-protection': '0', 'x-frame-options': 'SAMEORIGIN', 'x-content-type-options': 'nosniff', 'transfer-encoding': 'chunked', 'status': '404', 'content-length': '352', '-content-encoding': 'gzip'}>, content <{
E             "error": {
E               "code": 404,
E               "message": "Not found: Dataset dataflow-test:python_vector_search_test_17346435446a7aa2",
E               "errors": [
E                 {
E                   "message": "Not found: Dataset dataflow-test:python_vector_search_test_17346435446a7aa2",
E                   "domain": "global",
E                   "reason": "notFound"
E                 }
E               ],
E               "status": "NOT_FOUND"
E             }
E           }
E           >

target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:603: HttpNotFoundError

During handling of the above exception, another exception occurred:

cls = <class 'apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT'>

    @classmethod
    def setUpClass(cls):
>     super().setUpClass()

apache_beam/ml/rag/enrichment/bigquery_vector_search_it_test.py:135: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/ml/rag/enrichment/bigquery_vector_search_it_test.py:53: in setUpClass
    cls.bigquery_client.get_or_create_dataset(cls.project, cls.dataset_id)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/utils/retry.py:298: in wrapper
    return fun(*args, **kwargs)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/io/gcp/bigquery_tools.py:851: in get_or_create_dataset
    response = self.client.datasets.Insert(request)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/io/gcp/internal/clients/bigquery/bigquery_v2_client.py:158: in Insert
    return self._RunMethod(config, request, global_params=global_params)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:731: in _RunMethod
    return self.ProcessHttpResponse(method_config, http_response, request)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:737: in ProcessHttpResponse
    self.__ProcessHttpResponse(method_config, http_response, request))
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.io.gcp.internal.clients.bigquery.bigquery_v2_client.BigqueryV2.DatasetsService object at 0x78784416cc10>
method_config = <ApiMethodInfo
 relative_path: 'projects/{projectId}/datasets'
 method_id: 'bigquery.datasets.insert'
 http_method: 'P...me: 'BigqueryDatasetsInsertRequest'
 response_type_name: 'Dataset'
 request_field: 'dataset'
 supports_download: False>
http_response = Response(info={'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 1...DENIED"\n  }\n}\n', request_url='https://bigquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets?alt=json')
request = <BigqueryDatasetsInsertRequest
 dataset: <Dataset
 access: []
 datasetReference: <DatasetReference
 datasetId: 'python_vector_search_test_17346435446a7aa2'
 projectId: 'dataflow-test'>>
 projectId: 'dataflow-test'>

    def __ProcessHttpResponse(self, method_config, http_response, request):
        """Process the given http response."""
        if http_response.status_code not in (http_client.OK,
                                             http_client.CREATED,
                                             http_client.NO_CONTENT):
>           raise exceptions.HttpError.FromResponse(
                http_response, method_config=method_config, request=request)
E           apitools.base.py.exceptions.HttpForbiddenError: HttpError accessing <https://bigquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets?alt=json>: response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 19 Dec 2024 21:25:44 GMT', 'server': 'ESF', 'cache-control': 'private', 'x-xss-protection': '0', 'x-frame-options': 'SAMEORIGIN', 'x-content-type-options': 'nosniff', 'transfer-encoding': 'chunked', 'status': '403', 'content-length': '450', '-content-encoding': 'gzip'}>, content <{
E             "error": {
E               "code": 403,
E               "message": "Access Denied: Project dataflow-test: User does not have bigquery.datasets.create permission in project dataflow-test.",
E               "errors": [
E                 {
E                   "message": "Access Denied: Project dataflow-test: User does not have bigquery.datasets.create permission in project dataflow-test.",
E                   "domain": "global",
E                   "reason": "accessDenied"
E                 }
E               ],
E               "status": "PERMISSION_DENIED"
E             }
E           }
E           >

target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:603: HttpForbiddenError

Check failure on line 0 in apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT

See this annotation in the file changed.

@github-actions github-actions / Test Results

test_euclidean_distance_search (apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT) with error

sdks/python/test-suites/tox/py39/build/srcs/sdks/python/pytest_py39-ml.xml [took 0s]
Raw output
failed on setup with "apitools.base.py.exceptions.HttpForbiddenError: HttpError accessing <https://bigquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets?alt=json>: response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 19 Dec 2024 21:25:44 GMT', 'server': 'ESF', 'cache-control': 'private', 'x-xss-protection': '0', 'x-frame-options': 'SAMEORIGIN', 'x-content-type-options': 'nosniff', 'transfer-encoding': 'chunked', 'status': '403', 'content-length': '450', '-content-encoding': 'gzip'}>, content <{
  "error": {
    "code": 403,
    "message": "Access Denied: Project dataflow-test: User does not have bigquery.datasets.create permission in project dataflow-test.",
    "errors": [
      {
        "message": "Access Denied: Project dataflow-test: User does not have bigquery.datasets.create permission in project dataflow-test.",
        "domain": "global",
        "reason": "accessDenied"
      }
    ],
    "status": "PERMISSION_DENIED"
  }
}
>"
self = <apache_beam.io.gcp.bigquery_tools.BigQueryWrapper object at 0x787844169190>
project_id = 'dataflow-test'
dataset_id = 'python_vector_search_test_17346435446a7aa2', location = None
labels = None

    @retry.with_exponential_backoff(
        num_retries=MAX_RETRIES,
        retry_filter=retry.retry_on_server_errors_and_timeout_filter)
    def get_or_create_dataset(
        self, project_id, dataset_id, location=None, labels=None):
      # Check if dataset already exists otherwise create it
      try:
>       dataset = self.client.datasets.Get(
            bigquery.BigqueryDatasetsGetRequest(
                projectId=project_id, datasetId=dataset_id))

target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/io/gcp/bigquery_tools.py:829: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/io/gcp/internal/clients/bigquery/bigquery_v2_client.py:133: in Get
    return self._RunMethod(config, request, global_params=global_params)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:731: in _RunMethod
    return self.ProcessHttpResponse(method_config, http_response, request)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:737: in ProcessHttpResponse
    self.__ProcessHttpResponse(method_config, http_response, request))
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.io.gcp.internal.clients.bigquery.bigquery_v2_client.BigqueryV2.DatasetsService object at 0x78784416cc10>
method_config = <ApiMethodInfo
 relative_path: 'projects/{projectId}/datasets/{datasetId}'
 method_id: 'bigquery.datasets.get'
 http_m...st_type_name: 'BigqueryDatasetsGetRequest'
 response_type_name: 'Dataset'
 request_field: ''
 supports_download: False>
http_response = Response(info={'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 1...gquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets/python_vector_search_test_17346435446a7aa2?alt=json')
request = <BigqueryDatasetsGetRequest
 datasetId: 'python_vector_search_test_17346435446a7aa2'
 projectId: 'dataflow-test'>

    def __ProcessHttpResponse(self, method_config, http_response, request):
        """Process the given http response."""
        if http_response.status_code not in (http_client.OK,
                                             http_client.CREATED,
                                             http_client.NO_CONTENT):
>           raise exceptions.HttpError.FromResponse(
                http_response, method_config=method_config, request=request)
E           apitools.base.py.exceptions.HttpNotFoundError: HttpError accessing <https://bigquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets/python_vector_search_test_17346435446a7aa2?alt=json>: response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 19 Dec 2024 21:25:44 GMT', 'server': 'ESF', 'cache-control': 'private', 'x-xss-protection': '0', 'x-frame-options': 'SAMEORIGIN', 'x-content-type-options': 'nosniff', 'transfer-encoding': 'chunked', 'status': '404', 'content-length': '352', '-content-encoding': 'gzip'}>, content <{
E             "error": {
E               "code": 404,
E               "message": "Not found: Dataset dataflow-test:python_vector_search_test_17346435446a7aa2",
E               "errors": [
E                 {
E                   "message": "Not found: Dataset dataflow-test:python_vector_search_test_17346435446a7aa2",
E                   "domain": "global",
E                   "reason": "notFound"
E                 }
E               ],
E               "status": "NOT_FOUND"
E             }
E           }
E           >

target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:603: HttpNotFoundError

During handling of the above exception, another exception occurred:

cls = <class 'apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT'>

    @classmethod
    def setUpClass(cls):
>     super().setUpClass()

apache_beam/ml/rag/enrichment/bigquery_vector_search_it_test.py:135: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/ml/rag/enrichment/bigquery_vector_search_it_test.py:53: in setUpClass
    cls.bigquery_client.get_or_create_dataset(cls.project, cls.dataset_id)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/utils/retry.py:298: in wrapper
    return fun(*args, **kwargs)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/io/gcp/bigquery_tools.py:851: in get_or_create_dataset
    response = self.client.datasets.Insert(request)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/io/gcp/internal/clients/bigquery/bigquery_v2_client.py:158: in Insert
    return self._RunMethod(config, request, global_params=global_params)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:731: in _RunMethod
    return self.ProcessHttpResponse(method_config, http_response, request)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:737: in ProcessHttpResponse
    self.__ProcessHttpResponse(method_config, http_response, request))
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.io.gcp.internal.clients.bigquery.bigquery_v2_client.BigqueryV2.DatasetsService object at 0x78784416cc10>
method_config = <ApiMethodInfo
 relative_path: 'projects/{projectId}/datasets'
 method_id: 'bigquery.datasets.insert'
 http_method: 'P...me: 'BigqueryDatasetsInsertRequest'
 response_type_name: 'Dataset'
 request_field: 'dataset'
 supports_download: False>
http_response = Response(info={'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 1...DENIED"\n  }\n}\n', request_url='https://bigquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets?alt=json')
request = <BigqueryDatasetsInsertRequest
 dataset: <Dataset
 access: []
 datasetReference: <DatasetReference
 datasetId: 'python_vector_search_test_17346435446a7aa2'
 projectId: 'dataflow-test'>>
 projectId: 'dataflow-test'>

    def __ProcessHttpResponse(self, method_config, http_response, request):
        """Process the given http response."""
        if http_response.status_code not in (http_client.OK,
                                             http_client.CREATED,
                                             http_client.NO_CONTENT):
>           raise exceptions.HttpError.FromResponse(
                http_response, method_config=method_config, request=request)
E           apitools.base.py.exceptions.HttpForbiddenError: HttpError accessing <https://bigquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets?alt=json>: response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 19 Dec 2024 21:25:44 GMT', 'server': 'ESF', 'cache-control': 'private', 'x-xss-protection': '0', 'x-frame-options': 'SAMEORIGIN', 'x-content-type-options': 'nosniff', 'transfer-encoding': 'chunked', 'status': '403', 'content-length': '450', '-content-encoding': 'gzip'}>, content <{
E             "error": {
E               "code": 403,
E               "message": "Access Denied: Project dataflow-test: User does not have bigquery.datasets.create permission in project dataflow-test.",
E               "errors": [
E                 {
E                   "message": "Access Denied: Project dataflow-test: User does not have bigquery.datasets.create permission in project dataflow-test.",
E                   "domain": "global",
E                   "reason": "accessDenied"
E                 }
E               ],
E               "status": "PERMISSION_DENIED"
E             }
E           }
E           >

target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:603: HttpForbiddenError

Check failure on line 0 in apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT

See this annotation in the file changed.

@github-actions github-actions / Test Results

test_invalid_query (apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT) with error

sdks/python/test-suites/tox/py39/build/srcs/sdks/python/pytest_py39-ml.xml [took 0s]
Raw output
failed on setup with "apitools.base.py.exceptions.HttpForbiddenError: HttpError accessing <https://bigquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets?alt=json>: response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 19 Dec 2024 21:25:44 GMT', 'server': 'ESF', 'cache-control': 'private', 'x-xss-protection': '0', 'x-frame-options': 'SAMEORIGIN', 'x-content-type-options': 'nosniff', 'transfer-encoding': 'chunked', 'status': '403', 'content-length': '450', '-content-encoding': 'gzip'}>, content <{
  "error": {
    "code": 403,
    "message": "Access Denied: Project dataflow-test: User does not have bigquery.datasets.create permission in project dataflow-test.",
    "errors": [
      {
        "message": "Access Denied: Project dataflow-test: User does not have bigquery.datasets.create permission in project dataflow-test.",
        "domain": "global",
        "reason": "accessDenied"
      }
    ],
    "status": "PERMISSION_DENIED"
  }
}
>"
self = <apache_beam.io.gcp.bigquery_tools.BigQueryWrapper object at 0x787844169190>
project_id = 'dataflow-test'
dataset_id = 'python_vector_search_test_17346435446a7aa2', location = None
labels = None

    @retry.with_exponential_backoff(
        num_retries=MAX_RETRIES,
        retry_filter=retry.retry_on_server_errors_and_timeout_filter)
    def get_or_create_dataset(
        self, project_id, dataset_id, location=None, labels=None):
      # Check if dataset already exists otherwise create it
      try:
>       dataset = self.client.datasets.Get(
            bigquery.BigqueryDatasetsGetRequest(
                projectId=project_id, datasetId=dataset_id))

target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/io/gcp/bigquery_tools.py:829: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/io/gcp/internal/clients/bigquery/bigquery_v2_client.py:133: in Get
    return self._RunMethod(config, request, global_params=global_params)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:731: in _RunMethod
    return self.ProcessHttpResponse(method_config, http_response, request)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:737: in ProcessHttpResponse
    self.__ProcessHttpResponse(method_config, http_response, request))
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.io.gcp.internal.clients.bigquery.bigquery_v2_client.BigqueryV2.DatasetsService object at 0x78784416cc10>
method_config = <ApiMethodInfo
 relative_path: 'projects/{projectId}/datasets/{datasetId}'
 method_id: 'bigquery.datasets.get'
 http_m...st_type_name: 'BigqueryDatasetsGetRequest'
 response_type_name: 'Dataset'
 request_field: ''
 supports_download: False>
http_response = Response(info={'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 1...gquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets/python_vector_search_test_17346435446a7aa2?alt=json')
request = <BigqueryDatasetsGetRequest
 datasetId: 'python_vector_search_test_17346435446a7aa2'
 projectId: 'dataflow-test'>

    def __ProcessHttpResponse(self, method_config, http_response, request):
        """Process the given http response."""
        if http_response.status_code not in (http_client.OK,
                                             http_client.CREATED,
                                             http_client.NO_CONTENT):
>           raise exceptions.HttpError.FromResponse(
                http_response, method_config=method_config, request=request)
E           apitools.base.py.exceptions.HttpNotFoundError: HttpError accessing <https://bigquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets/python_vector_search_test_17346435446a7aa2?alt=json>: response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 19 Dec 2024 21:25:44 GMT', 'server': 'ESF', 'cache-control': 'private', 'x-xss-protection': '0', 'x-frame-options': 'SAMEORIGIN', 'x-content-type-options': 'nosniff', 'transfer-encoding': 'chunked', 'status': '404', 'content-length': '352', '-content-encoding': 'gzip'}>, content <{
E             "error": {
E               "code": 404,
E               "message": "Not found: Dataset dataflow-test:python_vector_search_test_17346435446a7aa2",
E               "errors": [
E                 {
E                   "message": "Not found: Dataset dataflow-test:python_vector_search_test_17346435446a7aa2",
E                   "domain": "global",
E                   "reason": "notFound"
E                 }
E               ],
E               "status": "NOT_FOUND"
E             }
E           }
E           >

target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:603: HttpNotFoundError

During handling of the above exception, another exception occurred:

cls = <class 'apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT'>

    @classmethod
    def setUpClass(cls):
>     super().setUpClass()

apache_beam/ml/rag/enrichment/bigquery_vector_search_it_test.py:135: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/ml/rag/enrichment/bigquery_vector_search_it_test.py:53: in setUpClass
    cls.bigquery_client.get_or_create_dataset(cls.project, cls.dataset_id)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/utils/retry.py:298: in wrapper
    return fun(*args, **kwargs)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/io/gcp/bigquery_tools.py:851: in get_or_create_dataset
    response = self.client.datasets.Insert(request)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apache_beam/io/gcp/internal/clients/bigquery/bigquery_v2_client.py:158: in Insert
    return self._RunMethod(config, request, global_params=global_params)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:731: in _RunMethod
    return self.ProcessHttpResponse(method_config, http_response, request)
target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:737: in ProcessHttpResponse
    self.__ProcessHttpResponse(method_config, http_response, request))
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.io.gcp.internal.clients.bigquery.bigquery_v2_client.BigqueryV2.DatasetsService object at 0x78784416cc10>
method_config = <ApiMethodInfo
 relative_path: 'projects/{projectId}/datasets'
 method_id: 'bigquery.datasets.insert'
 http_method: 'P...me: 'BigqueryDatasetsInsertRequest'
 response_type_name: 'Dataset'
 request_field: 'dataset'
 supports_download: False>
http_response = Response(info={'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 1...DENIED"\n  }\n}\n', request_url='https://bigquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets?alt=json')
request = <BigqueryDatasetsInsertRequest
 dataset: <Dataset
 access: []
 datasetReference: <DatasetReference
 datasetId: 'python_vector_search_test_17346435446a7aa2'
 projectId: 'dataflow-test'>>
 projectId: 'dataflow-test'>

    def __ProcessHttpResponse(self, method_config, http_response, request):
        """Process the given http response."""
        if http_response.status_code not in (http_client.OK,
                                             http_client.CREATED,
                                             http_client.NO_CONTENT):
>           raise exceptions.HttpError.FromResponse(
                http_response, method_config=method_config, request=request)
E           apitools.base.py.exceptions.HttpForbiddenError: HttpError accessing <https://bigquery.googleapis.com/bigquery/v2/projects/dataflow-test/datasets?alt=json>: response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Thu, 19 Dec 2024 21:25:44 GMT', 'server': 'ESF', 'cache-control': 'private', 'x-xss-protection': '0', 'x-frame-options': 'SAMEORIGIN', 'x-content-type-options': 'nosniff', 'transfer-encoding': 'chunked', 'status': '403', 'content-length': '450', '-content-encoding': 'gzip'}>, content <{
E             "error": {
E               "code": 403,
E               "message": "Access Denied: Project dataflow-test: User does not have bigquery.datasets.create permission in project dataflow-test.",
E               "errors": [
E                 {
E                   "message": "Access Denied: Project dataflow-test: User does not have bigquery.datasets.create permission in project dataflow-test.",
E                   "domain": "global",
E                   "reason": "accessDenied"
E                 }
E               ],
E               "status": "PERMISSION_DENIED"
E             }
E           }
E           >

target/.tox-py39-ml/py39-ml/lib/python3.9/site-packages/apitools/base/py/base_api.py:603: HttpForbiddenError

Check notice on line 0 in .github

See this annotation in the file changed.

@github-actions github-actions / Test Results

65 skipped tests found

There are 65 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.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.vertex_ai_inference_it_test.VertexAIInference ‑ test_vertex_ai_run_llm_text_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.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_streaming_default_schema
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.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 / Test Results

377 tests found

There are 377 tests, see "Raw output" for the full list of 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.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.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_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_it_test.VertexAIInference ‑ test_vertex_ai_run_llm_text_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.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_euclidean_distance_search
apache_beam.ml.rag.enrichment.bigquery_vector_search_it_test.TestBigQueryVectorSearchIT ‑ test_invalid_query
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_streaming_default_schema
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.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.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.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