You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hudi.apache.org by GitBox <gi...@apache.org> on 2022/07/01 11:09:46 UTC

[GitHub] [hudi] todd5167 opened a new issue, #6021: [SUPPORT] flink write rollback error, [Cannot use marker based rollback strategy on completed instant ]

todd5167 opened a new issue, #6021:
URL: https://github.com/apache/hudi/issues/6021

   flink version: flink1.13
   hudi-version: 0.10.0-patch
   
   
   The flink job has been running normally for over 20 days. Has the bug been fixed? @danny0405 
   
   ```
   2022-07-01 17:16:41
   org.apache.flink.util.FlinkException: Global failure triggered by OperatorCoordinator for 'hoodie_stream_write' (operator b7de72b1341e9865ca451f91c490f715).
   	at org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder$LazyInitializedCoordinatorContext.failJob(OperatorCoordinatorHolder.java:553)
   	at org.apache.hudi.sink.StreamWriteOperatorCoordinator.lambda$start$0(StreamWriteOperatorCoordinator.java:170)
   	at org.apache.hudi.sink.utils.NonThrownExecutor.lambda$execute$0(NonThrownExecutor.java:103)
   	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
   	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   	at java.lang.Thread.run(Thread.java:748)
   Caused by: org.apache.hudi.exception.HoodieException: Executor executes action [initialize instant ] error
   	... 5 more
   Caused by: org.apache.hudi.exception.HoodieRollbackException: Failed to rollback s3://sprs-common-data-sg1/hudi/dim_ads_midas_t_sku_info_v3/ commits 20220629155013313
   	at org.apache.hudi.client.AbstractHoodieWriteClient.rollback(AbstractHoodieWriteClient.java:660)
   	at org.apache.hudi.client.AbstractHoodieWriteClient.rollbackFailedWrites(AbstractHoodieWriteClient.java:952)
   	at org.apache.hudi.client.AbstractHoodieWriteClient.rollbackFailedWrites(AbstractHoodieWriteClient.java:935)
   	at org.apache.hudi.client.AbstractHoodieWriteClient.rollbackFailedWrites(AbstractHoodieWriteClient.java:923)
   	at org.apache.hudi.client.AbstractHoodieWriteClient.lambda$startCommitWithTime$97cdbdca$1(AbstractHoodieWriteClient.java:815)
   	at org.apache.hudi.common.util.CleanerUtils.rollbackFailedWrites(CleanerUtils.java:143)
   	at org.apache.hudi.client.AbstractHoodieWriteClient.startCommitWithTime(AbstractHoodieWriteClient.java:814)
   	at org.apache.hudi.client.AbstractHoodieWriteClient.startCommitWithTime(AbstractHoodieWriteClient.java:807)
   	at org.apache.hudi.sink.StreamWriteOperatorCoordinator.startInstant(StreamWriteOperatorCoordinator.java:348)
   	at org.apache.hudi.sink.StreamWriteOperatorCoordinator.lambda$initInstant$5(StreamWriteOperatorCoordinator.java:375)
   	at org.apache.hudi.sink.utils.NonThrownExecutor.lambda$execute$0(NonThrownExecutor.java:93)
   	... 3 more
   Caused by: java.lang.IllegalArgumentException: Cannot use marker based rollback strategy on completed instant:[20220629155013313__commit__COMPLETED]
   	at org.apache.hudi.common.util.ValidationUtils.checkArgument(ValidationUtils.java:40)
   	at org.apache.hudi.table.action.rollback.BaseRollbackActionExecutor.<init>(BaseRollbackActionExecutor.java:90)
   	at org.apache.hudi.table.action.rollback.BaseRollbackActionExecutor.<init>(BaseRollbackActionExecutor.java:71)
   	at org.apache.hudi.table.action.rollback.MergeOnReadRollbackActionExecutor.<init>(MergeOnReadRollbackActionExecutor.java:48)
   	at org.apache.hudi.table.HoodieFlinkMergeOnReadTable.rollback(HoodieFlinkMergeOnReadTable.java:131)
   	at org.apache.hudi.client.AbstractHoodieWriteClient.rollback(AbstractHoodieWriteClient.java:645)
   	... 13 more
   ```


-- 
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.apache.org

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


[GitHub] [hudi] zhmingyong commented on issue #6021: [SUPPORT] flink write rollback error, [Cannot use marker based rollback strategy on completed instant ]

Posted by "zhmingyong (via GitHub)" <gi...@apache.org>.
zhmingyong commented on issue #6021:
URL: https://github.com/apache/hudi/issues/6021#issuecomment-1415184506

   Well, thanks for the advice. I'll try it.


-- 
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


[GitHub] [hudi] zhmingyong commented on issue #6021: [SUPPORT] flink write rollback error, [Cannot use marker based rollback strategy on completed instant ]

Posted by "zhmingyong (via GitHub)" <gi...@apache.org>.
zhmingyong commented on issue #6021:
URL: https://github.com/apache/hudi/issues/6021#issuecomment-1413075020

   How did you solve the problem, I also encountered the same problem.


-- 
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


[GitHub] [hudi] danny0405 commented on issue #6021: [SUPPORT] flink write rollback error, [Cannot use marker based rollback strategy on completed instant ]

Posted by "danny0405 (via GitHub)" <gi...@apache.org>.
danny0405 commented on issue #6021:
URL: https://github.com/apache/hudi/issues/6021#issuecomment-1415169580

   You may need to try to delete the rollback metadata file under the .hoodie folder manually.


-- 
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


[GitHub] [hudi] danny0405 commented on issue #6021: [SUPPORT] flink write rollback error, [Cannot use marker based rollback strategy on completed instant ]

Posted by "danny0405 (via GitHub)" <gi...@apache.org>.
danny0405 commented on issue #6021:
URL: https://github.com/apache/hudi/issues/6021#issuecomment-1415178346

   Try to upgrade to new version of Hudi.


-- 
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


[GitHub] [hudi] zhmingyong commented on issue #6021: [SUPPORT] flink write rollback error, [Cannot use marker based rollback strategy on completed instant ]

Posted by "zhmingyong (via GitHub)" <gi...@apache.org>.
zhmingyong commented on issue #6021:
URL: https://github.com/apache/hudi/issues/6021#issuecomment-1415165399

   > What version do you use, it is kind of a known bug for release 0.11.0.
   
   My version is 0.10.1.


-- 
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


[GitHub] [hudi] todd5167 closed issue #6021: [SUPPORT] flink write rollback error, [Cannot use marker based rollback strategy on completed instant ]

Posted by GitBox <gi...@apache.org>.
todd5167 closed issue #6021: [SUPPORT] flink write rollback error, [Cannot use marker based rollback strategy on completed instant ]
URL: https://github.com/apache/hudi/issues/6021


-- 
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


[GitHub] [hudi] zhmingyong commented on issue #6021: [SUPPORT] flink write rollback error, [Cannot use marker based rollback strategy on completed instant ]

Posted by "zhmingyong (via GitHub)" <gi...@apache.org>.
zhmingyong commented on issue #6021:
URL: https://github.com/apache/hudi/issues/6021#issuecomment-1413075646

   > How did you solve the problem, I also encountered the same problem.
   
   Caused by: java.lang.IllegalArgumentException: Cannot use marker based rollback strategy on completed instant:[20230103022823207__commit__COMPLETED]
   at org.apache.hudi.common.util.ValidationUtils.checkArgument(ValidationUtils.java:40)
   at org.apache.hudi.table.action.rollback.BaseRollbackActionExecutor.<init>(BaseRollbackActionExecutor.java:90)
   at org.apache.hudi.table.action.rollback.BaseRollbackActionExecutor.<init>(BaseRollbackActionExecutor.java:71)
   at org.apache.hudi.table.action.rollback.CopyOnWriteRollbackActionExecutor.<init>(CopyOnWriteRollbackActionExecutor.java:48)
   at org.apache.hudi.table.HoodieSparkCopyOnWriteTable.rollback(HoodieSparkCopyOnWriteTable.java:343)
   at org.apache.hudi.client.AbstractHoodieWriteClient.rollback(AbstractHoodieWriteClient.java:640)


-- 
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


[GitHub] [hudi] danny0405 commented on issue #6021: [SUPPORT] flink write rollback error, [Cannot use marker based rollback strategy on completed instant ]

Posted by "danny0405 (via GitHub)" <gi...@apache.org>.
danny0405 commented on issue #6021:
URL: https://github.com/apache/hudi/issues/6021#issuecomment-1415158560

   What version do you use, it is kind of a known bug for release 0.11.0.


-- 
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


[GitHub] [hudi] zhmingyong commented on issue #6021: [SUPPORT] flink write rollback error, [Cannot use marker based rollback strategy on completed instant ]

Posted by "zhmingyong (via GitHub)" <gi...@apache.org>.
zhmingyong commented on issue #6021:
URL: https://github.com/apache/hudi/issues/6021#issuecomment-1415175133

   Well, at the moment I've done it this way, but there may be a future. Is there a solution?


-- 
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