You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@flink.apache.org by "Flink Jira Bot (Jira)" <ji...@apache.org> on 2022/04/15 22:39:00 UTC

[jira] [Updated] (FLINK-26104) KeyError: 'type_info' in PyFlink test

     [ https://issues.apache.org/jira/browse/FLINK-26104?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ]

Flink Jira Bot updated FLINK-26104:
-----------------------------------
    Labels: stale-major test-stability  (was: test-stability)

I am the [Flink Jira Bot|https://github.com/apache/flink-jira-bot/] and I help the community manage its development. I see this issues has been marked as Major but is unassigned and neither itself nor its Sub-Tasks have been updated for 60 days. I have gone ahead and added a "stale-major" to the issue". If this ticket is a Major, please either assign yourself or give an update. Afterwards, please remove the label or in 7 days the issue will be deprioritized.


> KeyError: 'type_info' in PyFlink test
> -------------------------------------
>
>                 Key: FLINK-26104
>                 URL: https://issues.apache.org/jira/browse/FLINK-26104
>             Project: Flink
>          Issue Type: Bug
>          Components: API / Python
>    Affects Versions: 1.14.3
>            Reporter: Huang Xingbo
>            Priority: Major
>              Labels: stale-major, test-stability
>
> {code:java}
> 2022-02-14T04:33:10.9891373Z Feb 14 04:33:10 E                   Caused by: java.lang.RuntimeException: Failed to create stage bundle factory! INFO:root:Initializing Python harness: /__w/1/s/flink-python/pyflink/fn_execution/beam/beam_boot.py --id=103-1 --provision_endpoint=localhost:46669
> 2022-02-14T04:33:10.9892470Z Feb 14 04:33:10 E                   INFO:root:Starting up Python harness in a standalone process.
> 2022-02-14T04:33:10.9893079Z Feb 14 04:33:10 E                   Traceback (most recent call last):
> 2022-02-14T04:33:10.9894030Z Feb 14 04:33:10 E                     File "/__w/1/s/flink-python/dev/.conda/lib/python3.7/runpy.py", line 193, in _run_module_as_main
> 2022-02-14T04:33:10.9894791Z Feb 14 04:33:10 E                       "__main__", mod_spec)
> 2022-02-14T04:33:10.9895653Z Feb 14 04:33:10 E                     File "/__w/1/s/flink-python/dev/.conda/lib/python3.7/runpy.py", line 85, in _run_code
> 2022-02-14T04:33:10.9896395Z Feb 14 04:33:10 E                       exec(code, run_globals)
> 2022-02-14T04:33:10.9904913Z Feb 14 04:33:10 E                     File "/__w/1/s/flink-python/pyflink/fn_execution/beam/beam_boot.py", line 116, in <module>
> 2022-02-14T04:33:10.9930244Z Feb 14 04:33:10 E                       from pyflink.fn_execution.beam import beam_sdk_worker_main
> 2022-02-14T04:33:10.9931563Z Feb 14 04:33:10 E                     File "/__w/1/s/flink-python/pyflink/fn_execution/beam/beam_sdk_worker_main.py", line 21, in <module>
> 2022-02-14T04:33:10.9932630Z Feb 14 04:33:10 E                       import pyflink.fn_execution.beam.beam_operations # noqa # pylint: disable=unused-import
> 2022-02-14T04:33:10.9933754Z Feb 14 04:33:10 E                     File "/__w/1/s/flink-python/pyflink/fn_execution/beam/beam_operations.py", line 23, in <module>
> 2022-02-14T04:33:10.9934415Z Feb 14 04:33:10 E                       from pyflink.fn_execution import flink_fn_execution_pb2
> 2022-02-14T04:33:10.9935335Z Feb 14 04:33:10 E                     File "/__w/1/s/flink-python/pyflink/fn_execution/flink_fn_execution_pb2.py", line 2581, in <module>
> 2022-02-14T04:33:10.9936378Z Feb 14 04:33:10 E                       _SCHEMA_FIELDTYPE.fields_by_name['time_info'].containing_oneof = _SCHEMA_FIELDTYPE.oneofs_by_name['type_info']
> 2022-02-14T04:33:10.9946519Z Feb 14 04:33:10 E                   KeyError: 'type_info'
> 2022-02-14T04:33:10.9947110Z Feb 14 04:33:10 E                   
> 2022-02-14T04:33:10.9947911Z Feb 14 04:33:10 E                   	at org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner.createStageBundleFactory(BeamPythonFunctionRunner.java:566)
> 2022-02-14T04:33:10.9949048Z Feb 14 04:33:10 E                   	at org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner.open(BeamPythonFunctionRunner.java:255)
> 2022-02-14T04:33:10.9950162Z Feb 14 04:33:10 E                   	at org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator.open(AbstractPythonFunctionOperator.java:131)
> 2022-02-14T04:33:10.9951344Z Feb 14 04:33:10 E                   	at org.apache.flink.streaming.api.operators.python.AbstractOneInputPythonFunctionOperator.open(AbstractOneInputPythonFunctionOperator.java:116)
> 2022-02-14T04:33:10.9952487Z Feb 14 04:33:10 E                   	at org.apache.flink.streaming.api.operators.python.PythonKeyedProcessOperator.open(PythonKeyedProcessOperator.java:121)
> 2022-02-14T04:33:10.9953561Z Feb 14 04:33:10 E                   	at org.apache.flink.streaming.runtime.tasks.RegularOperatorChain.initializeStateAndOpenOperators(RegularOperatorChain.java:110)
> 2022-02-14T04:33:10.9954565Z Feb 14 04:33:10 E                   	at org.apache.flink.streaming.runtime.tasks.StreamTask.restoreGates(StreamTask.java:711)
> 2022-02-14T04:33:10.9955522Z Feb 14 04:33:10 E                   	at org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor$1.call(StreamTaskActionExecutor.java:55)
> 2022-02-14T04:33:10.9956492Z Feb 14 04:33:10 E                   	at org.apache.flink.streaming.runtime.tasks.StreamTask.restoreInternal(StreamTask.java:687)
> 2022-02-14T04:33:10.9957378Z Feb 14 04:33:10 E                   	at org.apache.flink.streaming.runtime.tasks.StreamTask.restore(StreamTask.java:654)
> 2022-02-14T04:33:10.9958252Z Feb 14 04:33:10 E                   	at org.apache.flink.runtime.taskmanager.Task.runWithSystemExitMonitoring(Task.java:958)
> 2022-02-14T04:33:10.9959108Z Feb 14 04:33:10 E                   	at org.apache.flink.runtime.taskmanager.Task.restoreAndInvoke(Task.java:927)
> 2022-02-14T04:33:10.9960039Z Feb 14 04:33:10 E                   	at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:766)
> 2022-02-14T04:33:10.9960801Z Feb 14 04:33:10 E                   	at org.apache.flink.runtime.taskmanager.Task.run(Task.java:575)
> 2022-02-14T04:33:10.9961741Z Feb 14 04:33:10 E                   	at java.lang.Thread.run(Thread.java:748)
> 2022-02-14T04:33:10.9962730Z Feb 14 04:33:10 E                   Caused by: org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.UncheckedExecutionException: java.lang.IllegalStateException: Process died with exit code 0
> 2022-02-14T04:33:10.9963904Z Feb 14 04:33:10 E                   	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$Segment.get(LocalCache.java:2050)
> 2022-02-14T04:33:10.9964920Z Feb 14 04:33:10 E                   	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache.get(LocalCache.java:3952)
> 2022-02-14T04:33:10.9965915Z Feb 14 04:33:10 E                   	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache.getOrLoad(LocalCache.java:3974)
> 2022-02-14T04:33:10.9966962Z Feb 14 04:33:10 E                   	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$LocalLoadingCache.get(LocalCache.java:4958)
> 2022-02-14T04:33:10.9968077Z Feb 14 04:33:10 E                   	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$LocalLoadingCache.getUnchecked(LocalCache.java:4964)
> 2022-02-14T04:33:10.9969238Z Feb 14 04:33:10 E                   	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$SimpleStageBundleFactory.<init>(DefaultJobBundleFactory.java:451)
> 2022-02-14T04:33:10.9970404Z Feb 14 04:33:10 E                   	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$SimpleStageBundleFactory.<init>(DefaultJobBundleFactory.java:436)
> 2022-02-14T04:33:10.9971498Z Feb 14 04:33:10 E                   	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory.forStage(DefaultJobBundleFactory.java:303)
> 2022-02-14T04:33:10.9972608Z Feb 14 04:33:10 E                   	at org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner.createStageBundleFactory(BeamPythonFunctionRunner.java:564)
> 2022-02-14T04:33:10.9973414Z Feb 14 04:33:10 E                   	... 14 more
> 2022-02-14T04:33:10.9973955Z Feb 14 04:33:10 E                   Caused by: java.lang.IllegalStateException: Process died with exit code 0
> 2022-02-14T04:33:10.9974843Z Feb 14 04:33:10 E                   	at org.apache.beam.runners.fnexecution.environment.ProcessManager$RunningProcess.isAliveOrThrow(ProcessManager.java:75)
> 2022-02-14T04:33:10.9975949Z Feb 14 04:33:10 E                   	at org.apache.beam.runners.fnexecution.environment.ProcessEnvironmentFactory.createEnvironment(ProcessEnvironmentFactory.java:112)
> 2022-02-14T04:33:10.9986988Z Feb 14 04:33:10 E                   	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$1.load(DefaultJobBundleFactory.java:252)
> 2022-02-14T04:33:11.0000248Z Feb 14 04:33:10 E                   	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$1.load(DefaultJobBundleFactory.java:231)
> 2022-02-14T04:33:11.0001496Z Feb 14 04:33:10 E                   	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$LoadingValueReference.loadFuture(LocalCache.java:3528)
> 2022-02-14T04:33:11.0002642Z Feb 14 04:33:10 E                   	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$Segment.loadSync(LocalCache.java:2277)
> 2022-02-14T04:33:11.0003721Z Feb 14 04:33:10 E                   	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$Segment.lockedGetOrLoad(LocalCache.java:2154)
> 2022-02-14T04:33:11.0004783Z Feb 14 04:33:10 E                   	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.cache.LocalCache$Segment.get(LocalCache.java:2044)
> 2022-02-14T04:33:11.0005495Z Feb 14 04:33:10 E                   	... 22 more
> 2022-02-14T04:33:11.0005879Z Feb 14 04:33:10 
> {code}
> https://dev.azure.com/apache-flink/apache-flink/_build/results?buildId=31345&view=logs&j=821b528f-1eed-5598-a3b4-7f748b13f261&t=6bb545dd-772d-5d8c-f258-f5085fba3295



--
This message was sent by Atlassian Jira
(v8.20.1#820001)