You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hudi.apache.org by "DavidZ1 (via GitHub)" <gi...@apache.org> on 2023/03/01 01:56:11 UTC

[GitHub] [hudi] DavidZ1 commented on issue #8060: [SUPPORT] An instant exception occurs when the flink job is restarted

DavidZ1 commented on issue #8060:
URL: https://github.com/apache/hudi/issues/8060#issuecomment-1449197906

   when i clean the directory  `.hoodie/.aux/ckp_meta/` ,flink job can not recover, error message like this 
   
   `
   2023-03-01 09:53:36
   org.apache.hudi.exception.HoodieException: Timeout(601000ms) while waiting for instant initialize
   	at org.apache.hudi.sink.utils.TimeWait.waitFor(TimeWait.java:57)
   	at org.apache.hudi.sink.common.AbstractStreamWriteFunction.instantToWrite(AbstractStreamWriteFunction.java:276)
   	at org.apache.hudi.sink.StreamWriteFunction.flushBucket(StreamWriteFunction.java:423)
   	at org.apache.hudi.sink.StreamWriteFunction.bufferRecord(StreamWriteFunction.java:398)
   	at org.apache.hudi.sink.bucket.BucketStreamWriteFunction.processElement(BucketStreamWriteFunction.java:130)
   	at org.apache.flink.streaming.api.operators.ProcessOperator.processElement(ProcessOperator.java:66)
   	at org.apache.flink.streaming.runtime.tasks.OneInputStreamTask$StreamTaskNetworkOutput.emitRecord(OneInputStreamTask.java:205)
   	at org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput.processElement(AbstractStreamTaskNetworkInput.java:134)
   	at org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput.emitNext(AbstractStreamTaskNetworkInput.java:105)
   	at org.apache.flink.streaming.runtime.io.StreamOneInputProcessor.processInput(StreamOneInputProcessor.java:66)
   	at org.apache.flink.streaming.runtime.tasks.StreamTask.processInput(StreamTask.java:423)
   	at org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMailboxLoop(MailboxProcessor.java:204)
   	at org.apache.flink.streaming.runtime.tasks.StreamTask.runMailboxLoop(StreamTask.java:684)
   	at org.apache.flink.streaming.runtime.tasks.StreamTask.executeInvoke(StreamTask.java:639)
   	at org.apache.flink.streaming.runtime.tasks.StreamTask.runWithCleanUpOnFail(StreamTask.java:650)
   	at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:623)
   	at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:779)
   	at org.apache.flink.runtime.taskmanager.Task.run(Task.java:566)
   	at java.lang.Thread.run(Thread.java:750)
   
   `


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@hudi.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org