Uploaded image for project: 'Flink'
  1. Flink
  2. FLINK-17363

Asynchronous association dimension table timeout

    XMLWordPrintableJSON

Details

    Description

      java.lang.Exception: An async function call terminated with an exception. Failing the AsyncWaitOperator.
      at org.apache.flink.streaming.api.operators.async.Emitter.output(Emitter.java:137)
      at org.apache.flink.streaming.api.operators.async.Emitter.run(Emitter.java:85)
      at java.lang.Thread.run(Thread.java:748)
      Caused by: java.util.concurrent.ExecutionException: java.util.concurrent.TimeoutException: Async function call has timed out.
      at java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
      at java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
      at org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry.get(StreamRecordQueueEntry.java:68)
      at org.apache.flink.streaming.api.operators.async.Emitter.output(Emitter.java:129)
      ... 2 more
      Caused by: java.util.concurrent.TimeoutException: Async function call has timed out.
      at org.apache.flink.streaming.api.functions.async.AsyncFunction.timeout(AsyncFunction.java:97)
      at org.apache.flink.streaming.api.operators.async.AsyncWaitOperator$1.onProcessingTime(AsyncWaitOperator.java:215)
      at org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService$TriggerTask.run(SystemProcessingTimeService.java:281)
      at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
      at java.util.concurrent.FutureTask.run(FutureTask.java:266)
      at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.access$201(ScheduledThreadPoolExecutor.java:180)
      at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:293)
      at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
      at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
      ... 1 more
      2020-04-24 11:30:22,933 INFO org.apache.flink.runtime.checkpoint.CheckpointCoordinator - Discarding checkpoint 492 of job 075a0b260dd779f28bc87aaa59d7222a.
      java.lang.Exception: An async function call terminated with an exception. Failing the AsyncWaitOperator.
      at org.apache.flink.streaming.api.operators.async.Emitter.output(Emitter.java:137)
      at org.apache.flink.streaming.api.operators.async.Emitter.run(Emitter.java:85)
      at java.lang.Thread.run(Thread.java:748)
      Caused by: java.util.concurrent.ExecutionException: java.util.concurrent.TimeoutException: Async function call has timed out.
      at java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
      at java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
      at org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry.get(StreamRecordQueueEntry.java:68)
      at org.apache.flink.streaming.api.operators.async.Emitter.output(Emitter.java:129)
      ... 2 more
      Caused by: java.util.concurrent.TimeoutException: Async function call has timed out.
      at org.apache.flink.streaming.api.functions.async.AsyncFunction.timeout(AsyncFunction.java:97)
      at org.apache.flink.streaming.api.operators.async.AsyncWaitOperator$1.onProcessingTime(AsyncWaitOperator.java:215)
      at org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService$TriggerTask.run(SystemProcessingTimeService.java:281)
      at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
      at java.util.concurrent.FutureTask.run(FutureTask.java:266)
      at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.access$201(ScheduledThreadPoolExecutor.java:180)
      at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:293)
      at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
      at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
      ... 1 more
      2020-04-24 11:30:22,933 INFO org.apache.flink.runtime.executiongraph.ExecutionGraph - Job sql_details (075a0b260dd779f28bc87aaa59d7222a) switched from state RUNNING to FAILING.
      java.lang.Exception: An async function call terminated with an exception. Failing the AsyncWaitOperator.
      at org.apache.flink.streaming.api.operators.async.Emitter.output(Emitter.java:137)
      at org.apache.flink.streaming.api.operators.async.Emitter.run(Emitter.java:85)
      at java.lang.Thread.run(Thread.java:748)
      Caused by: java.util.concurrent.ExecutionException: java.util.concurrent.TimeoutException: Async function call has timed out.
      at java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
      at java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
      at org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry.get(StreamRecordQueueEntry.java:68)
      at org.apache.flink.streaming.api.operators.async.Emitter.output(Emitter.java:129)
      ... 2 more
      Caused by: java.util.concurrent.TimeoutException: Async function call has timed out.
      at org.apache.flink.streaming.api.functions.async.AsyncFunction.timeout(AsyncFunction.java:97)
      at org.apache.flink.streaming.api.operators.async.AsyncWaitOperator$1.onProcessingTime(AsyncWaitOperator.java:215)
      at org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService$TriggerTask.run(SystemProcessingTimeService.java:281)
      at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
      at java.util.concurrent.FutureTask.run(FutureTask.java:266)
      at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.access$201(ScheduledThreadPoolExecutor.java:180)
      at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:293)
      at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
      at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
      ... 1 more

      Attachments

        Activity

          People

            Unassigned Unassigned
            tets robert
            Votes:
            0 Vote for this issue
            Watchers:
            1 Start watching this issue

            Dates

              Created:
              Updated: