You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@iceberg.apache.org by GitBox <gi...@apache.org> on 2021/01/12 08:47:01 UTC

[GitHub] [iceberg] zhengqiangtan opened a new issue #2076: Can not write data to hive catalog iceberg table, why ?

zhengqiangtan opened a new issue #2076:
URL: https://github.com/apache/iceberg/issues/2076


   Hi ,I'm using sql-client to test create hive catalog as follow:
   > env: java: 1.8,  flink 1.11.2, hive 2.1.1
   
   ```shell
   bin/sql-client.sh embedded \
      -j /data/flink-1.11.2/extlib/iceberg-flink-runtime-0.10.0.jar \
      -j /data/flink-1.11.2/extlib/flink-sql-connector-hive-2.2.0_2.11-1.11.2.jar \
      shell
   
   CREATE CATALOG hive_catalog WITH (
     'type'='iceberg',
     'catalog-type'='hive',
     'uri'='thrift://zmbd-uat03:9083',
     'clients'='3',
     'property-version'='1',
     'warehouse'='hdfs://nameservice1/user/hive/warehouse'
   );
   
   CREATE TABLE hive_sample (
       id BIGINT COMMENT 'unique id',
       data STRING
   );
   
   insert into hive_sample values(1,'abcd');  
   
   when execute insert I met follow error , what's problem maybe cause ?
   ```
   
   #### Flink web ui exceptions:
   ```java
   2021-01-12 16:19:48
   org.apache.flink.runtime.JobException: Recovery is suppressed by NoRestartBackoffTimeStrategy
   	at org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.handleFailure(ExecutionFailureHandler.java:116)
   	at org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.getFailureHandlingResult(ExecutionFailureHandler.java:78)
   	at org.apache.flink.runtime.scheduler.DefaultScheduler.handleTaskFailure(DefaultScheduler.java:192)
   	at org.apache.flink.runtime.scheduler.DefaultScheduler.maybeHandleTaskFailure(DefaultScheduler.java:185)
   	at org.apache.flink.runtime.scheduler.DefaultScheduler.updateTaskExecutionStateInternal(DefaultScheduler.java:179)
   	at org.apache.flink.runtime.scheduler.SchedulerBase.updateTaskExecutionState(SchedulerBase.java:503)
   	at org.apache.flink.runtime.jobmaster.JobMaster.updateTaskExecutionState(JobMaster.java:386)
   	at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
   	at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:62)
   	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.handleRpcInvocation(AkkaRpcActor.java:284)
   	at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcMessage(AkkaRpcActor.java:199)
   	at org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor.handleRpcMessage(FencedAkkaRpcActor.java:74)
   	at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleMessage(AkkaRpcActor.java:152)
   	at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:26)
   	at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:21)
   	at scala.PartialFunction$class.applyOrElse(PartialFunction.scala:123)
   	at akka.japi.pf.UnitCaseStatement.applyOrElse(CaseStatements.scala:21)
   	at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:170)
   	at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:171)
   	at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:171)
   	at akka.actor.Actor$class.aroundReceive(Actor.scala:517)
   	at akka.actor.AbstractActor.aroundReceive(AbstractActor.scala:225)
   	at akka.actor.ActorCell.receiveMessage(ActorCell.scala:592)
   	at akka.actor.ActorCell.invoke(ActorCell.scala:561)
   	at akka.dispatch.Mailbox.processMailbox(Mailbox.scala:258)
   	at akka.dispatch.Mailbox.run(Mailbox.scala:225)
   	at akka.dispatch.Mailbox.exec(Mailbox.scala:235)
   	at akka.dispatch.forkjoin.ForkJoinTask.doExec(ForkJoinTask.java:260)
   	at akka.dispatch.forkjoin.ForkJoinPool$WorkQueue.runTask(ForkJoinPool.java:1339)
   	at akka.dispatch.forkjoin.ForkJoinPool.runWorker(ForkJoinPool.java:1979)
   	at akka.dispatch.forkjoin.ForkJoinWorkerThread.run(ForkJoinWorkerThread.java:107)
   Caused by: java.lang.VerifyError: Stack map does not match the one at exception handler 18
   Exception Details:
     Location:
       org/apache/iceberg/hive/HiveCatalog.alterHiveDataBase(Lorg/apache/iceberg/catalog/Namespace;Lorg/apache/hadoop/hive/metastore/api/Database;)V @18: astore_3
     Reason:
       Type 'org/apache/hadoop/hive/metastore/api/NoSuchObjectException' (current frame, stack[0]) is not assignable to 'org/apache/thrift/TException' (stack map, stack[0])
     Current Frame:
       bci: @0
       flags: { }
       locals: { 'org/apache/iceberg/hive/HiveCatalog', 'org/apache/iceberg/catalog/Namespace', 'org/apache/hadoop/hive/metastore/api/Database' }
       stack: { 'org/apache/hadoop/hive/metastore/api/NoSuchObjectException' }
     Stackmap Frame:
       bci: @18
       flags: { }
       locals: { 'org/apache/iceberg/hive/HiveCatalog', 'org/apache/iceberg/catalog/Namespace', 'org/apache/hadoop/hive/metastore/api/Database' }
       stack: { 'org/apache/thrift/TException' }
     Bytecode:
       0x0000000: 2ab4 0038 2b2c ba02 2800 00b6 009a 57a7
       0x0000010: 0065 4ebb 00c7 592d 12c9 04bd 00cb 5903
       0x0000020: 2b53 b702 29bf 4ebb 00d0 59bb 00d2 59b7
       0x0000030: 00d3 1302 2bb6 00d9 2bb6 00dc 1301 a4b6
       0x0000040: 00d9 b600 e02d b700 e3bf 4eb8 0040 b600
       0x0000050: e6bb 00d0 59bb 00d2 59b7 00d3 1302 2db6
       0x0000060: 00d9 2bb6 00dc 1301 a4b6 00d9 b600 e02d
       0x0000070: b700 e3bf b1                           
     Exception Handler Table:
       bci [0, 15] => handler: 18
       bci [0, 15] => handler: 18
       bci [0, 15] => handler: 38
       bci [0, 15] => handler: 74
     Stackmap Table:
       same_locals_1_stack_item_frame(@18,Object[#111])
       same_locals_1_stack_item_frame(@38,Object[#111])
       same_locals_1_stack_item_frame(@74,Object[#113])
       same_frame(@116)
   
   	at org.apache.iceberg.flink.CatalogLoader$HiveCatalogLoader.loadCatalog(CatalogLoader.java:95)
   	at org.apache.iceberg.flink.TableLoader$CatalogTableLoader.open(TableLoader.java:108)
   	at org.apache.iceberg.flink.sink.IcebergFilesCommitter.initializeState(IcebergFilesCommitter.java:120)
   	at org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.initializeOperatorState(StreamOperatorStateHandler.java:106)
   	at org.apache.flink.streaming.api.operators.AbstractStreamOperator.initializeState(AbstractStreamOperator.java:258)
   	at org.apache.flink.streaming.runtime.tasks.OperatorChain.initializeStateAndOpenOperators(OperatorChain.java:290)
   	at org.apache.flink.streaming.runtime.tasks.StreamTask.lambda$beforeInvoke$0(StreamTask.java:479)
   	at org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor$1.runThrowing(StreamTaskActionExecutor.java:47)
   	at org.apache.flink.streaming.runtime.tasks.StreamTask.beforeInvoke(StreamTask.java:475)
   	at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:528)
   	at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:721)
   	at org.apache.flink.runtime.taskmanager.Task.run(Task.java:546)
   	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.

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


[GitHub] [iceberg] chong0929 commented on issue #2076: Can not write data to hive catalog iceberg table, why ?

Posted by GitBox <gi...@apache.org>.
chong0929 commented on issue #2076:
URL: https://github.com/apache/iceberg/issues/2076#issuecomment-784167496


   Is your problem solved? I have the same error.


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

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


[GitHub] [iceberg] pvary commented on issue #2076: Can not write data to hive catalog iceberg table, why ?

Posted by GitBox <gi...@apache.org>.
pvary commented on issue #2076:
URL: https://github.com/apache/iceberg/issues/2076#issuecomment-759231509


   No too familiar with Flink error messages, but could this be similar to #2057?


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

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