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/13 06:33:33 UTC

[GitHub] [hudi] todd5167 opened a new issue, #6094: [SUPPORT] hudi rollback throw java.lang.IllegalArgumentException

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

   1.  hudi version: 0.10.0-patch
   2. flink write hudi config:
   ```
    'connector' = 'hudi',
     'path' = 's3://xxx/hudi/xxx/',
     'table.type' = 'MERGE_ON_READ',
     'write.bucket_assign.tasks' = '4',
     'write.tasks' = '4',
     'write.index_bootstrap.tasks' = '4',
     'index.bootstrap.enabled' = 'true',
     'index.global.enabled' = 'true',
     'changelog.enabled' = 'false',
     'hoodie.cleaner.policy' = 'KEEP_LATEST_FILE_VERSIONS',
     'hoodie.cleaner.fileversions.retained' = '2',
     'write.task.max.size' = '1024',
     'compaction.tasks' = '4',
     'compaction.max_memory' = '1024',
     'hoodie.compact.inline.trigger.strategy' = 'NUM_OR_TIME',
     'hoodie.compact.inline.max.delta.commits' = '10',
     'hoodie.compact.inline.max.delta.seconds' = '1800',
   ```
   
   
   error log: 
   ```
   java.lang.IllegalArgumentException
   	at org.apache.hudi.common.util.ValidationUtils.checkArgument(ValidationUtils.java:31)
   	at org.apache.hudi.common.table.timeline.HoodieActiveTimeline.transitionState(HoodieActiveTimeline.java:476)
   	at org.apache.hudi.common.table.timeline.HoodieActiveTimeline.transitionState(HoodieActiveTimeline.java:457)
   	at org.apache.hudi.common.table.timeline.HoodieActiveTimeline.transitionRollbackInflightToComplete(HoodieActiveTimeline.java:385)
   	at org.apache.hudi.table.action.rollback.BaseRollbackActionExecutor.finishRollback(BaseRollbackActionExecutor.java:262)
   	at org.apache.hudi.table.action.rollback.BaseRollbackActionExecutor.runRollback(BaseRollbackActionExecutor.java:127)
   	at org.apache.hudi.table.action.rollback.BaseRollbackActionExecutor.execute(BaseRollbackActionExecutor.java:158)
   	at org.apache.hudi.table.HoodieFlinkMergeOnReadTable.rollback(HoodieFlinkMergeOnReadTable.java:132)
   	at org.apache.hudi.table.HoodieTable.rollbackInflightCompaction(HoodieTable.java:499)
   	at org.apache.hudi.util.CompactionUtil.rollbackCompaction(CompactionUtil.java:147)
   	at org.apache.hudi.sink.compact.CompactionCommitSink.invoke(CompactionCommitSink.java:95)
   	at org.apache.hudi.sink.compact.CompactionCommitSink.invoke(CompactionCommitSink.java:53)
   	at org.apache.flink.streaming.api.operators.StreamSink.processElement(StreamSink.java:54)
   	at org.apache.flink.streaming.runtime.tasks.OneInputStreamTask$StreamTaskNetworkOutput.emitRecord(OneInputStreamTask.java:215)
   	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:748)
   ```


-- 
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] todd5167 closed issue #6094: [SUPPORT] hudi rollback throw java.lang.IllegalArgumentException

Posted by GitBox <gi...@apache.org>.
todd5167 closed issue #6094: [SUPPORT] hudi rollback throw java.lang.IllegalArgumentException 
URL: https://github.com/apache/hudi/issues/6094


-- 
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] nsivabalan commented on issue #6094: [SUPPORT] hudi rollback throw java.lang.IllegalArgumentException

Posted by GitBox <gi...@apache.org>.
nsivabalan commented on issue #6094:
URL: https://github.com/apache/hudi/issues/6094#issuecomment-1216268826

   hey @todd5167 : if there are no follow up, can we close this one out. 


-- 
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 commented on issue #6094: [SUPPORT] hudi rollback throw java.lang.IllegalArgumentException

Posted by GitBox <gi...@apache.org>.
todd5167 commented on issue #6094:
URL: https://github.com/apache/hudi/issues/6094#issuecomment-1186709177

   I'll take a look after cherry pick


-- 
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 #6094: [SUPPORT] hudi rollback throw java.lang.IllegalArgumentException

Posted by GitBox <gi...@apache.org>.
danny0405 commented on issue #6094:
URL: https://github.com/apache/hudi/issues/6094#issuecomment-1186706075

   It may be related to this PR: https://github.com/apache/hudi/pull/5357, which has tweaked the compaction rollback strategy.


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