Fix :examples:java:twitter:execute task (#31103) #11820
GitHub Actions / Test Results
failed
Apr 26, 2024 in 0s
1 fail, 16 skipped, 9 pass in 16m 24s
26 tests 9 ✅ 16m 24s ⏱️
1 suites 16 💤
1 files 1 ❌
Results for commit 088c854.
Annotations
Check warning on line 0 in apache_beam.io.avroio_test.TestFastAvro
github-actions / Test Results
test_avro_schema_to_beam_schema_with_nullable_atomic_fields (apache_beam.io.avroio_test.TestFastAvro) failed
sdks/python/pytest_xlangSqlValidateRunner.xml [took 7m 6s]
Raw output
OSError: No files found based on the file pattern /tmp/tmpjwy4ku73*
self = <apache_beam.io.avroio_test.TestFastAvro testMethod=test_avro_schema_to_beam_schema_with_nullable_atomic_fields>
@pytest.mark.xlang_sql_expansion_service
@unittest.skipIf(
TestPipeline().get_pipeline_options().view_as(StandardOptions).runner is
None,
"Must be run with a runner that supports staging java artifacts.")
def test_avro_schema_to_beam_schema_with_nullable_atomic_fields(self):
records = []
records.extend(self.RECORDS)
records.append({
'name': 'Bruce', 'favorite_number': None, 'favorite_color': None
})
with tempfile.TemporaryDirectory() as tmp_dirname_input:
input_path = os.path.join(tmp_dirname_input, 'tmp_filename.avro')
parsed_schema = fastavro.parse_schema(json.loads(self.SCHEMA_STRING))
with open(input_path, 'wb') as tmp_avro_file:
fastavro.writer(tmp_avro_file, parsed_schema, records)
with tempfile.TemporaryDirectory() as tmp_dirname_output:
with TestPipeline() as p:
_ = (
p
| avroio.ReadFromAvro(input_path, as_rows=True)
| SqlTransform("SELECT * FROM PCOLLECTION")
| avroio.WriteToAvro(tmp_dirname_output))
with TestPipeline() as p:
> readback = (p | avroio.ReadFromAvro(tmp_dirname_output + "*"))
apache_beam/io/avroio_test.py:199:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
apache_beam/io/avroio.py:164: in __init__
self._source = _FastAvroSource(
apache_beam/io/filebasedsource.py:127: in __init__
self._validate()
apache_beam/options/value_provider.py:193: in _f
return fnc(self, *args, **kwargs)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
self = <apache_beam.io.avroio._FastAvroSource object at 0x7d8df560fe90>
@check_accessible(['_pattern'])
def _validate(self):
"""Validate if there are actual files in the specified glob pattern
"""
pattern = self._pattern.get()
# Limit the responses as we only want to check if something exists
match_result = FileSystems.match([pattern], limits=[1])[0]
if len(match_result.metadata_list) <= 0:
> raise IOError('No files found based on the file pattern %s' % pattern)
E OSError: No files found based on the file pattern /tmp/tmpjwy4ku73*
apache_beam/io/filebasedsource.py:190: OSError
Check notice on line 0 in .github
github-actions / Test Results
16 skipped tests found
There are 16 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.tensorrt_inference_test
apache_beam.ml.inference.vertex_ai_inference_it_test
apache_beam.ml.inference.xgboost_inference_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
github-actions / Test Results
26 tests found
There are 26 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.avroio_test.TestFastAvro ‑ test_avro_schema_to_beam_schema_with_nullable_atomic_fields
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.tensorrt_inference_test
apache_beam.ml.inference.vertex_ai_inference_it_test
apache_beam.ml.inference.xgboost_inference_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.transforms.sql_test.SqlTransformTest ‑ test_agg
apache_beam.transforms.sql_test.SqlTransformTest ‑ test_filter
apache_beam.transforms.sql_test.SqlTransformTest ‑ test_generate_data
apache_beam.transforms.sql_test.SqlTransformTest ‑ test_map
apache_beam.transforms.sql_test.SqlTransformTest ‑ test_project
apache_beam.transforms.sql_test.SqlTransformTest ‑ test_row
apache_beam.transforms.sql_test.SqlTransformTest ‑ test_tagged_join
apache_beam.transforms.sql_test.SqlTransformTest ‑ test_windowing_before_sql
apache_beam.transforms.sql_test.SqlTransformTest ‑ test_zetasql_generate_data
apache_beam.typehints.pytorch_type_compatibility_test
Loading