You are viewing a plain text version of this content. The canonical link for it is here.
Posted to common-user@hadoop.apache.org by Kumar Jayapal <kj...@gmail.com> on 2015/06/30 01:39:05 UTC

hive load error

Hi,

I am trying to insert data into file from parquet table. with the following
command and getting this exception.


insert overwrite directory '/tmp/blo' ROW FORMAT DELIMITED FIELDS
TERMINATED BY ','  STORED AS AVRO select dwhse, dsdat, dreg_num, drn_num,
dscnr, dareq, datak, dmsgc from blok where fiscal_year=2008 and
fiscal_period=01 limit 10;



What wrong with this command when I execute i get this error.

2015-06-29 23:35:01,907 INFO org.apache.hadoop.hive.ql.log.PerfLogger:
</PERFLOG method=compile start=1435620901903 end=1435620901907 duration=4
from=org.apache.hadoop.hive.ql.Driver>
2015-06-29 23:35:01,907 INFO org.apache.hadoop.hive.ql.log.PerfLogger:
<PERFLOG method=releaseLocks from=org.apache.hadoop.hive.ql.Driver>
2015-06-29 23:35:01,907 INFO org.apache.hadoop.hive.ql.log.PerfLogger:
</PERFLOG method=releaseLocks start=1435620901907 end=1435620901907
duration=0 from=org.apache.hadoop.hive.ql.Driver>
2015-06-29 23:35:01,907 WARN
org.apache.hive.service.cli.thrift.ThriftCLIService: Error executing
statement:
org.apache.hive.service.cli.HiveSQLException: Error while compiling
statement: FAILED: ParseException line 1:46 cannot recognize input near
'ROW' 'FORMAT' 'DELIMITED' in select clause
        at
org.apache.hive.service.cli.operation.SQLOperation.prepare(SQLOperation.java:102)
        at
org.apache.hive.service.cli.operation.SQLOperation.run(SQLOperation.java:173)
        at
org.apache.hive.service.cli.session.HiveSessionImpl.runOperationWithLogCapture(HiveSessionImpl.java:715)
        at
org.apache.hive.service.cli.session.HiveSessionImpl.executeStatementInternal(HiveSessionImpl.java:370)
        at
org.apache.hive.service.cli.session.HiveSessionImpl.executeStatementAsync(HiveSessionImpl.java:357)
        at
org.apache.hive.service.cli.CLIService.executeStatementAsync(CLIService.java:237)
        at
org.apache.hive.service.cli.thrift.ThriftCLIService.ExecuteStatement(ThriftCLIService.java:392)
        at
org.apache.hive.service.cli.thrift.TCLIService$Processor$ExecuteStatement.getResult(TCLIService.java:1373)
        at
org.apache.hive.service.cli.thrift.TCLIService$Processor$ExecuteStatement.getResult(TCLIService.java:1358)
        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:55)
        at
org.apache.thrift.server.TThreadPoolServer$WorkerProcess.run(TThreadPoolServer.java:244)
        at
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1145)
        at
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:615)
        at java.lang.Thread.run(Thread.java:745)






Thanks
Jay