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/01 22:39:00 UTC

[jira] [Updated] (FLINK-25281) StreamingModeDataStreamTests::test_set_stream_env failed on azure

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

Flink Jira Bot updated FLINK-25281:
-----------------------------------
    Labels: stale-assigned 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 issue is assigned but has not received an update in 30 days, so it has been labeled "stale-assigned".
If you are still working on the issue, please remove the label and add a comment updating the community on your progress.  If this issue is waiting on feedback, please consider this a reminder to the committer/reviewer. Flink is a very active project, and so we appreciate your patience.
If you are no longer working on the issue, please unassign yourself so someone else may work on it.


> StreamingModeDataStreamTests::test_set_stream_env failed on azure
> -----------------------------------------------------------------
>
>                 Key: FLINK-25281
>                 URL: https://issues.apache.org/jira/browse/FLINK-25281
>             Project: Flink
>          Issue Type: Bug
>          Components: API / Python
>    Affects Versions: 1.14.0, 1.15.0
>            Reporter: Yun Gao
>            Assignee: Huang Xingbo
>            Priority: Major
>              Labels: stale-assigned, test-stability
>
> {code:java}
> 2021-12-13T02:25:17.0905034Z Dec 13 02:25:17 =================================== FAILURES ===================================
> 2021-12-13T02:25:17.0905626Z Dec 13 02:25:17 _____________ StreamExecutionEnvironmentTests.test_set_stream_env ______________
> 2021-12-13T02:25:17.0906084Z Dec 13 02:25:17 
> 2021-12-13T02:25:17.0906569Z Dec 13 02:25:17 self = <pyflink.datastream.tests.test_stream_execution_environment.StreamExecutionEnvironmentTests testMethod=test_set_stream_env>
> 2021-12-13T02:25:17.0907047Z Dec 13 02:25:17 
> 2021-12-13T02:25:17.0907483Z Dec 13 02:25:17     @unittest.skipIf(on_windows(), "Symbolic link is not supported on Windows, skipping.")
> 2021-12-13T02:25:17.0909942Z Dec 13 02:25:17     def test_set_stream_env(self):
> 2021-12-13T02:25:17.0910424Z Dec 13 02:25:17         import sys
> 2021-12-13T02:25:17.0910816Z Dec 13 02:25:17         python_exec = sys.executable
> 2021-12-13T02:25:17.0911369Z Dec 13 02:25:17         tmp_dir = self.tempdir
> 2021-12-13T02:25:17.0911736Z Dec 13 02:25:17         env = self.env
> 2021-12-13T02:25:17.0912153Z Dec 13 02:25:17         python_exec_link_path = os.path.join(tmp_dir, "py_exec")
> 2021-12-13T02:25:17.0912876Z Dec 13 02:25:17         os.symlink(python_exec, python_exec_link_path)
> 2021-12-13T02:25:17.0913342Z Dec 13 02:25:17         env.set_python_executable(python_exec_link_path)
> 2021-12-13T02:25:17.0913799Z Dec 13 02:25:17     
> 2021-12-13T02:25:17.0914365Z Dec 13 02:25:17         def check_python_exec(i):
> 2021-12-13T02:25:17.0914944Z Dec 13 02:25:17             import os
> 2021-12-13T02:25:17.0915541Z Dec 13 02:25:17             assert os.environ["python"] == python_exec_link_path
> 2021-12-13T02:25:17.0917263Z Dec 13 02:25:17             return i
> 2021-12-13T02:25:17.0917659Z Dec 13 02:25:17     
> 2021-12-13T02:25:17.0918488Z Dec 13 02:25:17         ds = env.from_collection([1, 2, 3, 4, 5])
> 2021-12-13T02:25:17.0919021Z Dec 13 02:25:17         ds.map(check_python_exec).add_sink(self.test_sink)
> 2021-12-13T02:25:17.0919717Z Dec 13 02:25:17 >       env.execute("test set python executable")
> 2021-12-13T02:25:17.0920265Z Dec 13 02:25:17 
> 2021-12-13T02:25:17.0920707Z Dec 13 02:25:17 pyflink/datastream/tests/test_stream_execution_environment.py:546: 
> 2021-12-13T02:25:17.0921533Z Dec 13 02:25:17 _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
> 2021-12-13T02:25:17.0922325Z Dec 13 02:25:17 pyflink/datastream/stream_execution_environment.py:691: in execute
> 2021-12-13T02:25:17.0922897Z Dec 13 02:25:17     return JobExecutionResult(self._j_stream_execution_environment.execute(j_stream_graph))
> 2021-12-13T02:25:17.0924157Z Dec 13 02:25:17 .tox/py37-cython/lib/python3.7/site-packages/py4j/java_gateway.py:1286: in __call__
> 2021-12-13T02:25:17.0924680Z Dec 13 02:25:17     answer, self.gateway_client, self.target_id, self.name)
> 2021-12-13T02:25:17.0925131Z Dec 13 02:25:17 pyflink/util/exceptions.py:146: in deco
> 2021-12-13T02:25:17.0925615Z Dec 13 02:25:17     return f(*a, **kw)
> 2021-12-13T02:25:17.0926311Z Dec 13 02:25:17 _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
> 2021-12-13T02:25:17.0926793Z Dec 13 02:25:17 
> 2021-12-13T02:25:17.0927550Z Dec 13 02:25:17 answer = 'xro13244'
> 2021-12-13T02:25:17.0928239Z Dec 13 02:25:17 gateway_client = <py4j.java_gateway.GatewayClient object at 0x7f6f553685f8>
> 2021-12-13T02:25:17.0929456Z Dec 13 02:25:17 target_id = 'o13195', name = 'execute'
> 2021-12-13T02:25:17.0929975Z Dec 13 02:25:17 
> 2021-12-13T02:25:17.0930616Z Dec 13 02:25:17     def get_return_value(answer, gateway_client, target_id=None, name=None):
> 2021-12-13T02:25:17.0931506Z Dec 13 02:25:17         """Converts an answer received from the Java gateway into a Python object.
> 2021-12-13T02:25:17.0931993Z Dec 13 02:25:17     
> 2021-12-13T02:25:17.0932493Z Dec 13 02:25:17         For example, string representation of integers are converted to Python
> 2021-12-13T02:25:17.0933249Z Dec 13 02:25:17         integer, string representation of objects are converted to JavaObject
> 2021-12-13T02:25:17.0933779Z Dec 13 02:25:17         instances, etc.
> 2021-12-13T02:25:17.0934191Z Dec 13 02:25:17     
> 2021-12-13T02:25:17.0934809Z Dec 13 02:25:17         :param answer: the string returned by the Java gateway
> 2021-12-13T02:25:17.0935350Z Dec 13 02:25:17         :param gateway_client: the gateway client used to communicate with the Java
> 2021-12-13T02:25:17.0935983Z Dec 13 02:25:17             Gateway. Only necessary if the answer is a reference (e.g., object,
> 2021-12-13T02:25:17.0936593Z Dec 13 02:25:17             list, map)
> 2021-12-13T02:25:17.0937254Z Dec 13 02:25:17         :param target_id: the name of the object from which the answer comes from
> 2021-12-13T02:25:17.0937783Z Dec 13 02:25:17             (e.g., *object1* in `object1.hello()`). Optional.
> 2021-12-13T02:25:17.0938649Z Dec 13 02:25:17         :param name: the name of the member from which the answer comes from
> 2021-12-13T02:25:17.0939345Z Dec 13 02:25:17             (e.g., *hello* in `object1.hello()`). Optional.
> 2021-12-13T02:25:17.0939964Z Dec 13 02:25:17         """
> 2021-12-13T02:25:17.0940478Z Dec 13 02:25:17         if is_error(answer)[0]:
> 2021-12-13T02:25:17.0940892Z Dec 13 02:25:17             if len(answer) > 1:
> 2021-12-13T02:25:17.0941376Z Dec 13 02:25:17                 type = answer[1]
> 2021-12-13T02:25:17.0942007Z Dec 13 02:25:17                 value = OUTPUT_CONVERTER[type](answer[2:], gateway_client)
> 2021-12-13T02:25:17.0942632Z Dec 13 02:25:17                 if answer[1] == REFERENCE_TYPE:
> 2021-12-13T02:25:17.0943271Z Dec 13 02:25:17                     raise Py4JJavaError(
> 2021-12-13T02:25:17.0943777Z Dec 13 02:25:17                         "An error occurred while calling {0}{1}{2}.\n".
> 2021-12-13T02:25:17.0944418Z Dec 13 02:25:17 >                       format(target_id, ".", name), value)
> 2021-12-13T02:25:17.0945358Z Dec 13 02:25:17 E                   py4j.protocol.Py4JJavaError: An error occurred while calling o13195.execute.
> 2021-12-13T02:25:17.0946044Z Dec 13 02:25:17 E                   : org.apache.flink.runtime.client.JobExecutionException: Job execution failed.
> 2021-12-13T02:25:17.0946828Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.jobmaster.JobResult.toJobExecutionResult(JobResult.java:144)
> 2021-12-13T02:25:17.0947676Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.minicluster.MiniClusterJobClient.lambda$getJobExecutionResult$3(MiniClusterJobClient.java:137)
> 2021-12-13T02:25:17.0948832Z Dec 13 02:25:17 E                   	at java.util.concurrent.CompletableFuture.uniApply(CompletableFuture.java:616)
> 2021-12-13T02:25:17.0949879Z Dec 13 02:25:17 E                   	at java.util.concurrent.CompletableFuture$UniApply.tryFire(CompletableFuture.java:591)
> 2021-12-13T02:25:17.0950937Z Dec 13 02:25:17 E                   	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
> 2021-12-13T02:25:17.0951856Z Dec 13 02:25:17 E                   	at java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:1975)
> 2021-12-13T02:25:17.0952574Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.rpc.akka.AkkaInvocationHandler.lambda$invokeRpc$1(AkkaInvocationHandler.java:258)
> 2021-12-13T02:25:17.0953291Z Dec 13 02:25:17 E                   	at java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:774)
> 2021-12-13T02:25:17.0954025Z Dec 13 02:25:17 E                   	at java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:750)
> 2021-12-13T02:25:17.0954868Z Dec 13 02:25:17 E                   	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
> 2021-12-13T02:25:17.0955515Z Dec 13 02:25:17 E                   	at java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:1975)
> 2021-12-13T02:25:17.0956286Z Dec 13 02:25:17 E                   	at org.apache.flink.util.concurrent.FutureUtils.doForward(FutureUtils.java:1389)
> 2021-12-13T02:25:17.0956987Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.concurrent.akka.ClassLoadingUtils.lambda$null$1(ClassLoadingUtils.java:93)
> 2021-12-13T02:25:17.0957747Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.concurrent.akka.ClassLoadingUtils.runWithContextClassLoader(ClassLoadingUtils.java:68)
> 2021-12-13T02:25:17.0958744Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.concurrent.akka.ClassLoadingUtils.lambda$guardCompletionWithContextClassLoader$2(ClassLoadingUtils.java:92)
> 2021-12-13T02:25:17.0959510Z Dec 13 02:25:17 E                   	at java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:774)
> 2021-12-13T02:25:17.0960192Z Dec 13 02:25:17 E                   	at java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:750)
> 2021-12-13T02:25:17.0961333Z Dec 13 02:25:17 E                   	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
> 2021-12-13T02:25:17.0962057Z Dec 13 02:25:17 E                   	at java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:1975)
> 2021-12-13T02:25:17.0962745Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.concurrent.akka.AkkaFutureUtils$1.onComplete(AkkaFutureUtils.java:47)
> 2021-12-13T02:25:17.0963385Z Dec 13 02:25:17 E                   	at akka.dispatch.OnComplete.internal(Future.scala:300)
> 2021-12-13T02:25:17.0963953Z Dec 13 02:25:17 E                   	at akka.dispatch.OnComplete.internal(Future.scala:297)
> 2021-12-13T02:25:17.0964529Z Dec 13 02:25:17 E                   	at akka.dispatch.japi$CallbackBridge.apply(Future.scala:224)
> 2021-12-13T02:25:17.0965092Z Dec 13 02:25:17 E                   	at akka.dispatch.japi$CallbackBridge.apply(Future.scala:221)
> 2021-12-13T02:25:17.0965783Z Dec 13 02:25:17 E                   	at scala.concurrent.impl.CallbackRunnable.run(Promise.scala:60)
> 2021-12-13T02:25:17.0966981Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.concurrent.akka.AkkaFutureUtils$DirectExecutionContext.execute(AkkaFutureUtils.java:65)
> 2021-12-13T02:25:17.0967839Z Dec 13 02:25:17 E                   	at scala.concurrent.impl.CallbackRunnable.executeWithValue(Promise.scala:68)
> 2021-12-13T02:25:17.0968667Z Dec 13 02:25:17 E                   	at scala.concurrent.impl.Promise$DefaultPromise.$anonfun$tryComplete$1(Promise.scala:284)
> 2021-12-13T02:25:17.0969372Z Dec 13 02:25:17 E                   	at scala.concurrent.impl.Promise$DefaultPromise.$anonfun$tryComplete$1$adapted(Promise.scala:284)
> 2021-12-13T02:25:17.0970092Z Dec 13 02:25:17 E                   	at scala.concurrent.impl.Promise$DefaultPromise.tryComplete(Promise.scala:284)
> 2021-12-13T02:25:17.0970725Z Dec 13 02:25:17 E                   	at akka.pattern.PromiseActorRef.$bang(AskSupport.scala:621)
> 2021-12-13T02:25:17.0971571Z Dec 13 02:25:17 E                   	at akka.pattern.PipeToSupport$PipeableFuture$$anonfun$pipeTo$1.applyOrElse(PipeToSupport.scala:24)
> 2021-12-13T02:25:17.0972299Z Dec 13 02:25:17 E                   	at akka.pattern.PipeToSupport$PipeableFuture$$anonfun$pipeTo$1.applyOrElse(PipeToSupport.scala:23)
> 2021-12-13T02:25:17.0972960Z Dec 13 02:25:17 E                   	at scala.concurrent.Future.$anonfun$andThen$1(Future.scala:532)
> 2021-12-13T02:25:17.0973539Z Dec 13 02:25:17 E                   	at scala.concurrent.impl.Promise.liftedTree1$1(Promise.scala:29)
> 2021-12-13T02:25:17.0974153Z Dec 13 02:25:17 E                   	at scala.concurrent.impl.Promise.$anonfun$transform$1(Promise.scala:29)
> 2021-12-13T02:25:17.0974894Z Dec 13 02:25:17 E                   	at scala.concurrent.impl.CallbackRunnable.run(Promise.scala:60)
> 2021-12-13T02:25:17.0975538Z Dec 13 02:25:17 E                   	at akka.dispatch.BatchingExecutor$AbstractBatch.processBatch(BatchingExecutor.scala:63)
> 2021-12-13T02:25:17.0976226Z Dec 13 02:25:17 E                   	at akka.dispatch.BatchingExecutor$BlockableBatch.$anonfun$run$1(BatchingExecutor.scala:100)
> 2021-12-13T02:25:17.0976890Z Dec 13 02:25:17 E                   	at scala.runtime.java8.JFunction0$mcV$sp.apply(JFunction0$mcV$sp.java:12)
> 2021-12-13T02:25:17.0977517Z Dec 13 02:25:17 E                   	at scala.concurrent.BlockContext$.withBlockContext(BlockContext.scala:81)
> 2021-12-13T02:25:17.0978328Z Dec 13 02:25:17 E                   	at akka.dispatch.BatchingExecutor$BlockableBatch.run(BatchingExecutor.scala:100)
> 2021-12-13T02:25:17.0978966Z Dec 13 02:25:17 E                   	at akka.dispatch.TaskInvocation.run(AbstractDispatcher.scala:49)
> 2021-12-13T02:25:17.0979629Z Dec 13 02:25:17 E                   	at akka.dispatch.ForkJoinExecutorConfigurator$AkkaForkJoinTask.exec(ForkJoinExecutorConfigurator.scala:48)
> 2021-12-13T02:25:17.0980303Z Dec 13 02:25:17 E                   	at java.util.concurrent.ForkJoinTask.doExec(ForkJoinTask.java:289)
> 2021-12-13T02:25:17.0980930Z Dec 13 02:25:17 E                   	at java.util.concurrent.ForkJoinPool$WorkQueue.runTask(ForkJoinPool.java:1056)
> 2021-12-13T02:25:17.0981634Z Dec 13 02:25:17 E                   	at java.util.concurrent.ForkJoinPool.runWorker(ForkJoinPool.java:1692)
> 2021-12-13T02:25:17.0982267Z Dec 13 02:25:17 E                   	at java.util.concurrent.ForkJoinWorkerThread.run(ForkJoinWorkerThread.java:175)
> 2021-12-13T02:25:17.0982938Z Dec 13 02:25:17 E                   Caused by: org.apache.flink.runtime.JobException: Recovery is suppressed by NoRestartBackoffTimeStrategy
> 2021-12-13T02:25:17.0983705Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.handleFailure(ExecutionFailureHandler.java:138)
> 2021-12-13T02:25:17.0984560Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.getFailureHandlingResult(ExecutionFailureHandler.java:82)
> 2021-12-13T02:25:17.0985362Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.scheduler.DefaultScheduler.handleTaskFailure(DefaultScheduler.java:252)
> 2021-12-13T02:25:17.0986176Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.scheduler.DefaultScheduler.maybeHandleTaskFailure(DefaultScheduler.java:242)
> 2021-12-13T02:25:17.0986940Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.scheduler.DefaultScheduler.updateTaskExecutionStateInternal(DefaultScheduler.java:233)
> 2021-12-13T02:25:17.0987690Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.scheduler.SchedulerBase.updateTaskExecutionState(SchedulerBase.java:684)
> 2021-12-13T02:25:17.0988544Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.scheduler.SchedulerNG.updateTaskExecutionState(SchedulerNG.java:79)
> 2021-12-13T02:25:17.0989257Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.jobmaster.JobMaster.updateTaskExecutionState(JobMaster.java:444)
> 2021-12-13T02:25:17.0989869Z Dec 13 02:25:17 E                   	at sun.reflect.GeneratedMethodAccessor32.invoke(Unknown Source)
> 2021-12-13T02:25:17.0990476Z Dec 13 02:25:17 E                   	at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
> 2021-12-13T02:25:17.0991160Z Dec 13 02:25:17 E                   	at java.lang.reflect.Method.invoke(Method.java:498)
> 2021-12-13T02:25:17.0991810Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.lambda$handleRpcInvocation$1(AkkaRpcActor.java:316)
> 2021-12-13T02:25:17.0992548Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.concurrent.akka.ClassLoadingUtils.runWithContextClassLoader(ClassLoadingUtils.java:83)
> 2021-12-13T02:25:17.0993369Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcInvocation(AkkaRpcActor.java:314)
> 2021-12-13T02:25:17.0994063Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcMessage(AkkaRpcActor.java:217)
> 2021-12-13T02:25:17.0994782Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor.handleRpcMessage(FencedAkkaRpcActor.java:78)
> 2021-12-13T02:25:17.0995498Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleMessage(AkkaRpcActor.java:163)
> 2021-12-13T02:25:17.0996134Z Dec 13 02:25:17 E                   	at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:24)
> 2021-12-13T02:25:17.0996728Z Dec 13 02:25:17 E                   	at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:20)
> 2021-12-13T02:25:17.0997323Z Dec 13 02:25:17 E                   	at scala.PartialFunction.applyOrElse(PartialFunction.scala:123)
> 2021-12-13T02:25:17.0997922Z Dec 13 02:25:17 E                   	at scala.PartialFunction.applyOrElse$(PartialFunction.scala:122)
> 2021-12-13T02:25:17.0998648Z Dec 13 02:25:17 E                   	at akka.japi.pf.UnitCaseStatement.applyOrElse(CaseStatements.scala:20)
> 2021-12-13T02:25:17.0999267Z Dec 13 02:25:17 E                   	at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:171)
> 2021-12-13T02:25:17.0999884Z Dec 13 02:25:17 E                   	at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:172)
> 2021-12-13T02:25:17.1000502Z Dec 13 02:25:17 E                   	at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:172)
> 2021-12-13T02:25:17.1001186Z Dec 13 02:25:17 E                   	at akka.actor.Actor.aroundReceive(Actor.scala:537)
> 2021-12-13T02:25:17.1001737Z Dec 13 02:25:17 E                   	at akka.actor.Actor.aroundReceive$(Actor.scala:535)
> 2021-12-13T02:25:17.1002318Z Dec 13 02:25:17 E                   	at akka.actor.AbstractActor.aroundReceive(AbstractActor.scala:220)
> 2021-12-13T02:25:17.1002914Z Dec 13 02:25:17 E                   	at akka.actor.ActorCell.receiveMessage(ActorCell.scala:580)
> 2021-12-13T02:25:17.1003468Z Dec 13 02:25:17 E                   	at akka.actor.ActorCell.invoke(ActorCell.scala:548)
> 2021-12-13T02:25:17.1004032Z Dec 13 02:25:17 E                   	at akka.dispatch.Mailbox.processMailbox(Mailbox.scala:270)
> 2021-12-13T02:25:17.1004770Z Dec 13 02:25:17 E                   	at akka.dispatch.Mailbox.run(Mailbox.scala:231)
> 2021-12-13T02:25:17.1005426Z Dec 13 02:25:17 E                   	at akka.dispatch.Mailbox.exec(Mailbox.scala:243)
> 2021-12-13T02:25:17.1005900Z Dec 13 02:25:17 E                   	... 4 more
> 2021-12-13T02:25:17.1006435Z Dec 13 02:25:17 E                   Caused by: java.lang.RuntimeException: Error while waiting for BeamPythonFunctionRunner flush
> 2021-12-13T02:25:17.1007254Z Dec 13 02:25:17 E                   	at org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator.invokeFinishBundle(AbstractPythonFunctionOperator.java:361)
> 2021-12-13T02:25:17.1008300Z Dec 13 02:25:17 E                   	at org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator.processWatermark(AbstractPythonFunctionOperator.java:222)
> 2021-12-13T02:25:17.1009150Z Dec 13 02:25:17 E                   	at org.apache.flink.streaming.api.operators.python.PythonProcessOperator.processWatermark(PythonProcessOperator.java:104)
> 2021-12-13T02:25:17.1010004Z Dec 13 02:25:17 E                   	at org.apache.flink.streaming.runtime.tasks.OneInputStreamTask$StreamTaskNetworkOutput.emitWatermark(OneInputStreamTask.java:239)
> 2021-12-13T02:25:17.1010906Z Dec 13 02:25:17 E                   	at org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.findAndOutputNewMinWatermarkAcrossAlignedChannels(StatusWatermarkValve.java:200)
> 2021-12-13T02:25:17.1011881Z Dec 13 02:25:17 E                   	at org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.inputWatermark(StatusWatermarkValve.java:105)
> 2021-12-13T02:25:17.1012809Z Dec 13 02:25:17 E                   	at org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput.processElement(AbstractStreamTaskNetworkInput.java:136)
> 2021-12-13T02:25:17.1013645Z Dec 13 02:25:17 E                   	at org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput.emitNext(AbstractStreamTaskNetworkInput.java:105)
> 2021-12-13T02:25:17.1014454Z Dec 13 02:25:17 E                   	at org.apache.flink.streaming.runtime.io.StreamOneInputProcessor.processInput(StreamOneInputProcessor.java:65)
> 2021-12-13T02:25:17.1015210Z Dec 13 02:25:17 E                   	at org.apache.flink.streaming.runtime.tasks.StreamTask.processInput(StreamTask.java:496)
> 2021-12-13T02:25:17.1015953Z Dec 13 02:25:17 E                   	at org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMailboxLoop(MailboxProcessor.java:203)
> 2021-12-13T02:25:17.1016812Z Dec 13 02:25:17 E                   	at org.apache.flink.streaming.runtime.tasks.StreamTask.runMailboxLoop(StreamTask.java:809)
> 2021-12-13T02:25:17.1017496Z Dec 13 02:25:17 E                   	at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:761)
> 2021-12-13T02:25:17.1018310Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.taskmanager.Task.runWithSystemExitMonitoring(Task.java:958)
> 2021-12-13T02:25:17.1019030Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.taskmanager.Task.restoreAndInvoke(Task.java:937)
> 2021-12-13T02:25:17.1019655Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:766)
> 2021-12-13T02:25:17.1020246Z Dec 13 02:25:17 E                   	at org.apache.flink.runtime.taskmanager.Task.run(Task.java:575)
> 2021-12-13T02:25:17.1020809Z Dec 13 02:25:17 E                   	at java.lang.Thread.run(Thread.java:748)
> 2021-12-13T02:25:17.1021413Z Dec 13 02:25:17 E                   Caused by: java.lang.RuntimeException: Failed to close remote bundle
> 2021-12-13T02:25:17.1022119Z Dec 13 02:25:17 E                   	at org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner.finishBundle(BeamPythonFunctionRunner.java:377)
> 2021-12-13T02:25:17.1022913Z Dec 13 02:25:17 E                   	at org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner.flush(BeamPythonFunctionRunner.java:361)
> 2021-12-13T02:25:17.1023754Z Dec 13 02:25:17 E                   	at org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator.lambda$invokeFinishBundle$2(AbstractPythonFunctionOperator.java:340)
> 2021-12-13T02:25:17.1024611Z Dec 13 02:25:17 E                   	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
> 2021-12-13T02:25:17.1025210Z Dec 13 02:25:17 E                   	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
> 2021-12-13T02:25:17.1025827Z Dec 13 02:25:17 E                   	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
> 2021-12-13T02:25:17.1026462Z Dec 13 02:25:17 E                   	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
> 2021-12-13T02:25:17.1026982Z Dec 13 02:25:17 E                   	... 1 more
> 2021-12-13T02:25:17.1027656Z Dec 13 02:25:17 E                   Caused by: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction 1: Traceback (most recent call last):
> 2021-12-13T02:25:17.1029249Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 289, in _execute
> 2021-12-13T02:25:17.1029844Z Dec 13 02:25:17 E                       response = task()
> 2021-12-13T02:25:17.1030674Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 362, in <lambda>
> 2021-12-13T02:25:17.1031384Z Dec 13 02:25:17 E                       lambda: self.create_worker().do_instruction(request), request)
> 2021-12-13T02:25:17.1032404Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 607, in do_instruction
> 2021-12-13T02:25:17.1033046Z Dec 13 02:25:17 E                       getattr(request, request_type), request.instruction_id)
> 2021-12-13T02:25:17.1033923Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 644, in process_bundle
> 2021-12-13T02:25:17.1034563Z Dec 13 02:25:17 E                       bundle_processor.process_bundle(instruction_id))
> 2021-12-13T02:25:17.1035445Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1000, in process_bundle
> 2021-12-13T02:25:17.1036033Z Dec 13 02:25:17 E                       element.data)
> 2021-12-13T02:25:17.1036863Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 228, in process_encoded
> 2021-12-13T02:25:17.1037451Z Dec 13 02:25:17 E                       self.output(decoded_value)
> 2021-12-13T02:25:17.1038003Z Dec 13 02:25:17 E                     File "apache_beam/runners/worker/operations.py", line 357, in apache_beam.runners.worker.operations.Operation.output
> 2021-12-13T02:25:17.1038848Z Dec 13 02:25:17 E                     File "apache_beam/runners/worker/operations.py", line 359, in apache_beam.runners.worker.operations.Operation.output
> 2021-12-13T02:25:17.1039542Z Dec 13 02:25:17 E                     File "apache_beam/runners/worker/operations.py", line 221, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
> 2021-12-13T02:25:17.1040229Z Dec 13 02:25:17 E                     File "apache_beam/runners/worker/operations.py", line 319, in apache_beam.runners.worker.operations.Operation.process
> 2021-12-13T02:25:17.1041187Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/pyflink/fn_execution/beam/beam_operations_slow.py", line 132, in process
> 2021-12-13T02:25:17.1041793Z Dec 13 02:25:17 E                       self._output_processor.process_outputs(o, self.process_element(value))
> 2021-12-13T02:25:17.1042611Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/pyflink/fn_execution/beam/beam_operations_slow.py", line 63, in process_outputs
> 2021-12-13T02:25:17.1043330Z Dec 13 02:25:17 E                       self._consumer.process(windowed_value.with_value(results))
> 2021-12-13T02:25:17.1044122Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/pyflink/fn_execution/beam/beam_operations_slow.py", line 131, in process
> 2021-12-13T02:25:17.1044657Z Dec 13 02:25:17 E                       for value in o.value:
> 2021-12-13T02:25:17.1045416Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/pyflink/fn_execution/datastream/operations.py", line 179, in wrapped_func
> 2021-12-13T02:25:17.1046002Z Dec 13 02:25:17 E                       yield from _emit_results(timestamp, watermark, results)
> 2021-12-13T02:25:17.1046792Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/pyflink/fn_execution/datastream/input_handler.py", line 101, in _emit_results
> 2021-12-13T02:25:17.1047351Z Dec 13 02:25:17 E                       for result in results:
> 2021-12-13T02:25:17.1048215Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/pyflink/datastream/data_stream.py", line 271, in process_element
> 2021-12-13T02:25:17.1048808Z Dec 13 02:25:17 E                       yield self._map_func(value)
> 2021-12-13T02:25:17.1049619Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/pyflink/datastream/tests/test_stream_execution_environment.py", line 541, in check_python_exec
> 2021-12-13T02:25:17.1050206Z Dec 13 02:25:17 E                       assert os.environ["python"] == python_exec_link_path
> 2021-12-13T02:25:17.1050911Z Dec 13 02:25:17 E                   AssertionError: assert 'python' == '/tmp/tmp1mas4ii5/py_exec'
> 2021-12-13T02:25:17.1051732Z Dec 13 02:25:17 E                     - /tmp/tmp1mas4ii5/py_exec
> 2021-12-13T02:25:17.1052146Z Dec 13 02:25:17 E                     + python
> 2021-12-13T02:25:17.1052510Z Dec 13 02:25:17 E                   
> 2021-12-13T02:25:17.1053005Z Dec 13 02:25:17 E                   	at java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
> 2021-12-13T02:25:17.1053659Z Dec 13 02:25:17 E                   	at java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1908)
> 2021-12-13T02:25:17.1054257Z Dec 13 02:25:17 E                   	at org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
> 2021-12-13T02:25:17.1054970Z Dec 13 02:25:17 E                   	at org.apache.beam.runners.fnexecution.control.SdkHarnessClient$BundleProcessor$ActiveBundle.close(SdkHarnessClient.java:504)
> 2021-12-13T02:25:17.1055806Z Dec 13 02:25:17 E                   	at org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$SimpleStageBundleFactory$1.close(DefaultJobBundleFactory.java:555)
> 2021-12-13T02:25:17.1056648Z Dec 13 02:25:17 E                   	at org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner.finishBundle(BeamPythonFunctionRunner.java:375)
> 2021-12-13T02:25:17.1057241Z Dec 13 02:25:17 E                   	... 7 more
> 2021-12-13T02:25:17.1057839Z Dec 13 02:25:17 E                   Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction 1: Traceback (most recent call last):
> 2021-12-13T02:25:17.1059051Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 289, in _execute
> 2021-12-13T02:25:17.1059629Z Dec 13 02:25:17 E                       response = task()
> 2021-12-13T02:25:17.1060435Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 362, in <lambda>
> 2021-12-13T02:25:17.1061175Z Dec 13 02:25:17 E                       lambda: self.create_worker().do_instruction(request), request)
> 2021-12-13T02:25:17.1062217Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 607, in do_instruction
> 2021-12-13T02:25:17.1062851Z Dec 13 02:25:17 E                       getattr(request, request_type), request.instruction_id)
> 2021-12-13T02:25:17.1063842Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 644, in process_bundle
> 2021-12-13T02:25:17.1064466Z Dec 13 02:25:17 E                       bundle_processor.process_bundle(instruction_id))
> 2021-12-13T02:25:17.1065345Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 1000, in process_bundle
> 2021-12-13T02:25:17.1065925Z Dec 13 02:25:17 E                       element.data)
> 2021-12-13T02:25:17.1066750Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/.tox/py37-cython/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 228, in process_encoded
> 2021-12-13T02:25:17.1067358Z Dec 13 02:25:17 E                       self.output(decoded_value)
> 2021-12-13T02:25:17.1067912Z Dec 13 02:25:17 E                     File "apache_beam/runners/worker/operations.py", line 357, in apache_beam.runners.worker.operations.Operation.output
> 2021-12-13T02:25:17.1068748Z Dec 13 02:25:17 E                     File "apache_beam/runners/worker/operations.py", line 359, in apache_beam.runners.worker.operations.Operation.output
> 2021-12-13T02:25:17.1069441Z Dec 13 02:25:17 E                     File "apache_beam/runners/worker/operations.py", line 221, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
> 2021-12-13T02:25:17.1070226Z Dec 13 02:25:17 E                     File "apache_beam/runners/worker/operations.py", line 319, in apache_beam.runners.worker.operations.Operation.process
> 2021-12-13T02:25:17.1071169Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/pyflink/fn_execution/beam/beam_operations_slow.py", line 132, in process
> 2021-12-13T02:25:17.1071779Z Dec 13 02:25:17 E                       self._output_processor.process_outputs(o, self.process_element(value))
> 2021-12-13T02:25:17.1072601Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/pyflink/fn_execution/beam/beam_operations_slow.py", line 63, in process_outputs
> 2021-12-13T02:25:17.1073175Z Dec 13 02:25:17 E                       self._consumer.process(windowed_value.with_value(results))
> 2021-12-13T02:25:17.1073958Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/pyflink/fn_execution/beam/beam_operations_slow.py", line 131, in process
> 2021-12-13T02:25:17.1074508Z Dec 13 02:25:17 E                       for value in o.value:
> 2021-12-13T02:25:17.1075271Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/pyflink/fn_execution/datastream/operations.py", line 179, in wrapped_func
> 2021-12-13T02:25:17.1075850Z Dec 13 02:25:17 E                       yield from _emit_results(timestamp, watermark, results)
> 2021-12-13T02:25:17.1076635Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/pyflink/fn_execution/datastream/input_handler.py", line 101, in _emit_results
> 2021-12-13T02:25:17.1077195Z Dec 13 02:25:17 E                       for result in results:
> 2021-12-13T02:25:17.1077928Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/pyflink/datastream/data_stream.py", line 271, in process_element
> 2021-12-13T02:25:17.1078658Z Dec 13 02:25:17 E                       yield self._map_func(value)
> 2021-12-13T02:25:17.1079464Z Dec 13 02:25:17 E                     File "/__w/1/s/flink-python/pyflink/datastream/tests/test_stream_execution_environment.py", line 541, in check_python_exec
> 2021-12-13T02:25:17.1080069Z Dec 13 02:25:17 E                       assert os.environ["python"] == python_exec_link_path
> 2021-12-13T02:25:17.1080770Z Dec 13 02:25:17 E                   AssertionError: assert 'python' == '/tmp/tmp1mas4ii5/py_exec'
> 2021-12-13T02:25:17.1081471Z Dec 13 02:25:17 E                     - /tmp/tmp1mas4ii5/py_exec
> 2021-12-13T02:25:17.1081878Z Dec 13 02:25:17 E                     + python
> 2021-12-13T02:25:17.1082234Z Dec 13 02:25:17 E                   
> 2021-12-13T02:25:17.1082893Z Dec 13 02:25:17 E                   	at org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
> 2021-12-13T02:25:17.1083710Z Dec 13 02:25:17 E                   	at org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
> 2021-12-13T02:25:17.1084561Z Dec 13 02:25:17 E                   	at org.apache.beam.vendor.grpc.v1p26p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:251)
> 2021-12-13T02:25:17.1085416Z Dec 13 02:25:17 E                   	at org.apache.beam.vendor.grpc.v1p26p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
> 2021-12-13T02:25:17.1086210Z Dec 13 02:25:17 E                   	at org.apache.beam.vendor.grpc.v1p26p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
> 2021-12-13T02:25:17.1087049Z Dec 13 02:25:17 E                   	at org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
> 2021-12-13T02:25:17.1087941Z Dec 13 02:25:17 E                   	at org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
> 2021-12-13T02:25:17.1089000Z Dec 13 02:25:17 E                   	at org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:782)
> 2021-12-13T02:25:17.1089933Z Dec 13 02:25:17 E                   	at org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
> 2021-12-13T02:25:17.1090672Z Dec 13 02:25:17 E                   	at org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
> 2021-12-13T02:25:17.1091321Z Dec 13 02:25:17 E                   	... 3 more
>  {code}
> https://dev.azure.com/apache-flink/apache-flink/_build/results?buildId=28010&view=logs&j=bdd9ea51-4de2-506a-d4d9-f3930e4d2355&t=dd50312f-73b5-56b5-c172-4d81d03e2ef1&l=24236



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