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 2022/11/17 05:49:20 UTC

[GitHub] [iceberg] tbinoy commented on issue #6186: Iceberg table creation fails in AWS Glue

tbinoy commented on issue #6186:
URL: https://github.com/apache/iceberg/issues/6186#issuecomment-1318117329

   I am using Presto 0.277 to connect create/ insert iceberg tables in AWS Glue. I am able to run select query for iceberg tables in glue but not able to do insert or table creation. 
   
   Below is the stack trace Query 20221116_103709_00002_qie8q failed: Lock is not supported by default
   com.facebook.presto.common.NotSupportedException: Lock is not supported by default
           at com.facebook.presto.hive.metastore.ExtendedHiveMetastore.lock(ExtendedHiveMetastore.java:126)
           at com.facebook.presto.hive.metastore.CachingHiveMetastore.lock(CachingHiveMetastore.java:997)
           at com.facebook.presto.iceberg.HiveTableOperations.commit(HiveTableOperations.java:244)
           at org.apache.iceberg.BaseTransaction.lambda$commitSimpleTransaction$5(BaseTransaction.java:386)
           at org.apache.iceberg.util.Tasks$Builder.runTaskWithRetry(Tasks.java:404)
           at org.apache.iceberg.util.Tasks$Builder.runSingleThreaded(Tasks.java:214)
           at org.apache.iceberg.util.Tasks$Builder.run(Tasks.java:198)
           at org.apache.iceberg.util.Tasks$Builder.run(Tasks.java:190)
           at org.apache.iceberg.BaseTransaction.commitSimpleTransaction(BaseTransaction.java:378)
           at org.apache.iceberg.BaseTransaction.commitTransaction(BaseTransaction.java:268)
           at com.facebook.presto.iceberg.IcebergAbstractMetadata.finishInsert(IcebergAbstractMetadata.java:250)
           at com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorMetadata.finishInsert(ClassLoaderSafeConnectorMetadata.java:452)
           at com.facebook.presto.metadata.MetadataManager.finishInsert(MetadataManager.java:896)
           at com.facebook.presto.sql.planner.LocalExecutionPlanner.lambda$createTableFinisher$3(LocalExecutionPlanner.java:3221)
           at com.facebook.presto.operator.TableFinishOperator.getOutput(TableFinishOperator.java:289)
           at com.facebook.presto.operator.Driver.processInternal(Driver.java:426)
           at com.facebook.presto.operator.Driver.lambda$processFor$9(Driver.java:309)
           at com.facebook.presto.operator.Driver.tryWithLock(Driver.java:730)
           at com.facebook.presto.operator.Driver.processFor(Driver.java:302)
           at com.facebook.presto.execution.SqlTaskExecution$DriverSplitRunner.processFor(SqlTaskExecution.java:1079)
           at com.facebook.presto.execution.executor.PrioritizedSplitRunner.process(PrioritizedSplitRunner.java:166)
           at com.facebook.presto.execution.executor.TaskExecutor$TaskRunner.run(TaskExecutor.java:599)
           at com.facebook.presto.$gen.Presto_0_277_119fd9a____20221116_101723_1.run(Unknown Source)
           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:750)
   


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