You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hudi.apache.org by "liujinhui (Jira)" <ji...@apache.org> on 2020/08/14 10:46:00 UTC

[jira] [Assigned] (HUDI-1192) Fix the failure of creating hive database

     [ https://issues.apache.org/jira/browse/HUDI-1192?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ]

liujinhui reassigned HUDI-1192:
-------------------------------

    Assignee: liujinhui

> Fix the failure of creating hive database
> -----------------------------------------
>
>                 Key: HUDI-1192
>                 URL: https://issues.apache.org/jira/browse/HUDI-1192
>             Project: Apache Hudi
>          Issue Type: Bug
>    Affects Versions: 0.6.0
>            Reporter: liujinhui
>            Assignee: liujinhui
>            Priority: Major
>             Fix For: 0.6.0
>
>
> {code:java}
> org.apache.hudi.hive.HoodieHiveSyncException: Failed in executing SQL create database if not exists data_lake
> 	at org.apache.hudi.hive.HoodieHiveClient.updateHiveSQL(HoodieHiveClient.java:352)
> 	at org.apache.hudi.hive.HiveSyncTool.syncHoodieTable(HiveSyncTool.java:121)
> 	at org.apache.hudi.hive.HiveSyncTool.syncHoodieTable(HiveSyncTool.java:94)
> 	at org.apache.hudi.utilities.deltastreamer.DeltaSync.syncMeta(DeltaSync.java:510)
> 	at org.apache.hudi.utilities.deltastreamer.DeltaSync.writeToSink(DeltaSync.java:425)
> 	at org.apache.hudi.utilities.deltastreamer.DeltaSync.syncOnce(DeltaSync.java:244)
> 	at org.apache.hudi.utilities.deltastreamer.HoodieDeltaStreamer$DeltaSyncService.lambda$startService$0(HoodieDeltaStreamer.java:579)
> 	at java.util.concurrent.CompletableFuture$AsyncSupply.run(CompletableFuture.java:1590)
> 	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:748)
> Caused by: org.apache.hive.service.cli.HiveSQLException: Error while compiling statement: FAILED: SemanticException No valid privileges
>  User lingqu does not have privileges for CREATEDATABASE
>  The required privileges: Server=server1->action=create->grantOption=false;
> 	at org.apache.hive.jdbc.Utils.verifySuccess(Utils.java:266)
> 	at org.apache.hive.jdbc.Utils.verifySuccessWithInfo(Utils.java:252)
> 	at org.apache.hive.jdbc.HiveStatement.runAsyncOnServer(HiveStatement.java:309)
> 	at org.apache.hive.jdbc.HiveStatement.execute(HiveStatement.java:250)
> 	at org.apache.hudi.hive.HoodieHiveClient.updateHiveSQL(HoodieHiveClient.java:350)
> 	... 10 more
> Caused by: org.apache.hive.service.cli.HiveSQLException: Error while compiling statement: FAILED: SemanticException No valid privileges
>  User lingqu does not have privileges for CREATEDATABASE
>  The required privileges: Server=server1->action=create->grantOption=false;
> 	at org.apache.hive.service.cli.operation.Operation.toSQLException(Operation.java:329)
> 	at org.apache.hive.service.cli.operation.SQLOperation.prepare(SQLOperation.java:207)
> 	at org.apache.hive.service.cli.operation.SQLOperation.runInternal(SQLOperation.java:290)
> 	at org.apache.hive.service.cli.operation.Operation.run(Operation.java:260)
> 	at org.apache.hive.service.cli.session.HiveSessionImpl.executeStatementInternal(HiveSessionImpl.java:505)
> 	at org.apache.hive.service.cli.session.HiveSessionImpl.executeStatementAsync(HiveSessionImpl.java:491)
> 	at org.apache.hive.service.cli.CLIService.executeStatementAsync(CLIService.java:295)
> 	at org.apache.hive.service.cli.thrift.ThriftCLIService.ExecuteStatement(ThriftCLIService.java:507)
> 	at org.apache.hive.service.rpc.thrift.TCLIService$Processor$ExecuteStatement.getResult(TCLIService.java:1437)
> 	at org.apache.hive.service.rpc.thrift.TCLIService$Processor$ExecuteStatement.getResult(TCLIService.java:1422)
> 	at org.apache.thrift.ProcessFunction.process(ProcessFunction.java:39)
> 	at org.apache.thrift.TBaseProcessor.process(TBaseProcessor.java:39)
> 	at org.apache.hive.service.auth.TSetIpAddressProcessor.process(TSetIpAddressProcessor.java:56)
> 	at org.apache.thrift.server.TThreadPoolServer$WorkerProcess.run(TThreadPoolServer.java:286)
> 	... 3 more
> Caused by: org.apache.hadoop.hive.ql.parse.SemanticException: No valid privileges
>  User lingqu does not have privileges for CREATEDATABASE
>  The required privileges: Server=server1->action=create->grantOption=false;
> 	at org.apache.sentry.binding.hive.HiveAuthzBindingHook.postAnalyze(HiveAuthzBindingHook.java:371)
> 	at org.apache.hadoop.hive.ql.Driver.compile(Driver.java:600)
> 	at org.apache.hadoop.hive.ql.Driver.compileInternal(Driver.java:1425)
> 	at org.apache.hadoop.hive.ql.Driver.compileAndRespond(Driver.java:1398)
> 	at org.apache.hive.service.cli.operation.SQLOperation.prepare(SQLOperation.java:205)
> 	... 15 more
> Caused by: org.apache.hadoop.hive.ql.metadata.AuthorizationException: User lingqu does not have privileges for CREATEDATABASE
> 	at org.apache.sentry.binding.hive.authz.HiveAuthzBinding.authorize(HiveAuthzBinding.java:339)
> 	at org.apache.sentry.binding.hive.authz.HiveAuthzBindingHookBase.authorizeWithHiveBindings(HiveAuthzBindingHookBase.java:514)
> 	at org.apache.sentry.binding.hive.HiveAuthzBindingHook.postAnalyze(HiveAuthzBindingHook.java:354)
> 	... 19 more
> {code}



--
This message was sent by Atlassian Jira
(v8.3.4#803005)