[Failing Test]: Beam ML unit test suite fails on Python 3.11 #1783
10 fail, 18 skipped in 21s
28 tests 0 ✅ 21s ⏱️
1 suites 18 💤
1 files 10 ❌
Results for commit 6de9a60.
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 0s]
Raw output
RuntimeError: Service failed to start up with error 1
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
})
avro_schema = fastavro.parse_schema(json.loads(self.SCHEMA_STRING))
beam_schema = avro_schema_to_beam_schema(avro_schema)
with TestPipeline() as p:
readback = (
> p
| Create(records)
| beam.Map(avro_dict_to_beam_row(avro_schema, beam_schema))
| SqlTransform("SELECT * FROM PCOLLECTION")
| beam.Map(beam_row_to_avro_dict(avro_schema, beam_schema)))
apache_beam/io/avroio_test.py:191:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
apache_beam/pvalue.py:138: in __or__
return self.pipeline.apply(ptransform, self)
apache_beam/pipeline.py:732: in apply
pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
apache_beam/runners/runner.py:203: in apply
return self.apply_PTransform(transform, input, options)
apache_beam/runners/runner.py:207: in apply_PTransform
return transform.expand(input)
apache_beam/transforms/external.py:750: in expand
with ExternalTransform.service(expansion_service) as service:
/opt/hostedtoolcache/Python/3.11.9/x64/lib/python3.11/contextlib.py:137: in __enter__
return next(self.gen)
apache_beam/transforms/external.py:806: in service
with expansion_service as stub:
apache_beam/transforms/external.py:1032: in __enter__
self._service = self._service_provider.__enter__()
apache_beam/utils/subprocess_server.py:158: in __enter__
return self.start()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
self = <apache_beam.utils.subprocess_server.JavaJarServer object at 0x798047755dd0>
def start(self):
try:
process, endpoint = self.start_process()
wait_secs = .1
channel_options = [("grpc.max_receive_message_length", -1),
("grpc.max_send_message_length", -1)]
self._grpc_channel = grpc.insecure_channel(
endpoint, options=channel_options)
channel_ready = grpc.channel_ready_future(self._grpc_channel)
while True:
if process is not None and process.poll() is not None:
_LOGGER.error("Started job service with %s", process.args)
> raise RuntimeError(
'Service failed to start up with error %s' % process.poll())
E RuntimeError: Service failed to start up with error 1
apache_beam/utils/subprocess_server.py:175: RuntimeError
Check warning on line 0 in apache_beam.transforms.sql_test.SqlTransformTest
github-actions / Test Results
test_row (apache_beam.transforms.sql_test.SqlTransformTest) failed
sdks/python/pytest_xlangSqlValidateRunner.xml [took 0s]
Raw output
RuntimeError: Service failed to start up with error 1
self = <apache_beam.transforms.sql_test.SqlTransformTest testMethod=test_row>
def test_row(self):
with TestPipeline() as p:
out = (
> p
| beam.Create([1, 2, 10])
| beam.Map(lambda x: beam.Row(a=x, b=str(x)))
| SqlTransform("SELECT a*a as s, LENGTH(b) AS c FROM PCOLLECTION"))
apache_beam/transforms/sql_test.py:146:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
apache_beam/pvalue.py:138: in __or__
return self.pipeline.apply(ptransform, self)
apache_beam/pipeline.py:732: in apply
pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
apache_beam/runners/runner.py:203: in apply
return self.apply_PTransform(transform, input, options)
apache_beam/runners/runner.py:207: in apply_PTransform
return transform.expand(input)
apache_beam/transforms/external.py:750: in expand
with ExternalTransform.service(expansion_service) as service:
/opt/hostedtoolcache/Python/3.11.9/x64/lib/python3.11/contextlib.py:137: in __enter__
return next(self.gen)
apache_beam/transforms/external.py:806: in service
with expansion_service as stub:
apache_beam/transforms/external.py:1032: in __enter__
self._service = self._service_provider.__enter__()
apache_beam/utils/subprocess_server.py:158: in __enter__
return self.start()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
self = <apache_beam.utils.subprocess_server.JavaJarServer object at 0x786de026f790>
def start(self):
try:
process, endpoint = self.start_process()
wait_secs = .1
channel_options = [("grpc.max_receive_message_length", -1),
("grpc.max_send_message_length", -1)]
self._grpc_channel = grpc.insecure_channel(
endpoint, options=channel_options)
channel_ready = grpc.channel_ready_future(self._grpc_channel)
while True:
if process is not None and process.poll() is not None:
_LOGGER.error("Started job service with %s", process.args)
> raise RuntimeError(
'Service failed to start up with error %s' % process.poll())
E RuntimeError: Service failed to start up with error 1
apache_beam/utils/subprocess_server.py:175: RuntimeError
Check warning on line 0 in apache_beam.transforms.sql_test.SqlTransformTest
github-actions / Test Results
test_tagged_join (apache_beam.transforms.sql_test.SqlTransformTest) failed
sdks/python/pytest_xlangSqlValidateRunner.xml [took 0s]
Raw output
RuntimeError: Service failed to start up with error 1
self = <apache_beam.transforms.sql_test.SqlTransformTest testMethod=test_tagged_join>
def test_tagged_join(self):
with TestPipeline() as p:
enrich = (
p | "Create enrich" >> beam.Create(
[Enrich(1, "a"), Enrich(2, "b"), Enrich(26, "z")]))
simple = (
p | "Create simple" >> beam.Create([
SimpleRow(1, "foo", 3.14),
SimpleRow(26, "bar", 1.11),
SimpleRow(1, "baz", 2.34)
]))
> out = ({
'simple': simple, 'enrich': enrich
}
| SqlTransform(
"""
SELECT
simple.`id` AS `id`,
enrich.metadata AS metadata
FROM simple
JOIN enrich
ON simple.`id` = enrich.`id`"""))
apache_beam/transforms/sql_test.py:130:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
apache_beam/transforms/ptransform.py:623: in __ror__
result = p.apply(self, pvalueish, label)
apache_beam/pipeline.py:732: in apply
pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
apache_beam/runners/runner.py:203: in apply
return self.apply_PTransform(transform, input, options)
apache_beam/runners/runner.py:207: in apply_PTransform
return transform.expand(input)
apache_beam/transforms/external.py:750: in expand
with ExternalTransform.service(expansion_service) as service:
/opt/hostedtoolcache/Python/3.11.9/x64/lib/python3.11/contextlib.py:137: in __enter__
return next(self.gen)
apache_beam/transforms/external.py:806: in service
with expansion_service as stub:
apache_beam/transforms/external.py:1032: in __enter__
self._service = self._service_provider.__enter__()
apache_beam/utils/subprocess_server.py:158: in __enter__
return self.start()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
self = <apache_beam.utils.subprocess_server.JavaJarServer object at 0x79b9a9ec3910>
def start(self):
try:
process, endpoint = self.start_process()
wait_secs = .1
channel_options = [("grpc.max_receive_message_length", -1),
("grpc.max_send_message_length", -1)]
self._grpc_channel = grpc.insecure_channel(
endpoint, options=channel_options)
channel_ready = grpc.channel_ready_future(self._grpc_channel)
while True:
if process is not None and process.poll() is not None:
_LOGGER.error("Started job service with %s", process.args)
> raise RuntimeError(
'Service failed to start up with error %s' % process.poll())
E RuntimeError: Service failed to start up with error 1
apache_beam/utils/subprocess_server.py:175: RuntimeError
Check warning on line 0 in apache_beam.transforms.sql_test.SqlTransformTest
github-actions / Test Results
test_generate_data (apache_beam.transforms.sql_test.SqlTransformTest) failed
sdks/python/pytest_xlangSqlValidateRunner.xml [took 0s]
Raw output
RuntimeError: Service failed to start up with error 1
self = <apache_beam.transforms.sql_test.SqlTransformTest testMethod=test_generate_data>
def test_generate_data(self):
with TestPipeline() as p:
> out = p | SqlTransform(
"""SELECT
CAST(1 AS INT) AS `id`,
CAST('foo' AS VARCHAR) AS `str`,
CAST(3.14 AS DOUBLE) AS `flt`""")
apache_beam/transforms/sql_test.py:74:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
apache_beam/transforms/ptransform.py:623: in __ror__
result = p.apply(self, pvalueish, label)
apache_beam/pipeline.py:732: in apply
pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
apache_beam/runners/runner.py:203: in apply
return self.apply_PTransform(transform, input, options)
apache_beam/runners/runner.py:207: in apply_PTransform
return transform.expand(input)
apache_beam/transforms/external.py:750: in expand
with ExternalTransform.service(expansion_service) as service:
/opt/hostedtoolcache/Python/3.11.9/x64/lib/python3.11/contextlib.py:137: in __enter__
return next(self.gen)
apache_beam/transforms/external.py:806: in service
with expansion_service as stub:
apache_beam/transforms/external.py:1032: in __enter__
self._service = self._service_provider.__enter__()
apache_beam/utils/subprocess_server.py:158: in __enter__
return self.start()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
self = <apache_beam.utils.subprocess_server.JavaJarServer object at 0x7f510a2128d0>
def start(self):
try:
process, endpoint = self.start_process()
wait_secs = .1
channel_options = [("grpc.max_receive_message_length", -1),
("grpc.max_send_message_length", -1)]
self._grpc_channel = grpc.insecure_channel(
endpoint, options=channel_options)
channel_ready = grpc.channel_ready_future(self._grpc_channel)
while True:
if process is not None and process.poll() is not None:
_LOGGER.error("Started job service with %s", process.args)
> raise RuntimeError(
'Service failed to start up with error %s' % process.poll())
E RuntimeError: Service failed to start up with error 1
apache_beam/utils/subprocess_server.py:175: RuntimeError
Check warning on line 0 in apache_beam.transforms.sql_test.SqlTransformTest
github-actions / Test Results
test_map (apache_beam.transforms.sql_test.SqlTransformTest) failed
sdks/python/pytest_xlangSqlValidateRunner.xml [took 0s]
Raw output
RuntimeError: Service failed to start up with error 1
self = <apache_beam.transforms.sql_test.SqlTransformTest testMethod=test_map>
def test_map(self):
with TestPipeline() as p:
out = (
> p
| beam.Create([
Shopper('bob', {
'bananas': 6, 'cherries': 3
}),
Shopper('alice', {
'apples': 2, 'bananas': 3
})
]).with_output_types(Shopper)
| SqlTransform("SELECT * FROM PCOLLECTION WHERE shopper = 'alice'"))
apache_beam/transforms/sql_test.py:180:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
apache_beam/pvalue.py:138: in __or__
return self.pipeline.apply(ptransform, self)
apache_beam/pipeline.py:732: in apply
pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
apache_beam/runners/runner.py:203: in apply
return self.apply_PTransform(transform, input, options)
apache_beam/runners/runner.py:207: in apply_PTransform
return transform.expand(input)
apache_beam/transforms/external.py:750: in expand
with ExternalTransform.service(expansion_service) as service:
/opt/hostedtoolcache/Python/3.11.9/x64/lib/python3.11/contextlib.py:137: in __enter__
return next(self.gen)
apache_beam/transforms/external.py:806: in service
with expansion_service as stub:
apache_beam/transforms/external.py:1032: in __enter__
self._service = self._service_provider.__enter__()
apache_beam/utils/subprocess_server.py:158: in __enter__
return self.start()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
self = <apache_beam.utils.subprocess_server.JavaJarServer object at 0x78c25e2ddc10>
def start(self):
try:
process, endpoint = self.start_process()
wait_secs = .1
channel_options = [("grpc.max_receive_message_length", -1),
("grpc.max_send_message_length", -1)]
self._grpc_channel = grpc.insecure_channel(
endpoint, options=channel_options)
channel_ready = grpc.channel_ready_future(self._grpc_channel)
while True:
if process is not None and process.poll() is not None:
_LOGGER.error("Started job service with %s", process.args)
> raise RuntimeError(
'Service failed to start up with error %s' % process.poll())
E RuntimeError: Service failed to start up with error 1
apache_beam/utils/subprocess_server.py:175: RuntimeError
Check warning on line 0 in apache_beam.transforms.sql_test.SqlTransformTest
github-actions / Test Results
test_project (apache_beam.transforms.sql_test.SqlTransformTest) failed
sdks/python/pytest_xlangSqlValidateRunner.xml [took 0s]
Raw output
RuntimeError: Service failed to start up with error 1
self = <apache_beam.transforms.sql_test.SqlTransformTest testMethod=test_project>
def test_project(self):
with TestPipeline() as p:
out = (
> p | beam.Create([SimpleRow(1, "foo", 3.14)])
| SqlTransform("SELECT `id`, `flt` FROM PCOLLECTION"))
apache_beam/transforms/sql_test.py:84:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
apache_beam/pvalue.py:138: in __or__
return self.pipeline.apply(ptransform, self)
apache_beam/pipeline.py:732: in apply
pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
apache_beam/runners/runner.py:203: in apply
return self.apply_PTransform(transform, input, options)
apache_beam/runners/runner.py:207: in apply_PTransform
return transform.expand(input)
apache_beam/transforms/external.py:750: in expand
with ExternalTransform.service(expansion_service) as service:
/opt/hostedtoolcache/Python/3.11.9/x64/lib/python3.11/contextlib.py:137: in __enter__
return next(self.gen)
apache_beam/transforms/external.py:806: in service
with expansion_service as stub:
apache_beam/transforms/external.py:1032: in __enter__
self._service = self._service_provider.__enter__()
apache_beam/utils/subprocess_server.py:158: in __enter__
return self.start()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
self = <apache_beam.utils.subprocess_server.JavaJarServer object at 0x7f1764b95450>
def start(self):
try:
process, endpoint = self.start_process()
wait_secs = .1
channel_options = [("grpc.max_receive_message_length", -1),
("grpc.max_send_message_length", -1)]
self._grpc_channel = grpc.insecure_channel(
endpoint, options=channel_options)
channel_ready = grpc.channel_ready_future(self._grpc_channel)
while True:
if process is not None and process.poll() is not None:
_LOGGER.error("Started job service with %s", process.args)
> raise RuntimeError(
'Service failed to start up with error %s' % process.poll())
E RuntimeError: Service failed to start up with error 1
apache_beam/utils/subprocess_server.py:175: RuntimeError
Check warning on line 0 in apache_beam.transforms.sql_test.SqlTransformTest
github-actions / Test Results
test_agg (apache_beam.transforms.sql_test.SqlTransformTest) failed
sdks/python/pytest_xlangSqlValidateRunner.xml [took 0s]
Raw output
RuntimeError: Service failed to start up with error 1
self = <apache_beam.transforms.sql_test.SqlTransformTest testMethod=test_agg>
def test_agg(self):
with TestPipeline() as p:
out = (
> p
| beam.Create([
SimpleRow(1, "foo", 1.),
SimpleRow(1, "foo", 2.),
SimpleRow(1, "foo", 3.),
SimpleRow(2, "bar", 1.414),
SimpleRow(2, "bar", 1.414),
SimpleRow(2, "bar", 1.414),
SimpleRow(2, "bar", 1.414),
])
| SqlTransform(
"""
SELECT
`str`,
COUNT(*) AS `count`,
SUM(`id`) AS `sum`,
AVG(`flt`) AS `avg`
FROM PCOLLECTION GROUP BY `str`"""))
apache_beam/transforms/sql_test.py:99:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
apache_beam/pvalue.py:138: in __or__
return self.pipeline.apply(ptransform, self)
apache_beam/pipeline.py:732: in apply
pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
apache_beam/runners/runner.py:203: in apply
return self.apply_PTransform(transform, input, options)
apache_beam/runners/runner.py:207: in apply_PTransform
return transform.expand(input)
apache_beam/transforms/external.py:750: in expand
with ExternalTransform.service(expansion_service) as service:
/opt/hostedtoolcache/Python/3.11.9/x64/lib/python3.11/contextlib.py:137: in __enter__
return next(self.gen)
apache_beam/transforms/external.py:806: in service
with expansion_service as stub:
apache_beam/transforms/external.py:1032: in __enter__
self._service = self._service_provider.__enter__()
apache_beam/utils/subprocess_server.py:158: in __enter__
return self.start()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
self = <apache_beam.utils.subprocess_server.JavaJarServer object at 0x7cee2cd90850>
def start(self):
try:
process, endpoint = self.start_process()
wait_secs = .1
channel_options = [("grpc.max_receive_message_length", -1),
("grpc.max_send_message_length", -1)]
self._grpc_channel = grpc.insecure_channel(
endpoint, options=channel_options)
channel_ready = grpc.channel_ready_future(self._grpc_channel)
while True:
if process is not None and process.poll() is not None:
_LOGGER.error("Started job service with %s", process.args)
> raise RuntimeError(
'Service failed to start up with error %s' % process.poll())
E RuntimeError: Service failed to start up with error 1
apache_beam/utils/subprocess_server.py:175: RuntimeError
Check warning on line 0 in apache_beam.transforms.sql_test.SqlTransformTest
github-actions / Test Results
test_filter (apache_beam.transforms.sql_test.SqlTransformTest) failed
sdks/python/pytest_xlangSqlValidateRunner.xml [took 0s]
Raw output
RuntimeError: Service failed to start up with error 1
self = <apache_beam.transforms.sql_test.SqlTransformTest testMethod=test_filter>
def test_filter(self):
with TestPipeline() as p:
out = (
> p
| beam.Create([SimpleRow(1, "foo", 3.14), SimpleRow(2, "bar", 1.414)])
| SqlTransform("SELECT * FROM PCOLLECTION WHERE `str` = 'bar'"))
apache_beam/transforms/sql_test.py:91:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
apache_beam/pvalue.py:138: in __or__
return self.pipeline.apply(ptransform, self)
apache_beam/pipeline.py:732: in apply
pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
apache_beam/runners/runner.py:203: in apply
return self.apply_PTransform(transform, input, options)
apache_beam/runners/runner.py:207: in apply_PTransform
return transform.expand(input)
apache_beam/transforms/external.py:750: in expand
with ExternalTransform.service(expansion_service) as service:
/opt/hostedtoolcache/Python/3.11.9/x64/lib/python3.11/contextlib.py:137: in __enter__
return next(self.gen)
apache_beam/transforms/external.py:806: in service
with expansion_service as stub:
apache_beam/transforms/external.py:1032: in __enter__
self._service = self._service_provider.__enter__()
apache_beam/utils/subprocess_server.py:158: in __enter__
return self.start()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
self = <apache_beam.utils.subprocess_server.JavaJarServer object at 0x7fbf42254290>
def start(self):
try:
process, endpoint = self.start_process()
wait_secs = .1
channel_options = [("grpc.max_receive_message_length", -1),
("grpc.max_send_message_length", -1)]
self._grpc_channel = grpc.insecure_channel(
endpoint, options=channel_options)
channel_ready = grpc.channel_ready_future(self._grpc_channel)
while True:
if process is not None and process.poll() is not None:
_LOGGER.error("Started job service with %s", process.args)
> raise RuntimeError(
'Service failed to start up with error %s' % process.poll())
E RuntimeError: Service failed to start up with error 1
apache_beam/utils/subprocess_server.py:175: RuntimeError
Check warning on line 0 in apache_beam.transforms.sql_test.SqlTransformTest
github-actions / Test Results
test_windowing_before_sql (apache_beam.transforms.sql_test.SqlTransformTest) failed
sdks/python/pytest_xlangSqlValidateRunner.xml [took 0s]
Raw output
RuntimeError: Service failed to start up with error 1
self = <apache_beam.transforms.sql_test.SqlTransformTest testMethod=test_windowing_before_sql>
def test_windowing_before_sql(self):
with TestPipeline() as p:
out = (
> p | beam.Create([
SimpleRow(5, "foo", 1.),
SimpleRow(15, "bar", 2.),
SimpleRow(25, "baz", 3.)
])
| beam.Map(lambda v: beam.window.TimestampedValue(v, v.id)).
with_output_types(SimpleRow)
| beam.WindowInto(
beam.window.FixedWindows(10)).with_output_types(SimpleRow)
| SqlTransform("SELECT COUNT(*) as `count` FROM PCOLLECTION"))
apache_beam/transforms/sql_test.py:165:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
apache_beam/pvalue.py:138: in __or__
return self.pipeline.apply(ptransform, self)
apache_beam/pipeline.py:732: in apply
pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
apache_beam/runners/runner.py:203: in apply
return self.apply_PTransform(transform, input, options)
apache_beam/runners/runner.py:207: in apply_PTransform
return transform.expand(input)
apache_beam/transforms/external.py:750: in expand
with ExternalTransform.service(expansion_service) as service:
/opt/hostedtoolcache/Python/3.11.9/x64/lib/python3.11/contextlib.py:137: in __enter__
return next(self.gen)
apache_beam/transforms/external.py:806: in service
with expansion_service as stub:
apache_beam/transforms/external.py:1032: in __enter__
self._service = self._service_provider.__enter__()
apache_beam/utils/subprocess_server.py:158: in __enter__
return self.start()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
self = <apache_beam.utils.subprocess_server.JavaJarServer object at 0x798047655050>
def start(self):
try:
process, endpoint = self.start_process()
wait_secs = .1
channel_options = [("grpc.max_receive_message_length", -1),
("grpc.max_send_message_length", -1)]
self._grpc_channel = grpc.insecure_channel(
endpoint, options=channel_options)
channel_ready = grpc.channel_ready_future(self._grpc_channel)
while True:
if process is not None and process.poll() is not None:
_LOGGER.error("Started job service with %s", process.args)
> raise RuntimeError(
'Service failed to start up with error %s' % process.poll())
E RuntimeError: Service failed to start up with error 1
apache_beam/utils/subprocess_server.py:175: RuntimeError
Check warning on line 0 in apache_beam.transforms.sql_test.SqlTransformTest
github-actions / Test Results
test_zetasql_generate_data (apache_beam.transforms.sql_test.SqlTransformTest) failed
sdks/python/pytest_xlangSqlValidateRunner.xml [took 0s]
Raw output
RuntimeError: Service failed to start up with error 1
self = <apache_beam.transforms.sql_test.SqlTransformTest testMethod=test_zetasql_generate_data>
def test_zetasql_generate_data(self):
with TestPipeline() as p:
> out = p | SqlTransform(
"""SELECT
CAST(1 AS INT64) AS `int`,
CAST('foo' AS STRING) AS `str`,
CAST(3.14 AS FLOAT64) AS `flt`""",
dialect="zetasql")
apache_beam/transforms/sql_test.py:154:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
apache_beam/transforms/ptransform.py:623: in __ror__
result = p.apply(self, pvalueish, label)
apache_beam/pipeline.py:732: in apply
pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
apache_beam/runners/runner.py:203: in apply
return self.apply_PTransform(transform, input, options)
apache_beam/runners/runner.py:207: in apply_PTransform
return transform.expand(input)
apache_beam/transforms/external.py:750: in expand
with ExternalTransform.service(expansion_service) as service:
/opt/hostedtoolcache/Python/3.11.9/x64/lib/python3.11/contextlib.py:137: in __enter__
return next(self.gen)
apache_beam/transforms/external.py:806: in service
with expansion_service as stub:
apache_beam/transforms/external.py:1032: in __enter__
self._service = self._service_provider.__enter__()
apache_beam/utils/subprocess_server.py:158: in __enter__
return self.start()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
self = <apache_beam.utils.subprocess_server.JavaJarServer object at 0x7cee2c4c9ad0>
def start(self):
try:
process, endpoint = self.start_process()
wait_secs = .1
channel_options = [("grpc.max_receive_message_length", -1),
("grpc.max_send_message_length", -1)]
self._grpc_channel = grpc.insecure_channel(
endpoint, options=channel_options)
channel_ready = grpc.channel_ready_future(self._grpc_channel)
while True:
if process is not None and process.poll() is not None:
_LOGGER.error("Started job service with %s", process.args)
> raise RuntimeError(
'Service failed to start up with error %s' % process.poll())
E RuntimeError: Service failed to start up with error 1
apache_beam/utils/subprocess_server.py:175: RuntimeError
Check notice on line 0 in .github
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.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.enrichment_handlers.feast_feature_store_it_test
apache_beam.transforms.enrichment_handlers.feast_feature_store_test
apache_beam.typehints.pytorch_type_compatibility_test
Check notice on line 0 in .github
github-actions / Test Results
28 tests found
There are 28 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.enrichment_handlers.feast_feature_store_it_test
apache_beam.transforms.enrichment_handlers.feast_feature_store_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