You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@iceberg.apache.org by "xzwDavid (via GitHub)" <gi...@apache.org> on 2023/10/29 07:33:14 UTC

[I] ClassNotFoundException when using the flinksql to write iceberg table [iceberg]

xzwDavid opened a new issue, #8947:
URL: https://github.com/apache/iceberg/issues/8947

   ### Apache Iceberg version
   
   1.4.1 (latest release)
   
   ### Query engine
   
   Flink
   
   ### Please describe the bug 🐞
   
   I create a iceberg catalog in flinksql and create a simple table and insert into it.
   However, it throw the exception like this(Full stack):
   2023-10-29 15:29:35
   org.apache.flink.runtime.JobException: Recovery is suppressed by NoRestartBackoffTimeStrategy
   	at org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.handleFailure(ExecutionFailureHandler.java:139)
   	at org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.getFailureHandlingResult(ExecutionFailureHandler.java:83)
   	at org.apache.flink.runtime.scheduler.DefaultScheduler.recordTaskFailure(DefaultScheduler.java:258)
   	at org.apache.flink.runtime.scheduler.DefaultScheduler.handleTaskFailure(DefaultScheduler.java:249)
   	at org.apache.flink.runtime.scheduler.DefaultScheduler.onTaskFailed(DefaultScheduler.java:242)
   	at org.apache.flink.runtime.scheduler.SchedulerBase.onTaskExecutionStateUpdate(SchedulerBase.java:748)
   	at org.apache.flink.runtime.scheduler.SchedulerBase.updateTaskExecutionState(SchedulerBase.java:725)
   	at org.apache.flink.runtime.scheduler.SchedulerNG.updateTaskExecutionState(SchedulerNG.java:80)
   	at org.apache.flink.runtime.jobmaster.JobMaster.updateTaskExecutionState(JobMaster.java:479)
   	at sun.reflect.GeneratedMethodAccessor50.invoke(Unknown Source)
   	at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
   	at java.lang.reflect.Method.invoke(Method.java:498)
   	at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.lambda$handleRpcInvocation$1(AkkaRpcActor.java:309)
   	at org.apache.flink.runtime.concurrent.akka.ClassLoadingUtils.runWithContextClassLoader(ClassLoadingUtils.java:83)
   	at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcInvocation(AkkaRpcActor.java:307)
   	at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcMessage(AkkaRpcActor.java:222)
   	at org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor.handleRpcMessage(FencedAkkaRpcActor.java:84)
   	at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleMessage(AkkaRpcActor.java:168)
   	at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:24)
   	at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:20)
   	at scala.PartialFunction.applyOrElse(PartialFunction.scala:127)
   	at scala.PartialFunction.applyOrElse$(PartialFunction.scala:126)
   	at akka.japi.pf.UnitCaseStatement.applyOrElse(CaseStatements.scala:20)
   	at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:175)
   	at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:176)
   	at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:176)
   	at akka.actor.Actor.aroundReceive(Actor.scala:537)
   	at akka.actor.Actor.aroundReceive$(Actor.scala:535)
   	at akka.actor.AbstractActor.aroundReceive(AbstractActor.scala:220)
   	at akka.actor.ActorCell.receiveMessage(ActorCell.scala:579)
   	at akka.actor.ActorCell.invoke(ActorCell.scala:547)
   	at akka.dispatch.Mailbox.processMailbox(Mailbox.scala:270)
   	at akka.dispatch.Mailbox.run(Mailbox.scala:231)
   	at akka.dispatch.Mailbox.exec(Mailbox.scala:243)
   	at java.util.concurrent.ForkJoinTask.doExec(ForkJoinTask.java:289)
   	at java.util.concurrent.ForkJoinPool$WorkQueue.runTask(ForkJoinPool.java:1056)
   	at java.util.concurrent.ForkJoinPool.runWorker(ForkJoinPool.java:1692)
   	at java.util.concurrent.ForkJoinWorkerThread.run(ForkJoinWorkerThread.java:157)
   Caused by: org.apache.flink.streaming.runtime.tasks.StreamTaskException: Cannot load user class: org.apache.iceberg.flink.sink.IcebergFilesCommitter
   ClassLoader info: URL ClassLoader:
       file: '/usr/local/flink-1.17.1/data/tm_container_1698550272631_0001_01_000018/blobStorage/job_9bed07011f84087c2bf5010236b8ff4a/blob_p-74de8414f153e6f082b311892d68b6f6efb82317-e6db6c933b6059b16d2df55e84fb4f10' (valid JAR)
       file: '/usr/local/flink-1.17.1/data/tm_container_1698550272631_0001_01_000018/blobStorage/job_9bed07011f84087c2bf5010236b8ff4a/blob_p-275820cb9b5e36c9f3e1e5483e93d0b808fe257e-12b0657b42a5e5955b56a8a56da07838' (valid JAR)
   Class not resolvable through given classloader.
   	at org.apache.flink.streaming.api.graph.StreamConfig.getStreamOperatorFactory(StreamConfig.java:397)
   	at org.apache.flink.streaming.runtime.tasks.OperatorChain.<init>(OperatorChain.java:166)
   	at org.apache.flink.streaming.runtime.tasks.RegularOperatorChain.<init>(RegularOperatorChain.java:60)
   	at org.apache.flink.streaming.runtime.tasks.StreamTask.restoreInternal(StreamTask.java:688)
   	at org.apache.flink.streaming.runtime.tasks.StreamTask.restore(StreamTask.java:675)
   	at org.apache.flink.runtime.taskmanager.Task.runWithSystemExitMonitoring(Task.java:952)
   	at org.apache.flink.runtime.taskmanager.Task.restoreAndInvoke(Task.java:921)
   	at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:745)
   	at org.apache.flink.runtime.taskmanager.Task.run(Task.java:562)
   	at java.lang.Thread.run(Thread.java:748)
   Caused by: java.lang.ClassNotFoundException: org.apache.iceberg.flink.sink.IcebergFilesCommitter
   	at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
   	at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
   	at org.apache.flink.util.FlinkUserCodeClassLoader.loadClassWithoutExceptionHandling(FlinkUserCodeClassLoader.java:67)
   	at org.apache.flink.util.ChildFirstClassLoader.loadClassWithoutExceptionHandling(ChildFirstClassLoader.java:74)
   	at org.apache.flink.util.FlinkUserCodeClassLoader.loadClass(FlinkUserCodeClassLoader.java:51)
   	at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
   	at java.lang.Class.forName0(Native Method)
   	at java.lang.Class.forName(Class.java:348)
   	at org.apache.flink.util.InstantiationUtil$ClassLoaderObjectInputStream.resolveClass(InstantiationUtil.java:76)
   	at java.io.ObjectInputStream.readNonProxyDesc(ObjectInputStream.java:1863)
   	at java.io.ObjectInputStream.readClassDesc(ObjectInputStream.java:1746)
   	at java.io.ObjectInputStream.readOrdinaryObject(ObjectInputStream.java:2037)
   	at java.io.ObjectInputStream.readObject0(ObjectInputStream.java:1568)
   	at java.io.ObjectInputStream.defaultReadFields(ObjectInputStream.java:2282)
   	at java.io.ObjectInputStream.readSerialData(ObjectInputStream.java:2206)
   	at java.io.ObjectInputStream.readOrdinaryObject(ObjectInputStream.java:2064)
   	at java.io.ObjectInputStream.readObject0(ObjectInputStream.java:1568)
   	at java.io.ObjectInputStream.readObject(ObjectInputStream.java:428)
   	at org.apache.flink.util.InstantiationUtil.deserializeObject(InstantiationUtil.java:534)
   	at org.apache.flink.util.InstantiationUtil.deserializeObject(InstantiationUtil.java:522)
   	at org.apache.flink.util.InstantiationUtil.readObjectFromConfig(InstantiationUtil.java:476)
   	at org.apache.flink.streaming.api.graph.StreamConfig.getStreamOperatorFactory(StreamConfig.java:383)
   	... 9 more
   
   I checked the dep in lib folder. I've download the 'iceberg-flink-runtime-1.17-1.3.0.jar' from the maven while it should involve the missing jars.


-- 
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: issues-unsubscribe@iceberg.apache.org.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


Re: [I] ClassNotFoundException when using the flinksql to write iceberg table [iceberg]

Posted by "xzwDavid (via GitHub)" <gi...@apache.org>.
xzwDavid closed issue #8947: ClassNotFoundException when using the flinksql to write iceberg table
URL: https://github.com/apache/iceberg/issues/8947


-- 
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: issues-unsubscribe@iceberg.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org