Uploaded image for project: 'Hive'
  1. Hive
  2. HIVE-3157

set fileformat rcfile is not working on the tables with partition

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Open
    • Major
    • Resolution: Unresolved
    • None
    • None
    • Metastore
    • None

    Description

      Steps to reproduce
      --------------------------
      Create the table with partition
      Add partition
      set the file format to rcfile
      Now try to load RCfile into the table
      Load is failing.

      create table rcfileTable(key int, value string) partitioned by (ds string);
      alter table rcfileTable add partition(ds='2010');
      alter table rcfileTable partition(ds='2010') set fileformat rcfile;
      load data local inpath 'smbbucket_1.rc' overwrite into table rcfileTable partition(ds='2010');
      

      Please find the exception trace for more details
      --------------------------------------------

      2012-06-19 19:21:01,500 ERROR exec.Task (SessionState.java:printError(400)) - Failed with exception Wrong file format. Please check the file's format.
      org.apache.hadoop.hive.ql.metadata.HiveException: Wrong file format. Please check the file's format.
      	at org.apache.hadoop.hive.ql.exec.MoveTask.execute(MoveTask.java:224)
      	at org.apache.hadoop.hive.ql.exec.Task.executeTask(Task.java:135)
      	at org.apache.hadoop.hive.ql.exec.TaskRunner.runSequential(TaskRunner.java:57)
      	at org.apache.hadoop.hive.ql.Driver.launchTask(Driver.java:1329)
      	at org.apache.hadoop.hive.ql.Driver.execute(Driver.java:1121)
      	at org.apache.hadoop.hive.ql.Driver.run(Driver.java:954)
      	at org.apache.hadoop.hive.service.HiveServer$HiveServerHandler.execute(HiveServer.java:191)
      	at org.apache.hadoop.hive.service.ThriftHive$Processor$execute.getResult(ThriftHive.java:629)
      	at org.apache.hadoop.hive.service.ThriftHive$Processor$execute.getResult(ThriftHive.java:617)
      	at org.apache.thrift.ProcessFunction.process(ProcessFunction.java:32)
      	at org.apache.thrift.TBaseProcessor.process(TBaseProcessor.java:34)
      	at org.apache.thrift.server.TThreadPoolServer$WorkerProcess.run(TThreadPoolServer.java:176)
      	at java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
      	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
      	at java.lang.Thread.run(Thread.java:662)
      
      

      Attachments

        Activity

          People

            chinnalalam Chinna Rao Lalam
            kristamswathi Kristam Subba Swathi
            Votes:
            0 Vote for this issue
            Watchers:
            3 Start watching this issue

            Dates

              Created:
              Updated: