Skip to content

[Task]: [RRIO] [Testing] Define and implement mock quota aware API #1324

[Task]: [RRIO] [Testing] Define and implement mock quota aware API

[Task]: [RRIO] [Testing] Define and implement mock quota aware API #1324

GitHub Actions / Test Results failed Oct 23, 2023 in 0s

6 fail, 18 skipped in 7m 50s

24 tests     0 ✔️  7m 50s ⏱️
  1 suites  18 💤
  1 files      6

Results for commit a07d90e.

Annotations

Check warning on line 0 in apache_beam.io.gcp.bigtableio_it_test.TestReadFromBigTableIT

See this annotation in the file changed.

@github-actions github-actions / Test Results

test_read_xlang (apache_beam.io.gcp.bigtableio_it_test.TestReadFromBigTableIT) failed

sdks/python/pytest_transformService.xml [took 1m 26s]
Raw output
grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNKNOWN
	details = ""
	debug_error_string = "UNKNOWN:Error received from peer  {grpc_message:"", grpc_status:2, created_time:"2023-10-23T17:46:19.081383+00:00"}"
>
self = <apache_beam.io.gcp.bigtableio_it_test.TestReadFromBigTableIT testMethod=test_read_xlang>

    def test_read_xlang(self):
      # create rows and retrieve expected cells
      expected_cells = self.add_rows(
          num_rows=5, num_families=3, num_columns_per_family=4)
    
      with beam.Pipeline(argv=self.args) as p:
        cells = (
            p
>           | bigtableio.ReadFromBigtable(
                project_id=self.project,
                instance_id=self.instance.instance_id,
                table_id=self.table.table_id,
                expansion_service=self.expansion_service)
            | "Extract cells" >> beam.Map(lambda row: row._cells))

apache_beam/io/gcp/bigtableio_it_test.py:135: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/io/gcp/bigtableio.py:318: in __init__
    self.schematransform_config = SchemaAwareExternalTransform.discover_config(
apache_beam/transforms/external.py:475: in discover_config
    schematransforms = SchemaAwareExternalTransform.discover(
apache_beam/transforms/external.py:438: in discover
    return list(cls.discover_iter(expansion_service, ignore_errors))
apache_beam/transforms/external.py:443: in discover_iter
    discover_response = service.DiscoverSchemaTransform(
../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1161: in __call__
    return _end_unary_response_blocking(state, call, False, None)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

state = <grpc._channel._RPCState object at 0x7bab92e31280>
call = <grpc._cython.cygrpc.SegregatedCall object at 0x7bab92e32300>
with_call = False, deadline = None

    def _end_unary_response_blocking(
        state: _RPCState,
        call: cygrpc.SegregatedCall,
        with_call: bool,
        deadline: Optional[float],
    ) -> Union[ResponseType, Tuple[ResponseType, grpc.Call]]:
        if state.code is grpc.StatusCode.OK:
            if with_call:
                rendezvous = _MultiThreadedRendezvous(state, call, None, deadline)
                return state.response, rendezvous
            else:
                return state.response
        else:
>           raise _InactiveRpcError(state)  # pytype: disable=not-instantiable
E           grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
E           	status = StatusCode.UNKNOWN
E           	details = ""
E           	debug_error_string = "UNKNOWN:Error received from peer  {grpc_message:"", grpc_status:2, created_time:"2023-10-23T17:46:19.081383+00:00"}"
E           >

../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1004: _InactiveRpcError

Check warning on line 0 in apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT

See this annotation in the file changed.

@github-actions github-actions / Test Results

test_delete_cells_mutation (apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT) failed

sdks/python/pytest_transformService.xml [took 1m 14s]
Raw output
grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNKNOWN
	details = ""
	debug_error_string = "UNKNOWN:Error received from peer  {grpc_message:"", grpc_status:2, created_time:"2023-10-23T17:47:33.83589015+00:00"}"
>
self = <apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT testMethod=test_delete_cells_mutation>

    def test_delete_cells_mutation(self):
      col_fam = self.table.column_family('col_fam')
      col_fam.create()
      # write a row with two columns to the table beforehand.
      write_row: DirectRow = DirectRow('key-1', self.table)
      write_row.set_cell('col_fam', b'col-1', b'val-1')
      write_row.set_cell('col_fam', b'col-2', b'val-2')
      write_row.commit()
    
      # prepare a row that will delete cells in one of the columns.
      delete_row: DirectRow = DirectRow('key-1')
      delete_row.delete_cell('col_fam', b'col-1')
    
>     self.run_pipeline([delete_row])

apache_beam/io/gcp/bigtableio_it_test.py:283: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/io/gcp/bigtableio_it_test.py:209: in run_pipeline
    | bigtableio.WriteToBigTable(
apache_beam/io/gcp/bigtableio.py:219: in __init__
    SchemaAwareExternalTransform.discover_config(
apache_beam/transforms/external.py:475: in discover_config
    schematransforms = SchemaAwareExternalTransform.discover(
apache_beam/transforms/external.py:438: in discover
    return list(cls.discover_iter(expansion_service, ignore_errors))
apache_beam/transforms/external.py:443: in discover_iter
    discover_response = service.DiscoverSchemaTransform(
../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1161: in __call__
    return _end_unary_response_blocking(state, call, False, None)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

state = <grpc._channel._RPCState object at 0x7bab92d93a60>
call = <grpc._cython.cygrpc.SegregatedCall object at 0x7bab92c62800>
with_call = False, deadline = None

    def _end_unary_response_blocking(
        state: _RPCState,
        call: cygrpc.SegregatedCall,
        with_call: bool,
        deadline: Optional[float],
    ) -> Union[ResponseType, Tuple[ResponseType, grpc.Call]]:
        if state.code is grpc.StatusCode.OK:
            if with_call:
                rendezvous = _MultiThreadedRendezvous(state, call, None, deadline)
                return state.response, rendezvous
            else:
                return state.response
        else:
>           raise _InactiveRpcError(state)  # pytype: disable=not-instantiable
E           grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
E           	status = StatusCode.UNKNOWN
E           	details = ""
E           	debug_error_string = "UNKNOWN:Error received from peer  {grpc_message:"", grpc_status:2, created_time:"2023-10-23T17:47:33.83589015+00:00"}"
E           >

../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1004: _InactiveRpcError

Check warning on line 0 in apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT

See this annotation in the file changed.

@github-actions github-actions / Test Results

test_delete_cells_with_timerange_mutation (apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT) failed

sdks/python/pytest_transformService.xml [took 1m 8s]
Raw output
grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNKNOWN
	details = ""
	debug_error_string = "UNKNOWN:Error received from peer  {grpc_message:"", grpc_status:2, created_time:"2023-10-23T17:48:42.864746899+00:00"}"
>
self = <apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT testMethod=test_delete_cells_with_timerange_mutation>

    def test_delete_cells_with_timerange_mutation(self):
      col_fam = self.table.column_family('col_fam')
      col_fam.create()
      # write two cells in a column to the table beforehand.
      write_row: DirectRow = DirectRow('key-1', self.table)
      write_row.set_cell(
          'col_fam',
          b'col',
          b'val',
          datetime.fromtimestamp(100_000_000, tz=timezone.utc))
      write_row.commit()
      write_row.set_cell(
          'col_fam',
          b'col',
          b'new-val',
          datetime.fromtimestamp(200_000_000, tz=timezone.utc))
      write_row.commit()
    
      # prepare a row that will delete cells within a timestamp range.
      delete_row: DirectRow = DirectRow('key-1')
      delete_row.delete_cell(
          'col_fam',
          b'col',
          time_range=TimestampRange(
              start=datetime.fromtimestamp(99_999_999, tz=timezone.utc),
              end=datetime.fromtimestamp(100_000_001, tz=timezone.utc)))
    
>     self.run_pipeline([delete_row])

apache_beam/io/gcp/bigtableio_it_test.py:324: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/io/gcp/bigtableio_it_test.py:209: in run_pipeline
    | bigtableio.WriteToBigTable(
apache_beam/io/gcp/bigtableio.py:219: in __init__
    SchemaAwareExternalTransform.discover_config(
apache_beam/transforms/external.py:475: in discover_config
    schematransforms = SchemaAwareExternalTransform.discover(
apache_beam/transforms/external.py:438: in discover
    return list(cls.discover_iter(expansion_service, ignore_errors))
apache_beam/transforms/external.py:443: in discover_iter
    discover_response = service.DiscoverSchemaTransform(
../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1161: in __call__
    return _end_unary_response_blocking(state, call, False, None)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

state = <grpc._channel._RPCState object at 0x7bab92aa07f0>
call = <grpc._cython.cygrpc.SegregatedCall object at 0x7bab92c5bd40>
with_call = False, deadline = None

    def _end_unary_response_blocking(
        state: _RPCState,
        call: cygrpc.SegregatedCall,
        with_call: bool,
        deadline: Optional[float],
    ) -> Union[ResponseType, Tuple[ResponseType, grpc.Call]]:
        if state.code is grpc.StatusCode.OK:
            if with_call:
                rendezvous = _MultiThreadedRendezvous(state, call, None, deadline)
                return state.response, rendezvous
            else:
                return state.response
        else:
>           raise _InactiveRpcError(state)  # pytype: disable=not-instantiable
E           grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
E           	status = StatusCode.UNKNOWN
E           	details = ""
E           	debug_error_string = "UNKNOWN:Error received from peer  {grpc_message:"", grpc_status:2, created_time:"2023-10-23T17:48:42.864746899+00:00"}"
E           >

../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1004: _InactiveRpcError

Check warning on line 0 in apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT

See this annotation in the file changed.

@github-actions github-actions / Test Results

test_delete_column_family_mutation (apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT) failed

sdks/python/pytest_transformService.xml [took 1m 18s]
Raw output
grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNKNOWN
	details = ""
	debug_error_string = "UNKNOWN:Error received from peer  {created_time:"2023-10-23T17:50:01.472455413+00:00", grpc_status:2, grpc_message:""}"
>
self = <apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT testMethod=test_delete_column_family_mutation>

    def test_delete_column_family_mutation(self):
      # create two column families
      col_fam = self.table.column_family('col_fam-1')
      col_fam.create()
      col_fam = self.table.column_family('col_fam-2')
      col_fam.create()
      # write a row with values in both column families to the table beforehand.
      write_row: DirectRow = DirectRow('key-1', self.table)
      write_row.set_cell('col_fam-1', b'col', b'val')
      write_row.set_cell('col_fam-2', b'col', b'val')
      write_row.commit()
    
      # prepare a row that will delete a column family from the row
      delete_row: DirectRow = DirectRow('key-1')
      delete_row.delete_cells('col_fam-1', delete_row.ALL_COLUMNS)
    
>     self.run_pipeline([delete_row])

apache_beam/io/gcp/bigtableio_it_test.py:354: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/io/gcp/bigtableio_it_test.py:209: in run_pipeline
    | bigtableio.WriteToBigTable(
apache_beam/io/gcp/bigtableio.py:219: in __init__
    SchemaAwareExternalTransform.discover_config(
apache_beam/transforms/external.py:475: in discover_config
    schematransforms = SchemaAwareExternalTransform.discover(
apache_beam/transforms/external.py:438: in discover
    return list(cls.discover_iter(expansion_service, ignore_errors))
apache_beam/transforms/external.py:443: in discover_iter
    discover_response = service.DiscoverSchemaTransform(
../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1161: in __call__
    return _end_unary_response_blocking(state, call, False, None)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

state = <grpc._channel._RPCState object at 0x7bab92aa2d60>
call = <grpc._cython.cygrpc.SegregatedCall object at 0x7bab92aa8600>
with_call = False, deadline = None

    def _end_unary_response_blocking(
        state: _RPCState,
        call: cygrpc.SegregatedCall,
        with_call: bool,
        deadline: Optional[float],
    ) -> Union[ResponseType, Tuple[ResponseType, grpc.Call]]:
        if state.code is grpc.StatusCode.OK:
            if with_call:
                rendezvous = _MultiThreadedRendezvous(state, call, None, deadline)
                return state.response, rendezvous
            else:
                return state.response
        else:
>           raise _InactiveRpcError(state)  # pytype: disable=not-instantiable
E           grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
E           	status = StatusCode.UNKNOWN
E           	details = ""
E           	debug_error_string = "UNKNOWN:Error received from peer  {created_time:"2023-10-23T17:50:01.472455413+00:00", grpc_status:2, grpc_message:""}"
E           >

../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1004: _InactiveRpcError

Check warning on line 0 in apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT

See this annotation in the file changed.

@github-actions github-actions / Test Results

test_delete_row_mutation (apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT) failed

sdks/python/pytest_transformService.xml [took 1m 15s]
Raw output
grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNKNOWN
	details = ""
	debug_error_string = "UNKNOWN:Error received from peer  {grpc_message:"", grpc_status:2, created_time:"2023-10-23T17:51:17.140940419+00:00"}"
>
self = <apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT testMethod=test_delete_row_mutation>

    def test_delete_row_mutation(self):
      write_row1: DirectRow = DirectRow('key-1', self.table)
      write_row2: DirectRow = DirectRow('key-2', self.table)
      col_fam = self.table.column_family('col_fam')
      col_fam.create()
      # write a couple of rows to the table beforehand
      write_row1.set_cell('col_fam', b'col', b'val-1')
      write_row1.commit()
      write_row2.set_cell('col_fam', b'col', b'val-2')
      write_row2.commit()
    
      # prepare a row that will delete itself
      delete_row: DirectRow = DirectRow('key-1')
      delete_row.delete()
    
>     self.run_pipeline([delete_row])

apache_beam/io/gcp/bigtableio_it_test.py:382: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/io/gcp/bigtableio_it_test.py:209: in run_pipeline
    | bigtableio.WriteToBigTable(
apache_beam/io/gcp/bigtableio.py:219: in __init__
    SchemaAwareExternalTransform.discover_config(
apache_beam/transforms/external.py:475: in discover_config
    schematransforms = SchemaAwareExternalTransform.discover(
apache_beam/transforms/external.py:438: in discover
    return list(cls.discover_iter(expansion_service, ignore_errors))
apache_beam/transforms/external.py:443: in discover_iter
    discover_response = service.DiscoverSchemaTransform(
../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1161: in __call__
    return _end_unary_response_blocking(state, call, False, None)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

state = <grpc._channel._RPCState object at 0x7bab92aa6f10>
call = <grpc._cython.cygrpc.SegregatedCall object at 0x7bab92c61880>
with_call = False, deadline = None

    def _end_unary_response_blocking(
        state: _RPCState,
        call: cygrpc.SegregatedCall,
        with_call: bool,
        deadline: Optional[float],
    ) -> Union[ResponseType, Tuple[ResponseType, grpc.Call]]:
        if state.code is grpc.StatusCode.OK:
            if with_call:
                rendezvous = _MultiThreadedRendezvous(state, call, None, deadline)
                return state.response, rendezvous
            else:
                return state.response
        else:
>           raise _InactiveRpcError(state)  # pytype: disable=not-instantiable
E           grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
E           	status = StatusCode.UNKNOWN
E           	details = ""
E           	debug_error_string = "UNKNOWN:Error received from peer  {grpc_message:"", grpc_status:2, created_time:"2023-10-23T17:51:17.140940419+00:00"}"
E           >

../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1004: _InactiveRpcError

Check warning on line 0 in apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT

See this annotation in the file changed.

@github-actions github-actions / Test Results

test_set_mutation (apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT) failed

sdks/python/pytest_transformService.xml [took 1m 15s]
Raw output
grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNKNOWN
	details = ""
	debug_error_string = "UNKNOWN:Error received from peer  {grpc_message:"", grpc_status:2, created_time:"2023-10-23T17:52:32.611911671+00:00"}"
>
self = <apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT testMethod=test_set_mutation>

    def test_set_mutation(self):
      row1: DirectRow = DirectRow('key-1')
      row2: DirectRow = DirectRow('key-2')
      col_fam = self.table.column_family('col_fam')
      col_fam.create()
      # expected cells
      row1_col1_cell = Cell(b'val1-1', 100_000_000)
      row1_col2_cell = Cell(b'val1-2', 200_000_000)
      row2_col1_cell = Cell(b'val2-1', 100_000_000)
      row2_col2_cell = Cell(b'val2-2', 200_000_000)
      # When setting this cell, we won't set a timestamp. We expect the timestamp
      # to default to -1, and Bigtable will set it to system time at insertion.
      row2_col1_no_timestamp = Cell(b'val2-2-notimestamp', time.time())
      # rows sent to write transform
      row1.set_cell(
          'col_fam', b'col-1', row1_col1_cell.value, row1_col1_cell.timestamp)
      row1.set_cell(
          'col_fam', b'col-2', row1_col2_cell.value, row1_col2_cell.timestamp)
      row2.set_cell(
          'col_fam', b'col-1', row2_col1_cell.value, row2_col1_cell.timestamp)
      row2.set_cell(
          'col_fam', b'col-2', row2_col2_cell.value, row2_col2_cell.timestamp)
      # don't set a timestamp here. it should default to -1
      row2.set_cell('col_fam', b'col-no-timestamp', row2_col1_no_timestamp.value)
    
>     self.run_pipeline([row1, row2])

apache_beam/io/gcp/bigtableio_it_test.py:241: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/io/gcp/bigtableio_it_test.py:209: in run_pipeline
    | bigtableio.WriteToBigTable(
apache_beam/io/gcp/bigtableio.py:219: in __init__
    SchemaAwareExternalTransform.discover_config(
apache_beam/transforms/external.py:475: in discover_config
    schematransforms = SchemaAwareExternalTransform.discover(
apache_beam/transforms/external.py:438: in discover
    return list(cls.discover_iter(expansion_service, ignore_errors))
apache_beam/transforms/external.py:443: in discover_iter
    discover_response = service.DiscoverSchemaTransform(
../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1161: in __call__
    return _end_unary_response_blocking(state, call, False, None)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

state = <grpc._channel._RPCState object at 0x7bab92a486a0>
call = <grpc._cython.cygrpc.SegregatedCall object at 0x7bab92cf6c00>
with_call = False, deadline = None

    def _end_unary_response_blocking(
        state: _RPCState,
        call: cygrpc.SegregatedCall,
        with_call: bool,
        deadline: Optional[float],
    ) -> Union[ResponseType, Tuple[ResponseType, grpc.Call]]:
        if state.code is grpc.StatusCode.OK:
            if with_call:
                rendezvous = _MultiThreadedRendezvous(state, call, None, deadline)
                return state.response, rendezvous
            else:
                return state.response
        else:
>           raise _InactiveRpcError(state)  # pytype: disable=not-instantiable
E           grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
E           	status = StatusCode.UNKNOWN
E           	details = ""
E           	debug_error_string = "UNKNOWN:Error received from peer  {grpc_message:"", grpc_status:2, created_time:"2023-10-23T17:52:32.611911671+00:00"}"
E           >

../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1004: _InactiveRpcError

Check notice on line 0 in .github

See this annotation in the file changed.

@github-actions github-actions / Test Results

18 skipped tests found

There are 18 skipped tests, see "Raw output" for the full list of skipped tests.
Raw output
apache_beam.examples.ml_transform.ml_transform_it_test
apache_beam.examples.snippets.transforms.elementwise.mltransform_test
apache_beam.examples.snippets.transforms.elementwise.runinference_test
apache_beam.ml.inference.huggingface_inference_it_test
apache_beam.ml.inference.huggingface_inference_test
apache_beam.ml.inference.onnx_inference_test
apache_beam.ml.inference.pytorch_inference_test
apache_beam.ml.inference.tensorflow_inference_test
apache_beam.ml.inference.tensorrt_inference_test
apache_beam.ml.inference.vertex_ai_inference_it_test
apache_beam.ml.inference.xgboost_inference_test
apache_beam.ml.transforms.base_test
apache_beam.ml.transforms.handlers_test
apache_beam.ml.transforms.tft_test
apache_beam.runners.dask.dask_runner_test
apache_beam.testing.analyzers.perf_analysis_test
apache_beam.testing.benchmarks.cloudml.cloudml_benchmark_test
apache_beam.typehints.pytorch_type_compatibility_test

Check notice on line 0 in .github

See this annotation in the file changed.

@github-actions github-actions / Test Results

24 tests found

There are 24 tests, see "Raw output" for the full list of tests.
Raw output
apache_beam.examples.ml_transform.ml_transform_it_test
apache_beam.examples.snippets.transforms.elementwise.mltransform_test
apache_beam.examples.snippets.transforms.elementwise.runinference_test
apache_beam.io.gcp.bigtableio_it_test.TestReadFromBigTableIT ‑ test_read_xlang
apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT ‑ test_delete_cells_mutation
apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT ‑ test_delete_cells_with_timerange_mutation
apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT ‑ test_delete_column_family_mutation
apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT ‑ test_delete_row_mutation
apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT ‑ test_set_mutation
apache_beam.ml.inference.huggingface_inference_it_test
apache_beam.ml.inference.huggingface_inference_test
apache_beam.ml.inference.onnx_inference_test
apache_beam.ml.inference.pytorch_inference_test
apache_beam.ml.inference.tensorflow_inference_test
apache_beam.ml.inference.tensorrt_inference_test
apache_beam.ml.inference.vertex_ai_inference_it_test
apache_beam.ml.inference.xgboost_inference_test
apache_beam.ml.transforms.base_test
apache_beam.ml.transforms.handlers_test
apache_beam.ml.transforms.tft_test
apache_beam.runners.dask.dask_runner_test
apache_beam.testing.analyzers.perf_analysis_test
apache_beam.testing.benchmarks.cloudml.cloudml_benchmark_test
apache_beam.typehints.pytorch_type_compatibility_test