You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hudi.apache.org by "hbgstc123 (via GitHub)" <gi...@apache.org> on 2023/02/21 08:55:57 UTC

[GitHub] [hudi] hbgstc123 opened a new issue, #6478: [SUPPORT]Get KryoException when upgrade from 0.10 to 0.11 in flink

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

   **Describe the problem you faced**
   
   Get KryoException when try to upgrade hudi version of a flink job.
   Flink job is writing to a hudi MOR table using hudi 0.10.
   And i try to switch to 0.11 version
   
   **To Reproduce**
   
   Steps to reproduce the behavior:
   
   1.use flink to write to a hudi mor table with hudi 0.10 version
   2.stop the flink job
   3.restore flink job from ckp with hudi 0.11 version
   
   **Environment Description**
   
   * Hudi version : upgrade from 0.10 to 0.11
   
   **Stacktrace**
   
   ```Add the stacktrace of the error.```
   
   java.lang.Exception: Exception while creating StreamOperatorStateContext.
       at org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl.streamOperatorStateContext(StreamTaskStateInitializerImpl.java:254)
       at org.apache.flink.streaming.api.operators.AbstractStreamOperator.initializeState(AbstractStreamOperator.java:272)
       at org.apache.flink.streaming.runtime.tasks.OperatorChain.initializeStateAndOpenOperators(OperatorChain.java:454)
       at org.apache.flink.streaming.runtime.tasks.StreamTask.restoreGates(StreamTask.java:589)
       at org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor$1.call(StreamTaskActionExecutor.java:55)
       at org.apache.flink.streaming.runtime.tasks.StreamTask.executeRestore(StreamTask.java:569)
       at org.apache.flink.streaming.runtime.tasks.StreamTask.runWithCleanUpOnFail(StreamTask.java:654)
       at org.apache.flink.streaming.runtime.tasks.StreamTask.restore(StreamTask.java:544)
       at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:762)
       at org.apache.flink.runtime.taskmanager.Task.run(Task.java:566)
       at java.lang.Thread.run(Thread.java:748)
   Caused by: org.apache.flink.util.FlinkException: Could not restore operator state backend for BucketStreamWriteOperator_e73f56cacd46e7a7c0fc0033a27aad68_(2/4) from any of the 1 provided restore options.
       at org.apache.flink.streaming.api.operators.BackendRestorerProcedure.createAndRestore(BackendRestorerProcedure.java:160)
       at org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl.operatorStateBackend(StreamTaskStateInitializerImpl.java:285)
       at org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl.streamOperatorStateContext(StreamTaskStateInitializerImpl.java:173)
       ... 10 more
   Caused by: org.apache.flink.runtime.state.BackendBuildingException: Failed when trying to restore operator state backend
       at org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder.build(DefaultOperatorStateBackendBuilder.java:92)
       at org.apache.flink.contrib.streaming.state.EmbeddedRocksDBStateBackend.createOperatorStateBackend(EmbeddedRocksDBStateBackend.java:485)
       at org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl.lambda$operatorStateBackend$0(StreamTaskStateInitializerImpl.java:276)
       at org.apache.flink.streaming.api.operators.BackendRestorerProcedure.attemptCreateAndRestore(BackendRestorerProcedure.java:168)
       at org.apache.flink.streaming.api.operators.BackendRestorerProcedure.createAndRestore(BackendRestorerProcedure.java:135)
       ... 12 more
   Caused by: com.esotericsoftware.kryo.KryoException: Encountered unregistered class ID: 95
   Serialization trace:
   runtimeStats (org.apache.hudi.common.model.HoodieDeltaWriteStat)
   stat (org.apache.hudi.client.WriteStatus)
       at com.esotericsoftware.kryo.util.DefaultClassResolver.readClass(DefaultClassResolver.java:119)
       at com.esotericsoftware.kryo.Kryo.readClass(Kryo.java:641)
       at com.esotericsoftware.kryo.serializers.ObjectField.read(ObjectField.java:99)
       at com.esotericsoftware.kryo.serializers.FieldSerializer.read(FieldSerializer.java:528)
       at com.esotericsoftware.kryo.Kryo.readObject(Kryo.java:679)
       at com.esotericsoftware.kryo.serializers.ObjectField.read(ObjectField.java:106)
       at com.esotericsoftware.kryo.serializers.FieldSerializer.read(FieldSerializer.java:528)
       at com.esotericsoftware.kryo.Kryo.readClassAndObject(Kryo.java:761)
       at com.esotericsoftware.kryo.serializers.CollectionSerializer.read(CollectionSerializer.java:116)
       at com.esotericsoftware.kryo.serializers.CollectionSerializer.read(CollectionSerializer.java:22)
       at com.esotericsoftware.kryo.Kryo.readClassAndObject(Kryo.java:761)
       at org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer.deserialize(KryoSerializer.java:354)
       at org.apache.flink.api.java.typeutils.runtime.PojoSerializer.deserialize(PojoSerializer.java:425)
       at org.apache.flink.runtime.state.OperatorStateRestoreOperation.deserializeOperatorStateValues(OperatorStateRestoreOperation.java:217)
       at org.apache.flink.runtime.state.OperatorStateRestoreOperation.restore(OperatorStateRestoreOperation.java:188)
       at org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder.build(DefaultOperatorStateBackendBuilder.java:87)
       ... 16 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] danny0405 commented on issue #6478: [SUPPORT]Get KryoException when upgrade from 0.10 to 0.11 in flink

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

   I guess there is no good upgrade way since we serialize the `DeleteRecord` through kryo now, `DeleteRecord` is a structure introduced in 0.11.x to keep the event time sequence of the incoming records.
   
   @alexeykudinkin any idea to fix it for the next release?


-- 
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 closed issue #6478: [SUPPORT]Get KryoException when upgrade from 0.10 to 0.11 in flink

Posted by GitBox <gi...@apache.org>.
nsivabalan closed issue #6478: [SUPPORT]Get KryoException when upgrade from 0.10 to 0.11 in flink
URL: https://github.com/apache/hudi/issues/6478


-- 
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] Sam-3344 commented on issue #6478: [SUPPORT]Get KryoException when upgrade from 0.10 to 0.11 in flink

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

   Whats the fix for this now?


-- 
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 #6478: [SUPPORT]Get KryoException when upgrade from 0.10 to 0.11 in flink

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

   Guess its related to https://github.com/apache/hudi/issues/6621 
   We are actively working on a fix https://issues.apache.org/jira/browse/HUDI-4959
   will go ahead and close out the github issue. feel free to subscript to jira and PR
   
   thanks for raising the issue.


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