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/14 13:56:20 UTC

[GitHub] [iceberg] tbinoy opened a new issue, #6186: Iceberg table creation fails in AWS Glue

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

   ### Apache Iceberg version
   
   _No response_
   
   ### Query engine
   
   _No response_
   
   ### Please describe the bug 🐞
   
   The table create statement from Presto to AWS Glue metastore  fails with below error.
   
   presto> create schema isl_progress with(location='s3://xxxxxx/');
   CREATE SCHEMA
   presto> create table isl_progress.sprint_details(sprint_id int, sprint_progress_pct varchar);
   **Query 20221114_115537_00033_tb3fw failed: Lock is not supported by default**
   
   I noticed an old issue for the AWS Glue support for metastore. 
   https://github.com/apache/iceberg/issues/932 
   Had this issue been addressed?


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


[GitHub] [iceberg] github-actions[bot] commented on issue #6186: Iceberg table creation fails in AWS Glue

Posted by "github-actions[bot] (via GitHub)" <gi...@apache.org>.
github-actions[bot] commented on issue #6186:
URL: https://github.com/apache/iceberg/issues/6186#issuecomment-1567613339

   This issue has been automatically marked as stale because it has been open for 180 days with no activity. It will be closed in next 14 days if no further activity occurs. To permanently prevent this issue from being considered stale, add the label 'not-stale', but commenting on the issue is preferred when possible.


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


[GitHub] [iceberg] github-actions[bot] closed issue #6186: Iceberg table creation fails in AWS Glue

Posted by "github-actions[bot] (via GitHub)" <gi...@apache.org>.
github-actions[bot] closed issue #6186: Iceberg table creation fails in AWS Glue
URL: https://github.com/apache/iceberg/issues/6186


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


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

Posted by GitBox <gi...@apache.org>.
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


[GitHub] [iceberg] github-actions[bot] commented on issue #6186: Iceberg table creation fails in AWS Glue

Posted by "github-actions[bot] (via GitHub)" <gi...@apache.org>.
github-actions[bot] commented on issue #6186:
URL: https://github.com/apache/iceberg/issues/6186#issuecomment-1593872946

   This issue has been closed because it has not received any activity in the last 14 days since being marked as 'stale'


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


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

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

   I notice  a PR request https://github.com/prestodb/presto/pull/18708 . Will it address this 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: 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