[ https://issues.apache.org/jira/browse/FLINK-32864?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel&focusedCommentId=17754092#comment-17754092 ]
Matthias Pohl edited comment on FLINK-32864 at 8/14/23 1:07 PM: ---------------------------------------------------------------- {quote} ModuleNotFoundError: No module named 'python_package1' {quote} Not sure about the close relationship with FLINK-15929. Looks like there is a module not appearing on the classpath: {code} [...] Aug 13 01:41:17 E Caused by: java.lang.RuntimeException: Error while waiting for BeamPythonFunctionRunner flush Aug 13 01:41:17 E at org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator.invokeFinishBundle(AbstractExternalPythonFunctionOperator.java:107) Aug 13 01:41:17 E at org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator.checkInvokeFinishBundleByCount(AbstractPythonFunctionOperator.java:292) Aug 13 01:41:17 E at org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator.processElement(AbstractStatelessFunctionOperator.java:101) Aug 13 01:41:17 E at org.apache.flink.streaming.runtime.tasks.CopyingChainingOutput.pushToOperator(CopyingChainingOutput.java:75) Aug 13 01:41:17 E at org.apache.flink.streaming.runtime.tasks.CopyingChainingOutput.collect(CopyingChainingOutput.java:50) Aug 13 01:41:17 E at org.apache.flink.streaming.runtime.tasks.CopyingChainingOutput.collect(CopyingChainingOutput.java:29) Aug 13 01:41:17 E at org.apache.flink.streaming.api.operators.StreamSourceContexts$ManualWatermarkContext.processAndCollect(StreamSourceContexts.java:425) Aug 13 01:41:17 E at org.apache.flink.streaming.api.operators.StreamSourceContexts$WatermarkContext.collect(StreamSourceContexts.java:520) Aug 13 01:41:17 E at org.apache.flink.streaming.api.operators.StreamSourceContexts$SwitchingOnClose.collect(StreamSourceContexts.java:110) Aug 13 01:41:17 E at org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction.run(InputFormatSourceFunction.java:99) Aug 13 01:41:17 E at org.apache.flink.streaming.api.operators.StreamSource.run(StreamSource.java:114) Aug 13 01:41:17 E at org.apache.flink.streaming.api.operators.StreamSource.run(StreamSource.java:71) Aug 13 01:41:17 E at org.apache.flink.streaming.runtime.tasks.SourceStreamTask$LegacySourceFunctionThread.run(SourceStreamTask.java:338) Aug 13 01:41:17 E Caused by: java.lang.RuntimeException: Failed to close remote bundle Aug 13 01:41:17 E at org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner.finishBundle(BeamPythonFunctionRunner.java:423) Aug 13 01:41:17 E at org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner.flush(BeamPythonFunctionRunner.java:407) Aug 13 01:41:17 E at org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator.lambda$invokeFinishBundle$0(AbstractExternalPythonFunctionOperator.java:86) Aug 13 01:41:17 E at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511) Aug 13 01:41:17 E at java.util.concurrent.FutureTask.run(FutureTask.java:266) Aug 13 01:41:17 E at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149) Aug 13 01:41:17 E at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624) Aug 13 01:41:17 E at java.lang.Thread.run(Thread.java:748) Aug 13 01:41:17 E Caused by: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction 1: Traceback (most recent call last): Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 287, in _execute Aug 13 01:41:17 E response = task() Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 360, in <lambda> Aug 13 01:41:17 E lambda: self.create_worker().do_instruction(request), request) Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 597, in do_instruction Aug 13 01:41:17 E getattr(request, request_type), request.instruction_id) Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 634, in process_bundle Aug 13 01:41:17 E bundle_processor.process_bundle(instruction_id)) Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1004, in process_bundle Aug 13 01:41:17 E element.data) Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 227, in process_encoded Aug 13 01:41:17 E self.output(decoded_value) Aug 13 01:41:17 E File "apache_beam/runners/worker/operations.py", line 526, in apache_beam.runners.worker.operations.Operation.output Aug 13 01:41:17 E File "apache_beam/runners/worker/operations.py", line 528, in apache_beam.runners.worker.operations.Operation.output Aug 13 01:41:17 E File "apache_beam/runners/worker/operations.py", line 237, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive Aug 13 01:41:17 E File "apache_beam/runners/worker/operations.py", line 240, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive Aug 13 01:41:17 E File "pyflink/fn_execution/beam/beam_operations_fast.pyx", line 169, in pyflink.fn_execution.beam.beam_operations_fast.FunctionOperation.process Aug 13 01:41:17 E with self.scoped_process_state: Aug 13 01:41:17 E File "pyflink/fn_execution/beam/beam_operations_fast.pyx", line 196, in pyflink.fn_execution.beam.beam_operations_fast.FunctionOperation.process Aug 13 01:41:17 E self.process_element(input_processor.next()) Aug 13 01:41:17 E File "/__w/3/s/flink-python/pyflink/fn_execution/table/operations.py", line 102, in process_element Aug 13 01:41:17 E return self.func(value) Aug 13 01:41:17 E File "<string>", line 1, in <lambda> Aug 13 01:41:17 E File "/__w/3/s/flink-python/pyflink/table/tests/test_dependency.py", line 184, in add_one Aug 13 01:41:17 E from python_package1 import plus Aug 13 01:41:17 E ModuleNotFoundError: No module named 'python_package1' Aug 13 01:41:17 E Aug 13 01:41:17 E at java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357) Aug 13 01:41:17 E at java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1908) Aug 13 01:41:17 E at org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:61) Aug 13 01:41:17 E at org.apache.beam.runners.fnexecution.control.SdkHarnessClient$BundleProcessor$ActiveBundle.close(SdkHarnessClient.java:504) Aug 13 01:41:17 E at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$SimpleStageBundleFactory$1.close(DefaultJobBundleFactory.java:555) Aug 13 01:41:17 E at org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner.finishBundle(BeamPythonFunctionRunner.java:421) Aug 13 01:41:17 E ... 7 more Aug 13 01:41:17 E Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction 1: Traceback (most recent call last): Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 287, in _execute Aug 13 01:41:17 E response = task() Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 360, in <lambda> Aug 13 01:41:17 E lambda: self.create_worker().do_instruction(request), request) Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 597, in do_instruction Aug 13 01:41:17 E getattr(request, request_type), request.instruction_id) Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 634, in process_bundle Aug 13 01:41:17 E bundle_processor.process_bundle(instruction_id)) Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1004, in process_bundle Aug 13 01:41:17 E element.data) Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 227, in process_encoded Aug 13 01:41:17 E self.output(decoded_value) Aug 13 01:41:17 E File "apache_beam/runners/worker/operations.py", line 526, in apache_beam.runners.worker.operations.Operation.output Aug 13 01:41:17 E File "apache_beam/runners/worker/operations.py", line 528, in apache_beam.runners.worker.operations.Operation.output Aug 13 01:41:17 E File "apache_beam/runners/worker/operations.py", line 237, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive Aug 13 01:41:17 E File "apache_beam/runners/worker/operations.py", line 240, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive Aug 13 01:41:17 E File "pyflink/fn_execution/beam/beam_operations_fast.pyx", line 169, in pyflink.fn_execution.beam.beam_operations_fast.FunctionOperation.process Aug 13 01:41:17 E with self.scoped_process_state: Aug 13 01:41:17 E File "pyflink/fn_execution/beam/beam_operations_fast.pyx", line 196, in pyflink.fn_execution.beam.beam_operations_fast.FunctionOperation.process Aug 13 01:41:17 E self.process_element(input_processor.next()) Aug 13 01:41:17 E File "/__w/3/s/flink-python/pyflink/fn_execution/table/operations.py", line 102, in process_element Aug 13 01:41:17 E return self.func(value) Aug 13 01:41:17 E File "<string>", line 1, in <lambda> Aug 13 01:41:17 E File "/__w/3/s/flink-python/pyflink/table/tests/test_dependency.py", line 184, in add_one Aug 13 01:41:17 E from python_package1 import plus Aug 13 01:41:17 E ModuleNotFoundError: No module named 'python_package1' Aug 13 01:41:17 E Aug 13 01:41:17 E at org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180) Aug 13 01:41:17 E at org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160) Aug 13 01:41:17 E at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:262) Aug 13 01:41:17 E at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33) Aug 13 01:41:17 E at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76) Aug 13 01:41:17 E at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:332) Aug 13 01:41:17 E at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:315) Aug 13 01:41:17 E at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:834) Aug 13 01:41:17 E at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37) Aug 13 01:41:17 E at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133) Aug 13 01:41:17 E ... 3 more {code} was (Author: mapohl): Not sure about the close relationship with FLINK-15929. Looks like there is a module not appearing on the classpath: {{ModuleNotFoundError: No module named 'python_package1'}} {code} [...] Aug 13 01:41:17 E Caused by: java.lang.RuntimeException: Error while waiting for BeamPythonFunctionRunner flush Aug 13 01:41:17 E at org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator.invokeFinishBundle(AbstractExternalPythonFunctionOperator.java:107) Aug 13 01:41:17 E at org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator.checkInvokeFinishBundleByCount(AbstractPythonFunctionOperator.java:292) Aug 13 01:41:17 E at org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator.processElement(AbstractStatelessFunctionOperator.java:101) Aug 13 01:41:17 E at org.apache.flink.streaming.runtime.tasks.CopyingChainingOutput.pushToOperator(CopyingChainingOutput.java:75) Aug 13 01:41:17 E at org.apache.flink.streaming.runtime.tasks.CopyingChainingOutput.collect(CopyingChainingOutput.java:50) Aug 13 01:41:17 E at org.apache.flink.streaming.runtime.tasks.CopyingChainingOutput.collect(CopyingChainingOutput.java:29) Aug 13 01:41:17 E at org.apache.flink.streaming.api.operators.StreamSourceContexts$ManualWatermarkContext.processAndCollect(StreamSourceContexts.java:425) Aug 13 01:41:17 E at org.apache.flink.streaming.api.operators.StreamSourceContexts$WatermarkContext.collect(StreamSourceContexts.java:520) Aug 13 01:41:17 E at org.apache.flink.streaming.api.operators.StreamSourceContexts$SwitchingOnClose.collect(StreamSourceContexts.java:110) Aug 13 01:41:17 E at org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction.run(InputFormatSourceFunction.java:99) Aug 13 01:41:17 E at org.apache.flink.streaming.api.operators.StreamSource.run(StreamSource.java:114) Aug 13 01:41:17 E at org.apache.flink.streaming.api.operators.StreamSource.run(StreamSource.java:71) Aug 13 01:41:17 E at org.apache.flink.streaming.runtime.tasks.SourceStreamTask$LegacySourceFunctionThread.run(SourceStreamTask.java:338) Aug 13 01:41:17 E Caused by: java.lang.RuntimeException: Failed to close remote bundle Aug 13 01:41:17 E at org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner.finishBundle(BeamPythonFunctionRunner.java:423) Aug 13 01:41:17 E at org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner.flush(BeamPythonFunctionRunner.java:407) Aug 13 01:41:17 E at org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator.lambda$invokeFinishBundle$0(AbstractExternalPythonFunctionOperator.java:86) Aug 13 01:41:17 E at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511) Aug 13 01:41:17 E at java.util.concurrent.FutureTask.run(FutureTask.java:266) Aug 13 01:41:17 E at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149) Aug 13 01:41:17 E at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624) Aug 13 01:41:17 E at java.lang.Thread.run(Thread.java:748) Aug 13 01:41:17 E Caused by: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction 1: Traceback (most recent call last): Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 287, in _execute Aug 13 01:41:17 E response = task() Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 360, in <lambda> Aug 13 01:41:17 E lambda: self.create_worker().do_instruction(request), request) Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 597, in do_instruction Aug 13 01:41:17 E getattr(request, request_type), request.instruction_id) Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 634, in process_bundle Aug 13 01:41:17 E bundle_processor.process_bundle(instruction_id)) Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1004, in process_bundle Aug 13 01:41:17 E element.data) Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 227, in process_encoded Aug 13 01:41:17 E self.output(decoded_value) Aug 13 01:41:17 E File "apache_beam/runners/worker/operations.py", line 526, in apache_beam.runners.worker.operations.Operation.output Aug 13 01:41:17 E File "apache_beam/runners/worker/operations.py", line 528, in apache_beam.runners.worker.operations.Operation.output Aug 13 01:41:17 E File "apache_beam/runners/worker/operations.py", line 237, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive Aug 13 01:41:17 E File "apache_beam/runners/worker/operations.py", line 240, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive Aug 13 01:41:17 E File "pyflink/fn_execution/beam/beam_operations_fast.pyx", line 169, in pyflink.fn_execution.beam.beam_operations_fast.FunctionOperation.process Aug 13 01:41:17 E with self.scoped_process_state: Aug 13 01:41:17 E File "pyflink/fn_execution/beam/beam_operations_fast.pyx", line 196, in pyflink.fn_execution.beam.beam_operations_fast.FunctionOperation.process Aug 13 01:41:17 E self.process_element(input_processor.next()) Aug 13 01:41:17 E File "/__w/3/s/flink-python/pyflink/fn_execution/table/operations.py", line 102, in process_element Aug 13 01:41:17 E return self.func(value) Aug 13 01:41:17 E File "<string>", line 1, in <lambda> Aug 13 01:41:17 E File "/__w/3/s/flink-python/pyflink/table/tests/test_dependency.py", line 184, in add_one Aug 13 01:41:17 E from python_package1 import plus Aug 13 01:41:17 E ModuleNotFoundError: No module named 'python_package1' Aug 13 01:41:17 E Aug 13 01:41:17 E at java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357) Aug 13 01:41:17 E at java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1908) Aug 13 01:41:17 E at org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:61) Aug 13 01:41:17 E at org.apache.beam.runners.fnexecution.control.SdkHarnessClient$BundleProcessor$ActiveBundle.close(SdkHarnessClient.java:504) Aug 13 01:41:17 E at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$SimpleStageBundleFactory$1.close(DefaultJobBundleFactory.java:555) Aug 13 01:41:17 E at org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner.finishBundle(BeamPythonFunctionRunner.java:421) Aug 13 01:41:17 E ... 7 more Aug 13 01:41:17 E Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction 1: Traceback (most recent call last): Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 287, in _execute Aug 13 01:41:17 E response = task() Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 360, in <lambda> Aug 13 01:41:17 E lambda: self.create_worker().do_instruction(request), request) Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 597, in do_instruction Aug 13 01:41:17 E getattr(request, request_type), request.instruction_id) Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 634, in process_bundle Aug 13 01:41:17 E bundle_processor.process_bundle(instruction_id)) Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1004, in process_bundle Aug 13 01:41:17 E element.data) Aug 13 01:41:17 E File "/__w/3/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 227, in process_encoded Aug 13 01:41:17 E self.output(decoded_value) Aug 13 01:41:17 E File "apache_beam/runners/worker/operations.py", line 526, in apache_beam.runners.worker.operations.Operation.output Aug 13 01:41:17 E File "apache_beam/runners/worker/operations.py", line 528, in apache_beam.runners.worker.operations.Operation.output Aug 13 01:41:17 E File "apache_beam/runners/worker/operations.py", line 237, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive Aug 13 01:41:17 E File "apache_beam/runners/worker/operations.py", line 240, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive Aug 13 01:41:17 E File "pyflink/fn_execution/beam/beam_operations_fast.pyx", line 169, in pyflink.fn_execution.beam.beam_operations_fast.FunctionOperation.process Aug 13 01:41:17 E with self.scoped_process_state: Aug 13 01:41:17 E File "pyflink/fn_execution/beam/beam_operations_fast.pyx", line 196, in pyflink.fn_execution.beam.beam_operations_fast.FunctionOperation.process Aug 13 01:41:17 E self.process_element(input_processor.next()) Aug 13 01:41:17 E File "/__w/3/s/flink-python/pyflink/fn_execution/table/operations.py", line 102, in process_element Aug 13 01:41:17 E return self.func(value) Aug 13 01:41:17 E File "<string>", line 1, in <lambda> Aug 13 01:41:17 E File "/__w/3/s/flink-python/pyflink/table/tests/test_dependency.py", line 184, in add_one Aug 13 01:41:17 E from python_package1 import plus Aug 13 01:41:17 E ModuleNotFoundError: No module named 'python_package1' Aug 13 01:41:17 E Aug 13 01:41:17 E at org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180) Aug 13 01:41:17 E at org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160) Aug 13 01:41:17 E at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:262) Aug 13 01:41:17 E at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33) Aug 13 01:41:17 E at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76) Aug 13 01:41:17 E at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:332) Aug 13 01:41:17 E at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:315) Aug 13 01:41:17 E at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:834) Aug 13 01:41:17 E at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37) Aug 13 01:41:17 E at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133) Aug 13 01:41:17 E ... 3 more {code} > StreamDependencyTests.test_set_requirements_with_cached_directory fails on > AZP > ------------------------------------------------------------------------------- > > Key: FLINK-32864 > URL: https://issues.apache.org/jira/browse/FLINK-32864 > Project: Flink > Issue Type: Bug > Components: API / Python > Affects Versions: 1.18.0 > Reporter: Sergey Nuyanzin > Priority: Critical > Labels: test-stability > > This build > [https://dev.azure.com/apache-flink/apache-flink/_build/results?buildId=52209&view=logs&j=9cada3cb-c1d3-5621-16da-0f718fb86602&t=c67e71ed-6451-5d26-8920-5a8cf9651901&l=25208] > fails as below. > The error is very similar to one of the old issues FLINK-15929, probably some > dependencies in requirements should be fixed... > {noformat} > Aug 13 01:41:17 =================================== FAILURES > =================================== > Aug 13 01:41:17 ______ > StreamDependencyTests.test_set_requirements_with_cached_directory _______ > Aug 13 01:41:17 > Aug 13 01:41:17 self = > <pyflink.table.tests.test_dependency.StreamDependencyTests > testMethod=test_set_requirements_with_cached_directory> > Aug 13 01:41:17 > Aug 13 01:41:17 def test_set_requirements_with_cached_directory(self): > Aug 13 01:41:17 tmp_dir = self.tempdir > Aug 13 01:41:17 requirements_txt_path = os.path.join(tmp_dir, > "requirements_txt_" + str(uuid.uuid4())) > Aug 13 01:41:17 with open(requirements_txt_path, 'w') as f: > Aug 13 01:41:17 f.write("python-package1==0.0.0") > Aug 13 01:41:17 > Aug 13 01:41:17 requirements_dir_path = os.path.join(tmp_dir, > "requirements_dir_" + str(uuid.uuid4())) > Aug 13 01:41:17 os.mkdir(requirements_dir_path) > Aug 13 01:41:17 package_file_name = "python-package1-0.0.0.tar.gz" > {noformat} -- This message was sent by Atlassian Jira (v8.20.10#820010)