Uploaded image for project: 'Tajo (Retired)'
  1. Tajo (Retired)
  2. TAJO-507

Column partitioned table is not dropped

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Resolved
    • Major
    • Resolution: Not A Problem
    • None
    • 0.8.0
    • None
    • None

    Description

      See the title.
      I defined a table and tried to drop the table as follows.

      tajo> create table test (totaltime int8, cache text, httpcode int4, requestaddr text, user text) partition by column (totaltime int8);
      OK
      tajo> \d
      test
      tajo> \d test 
      table name: test
      table path: hdfs://localhost:7020/tajo/warehouse/test
      store type: CSV
      number of rows: 0
      volume: 0 B
      Options: 
      
      schema: 
      totaltime	INT8
      cache	TEXT
      httpcode	INT4
      requestaddr	TEXT
      user	TEXT
      
      Partitions: 
      
      tajo> drop table test purge;
      OK
      tajo> \d
      test
      

      The error log is as follows.

      2014-01-16 13:49:57,335 ERROR catalog.CatalogServer (CatalogServer.java:deleteTable(278)) - java.sql.SQLSyntaxErrorException: Column 'TABLE_ID' is either not in any table in the FROM list or appears within a join specification and is outside the scope of the join specification or appears in a HAVING clause and is not in the GROUP BY list. If this is a CREATE or ALTER TABLE  statement then 'TABLE_ID' is not a column in the target table.
      java.io.IOException: java.sql.SQLSyntaxErrorException: Column 'TABLE_ID' is either not in any table in the FROM list or appears within a join specification and is outside the scope of the join specification or appears in a HAVING clause and is not in the GROUP BY list. If this is a CREATE or ALTER TABLE  statement then 'TABLE_ID' is not a column in the target table.
              at org.apache.tajo.catalog.store.AbstractDBStore.deleteTable(AbstractDBStore.java:418)
              at org.apache.tajo.catalog.CatalogServer$CatalogProtocolHandler.deleteTable(CatalogServer.java:276)
              at org.apache.tajo.catalog.AbstractCatalogClient$7.call(AbstractCatalogClient.java:173)
              at org.apache.tajo.catalog.AbstractCatalogClient$7.call(AbstractCatalogClient.java:170)
              at org.apache.tajo.rpc.ServerCallable.withRetries(ServerCallable.java:89)
              at org.apache.tajo.catalog.AbstractCatalogClient.deleteTable(AbstractCatalogClient.java:170)
              at org.apache.tajo.master.GlobalEngine.dropTable(GlobalEngine.java:330)
              at org.apache.tajo.master.GlobalEngine.updateQuery(GlobalEngine.java:227)
              at org.apache.tajo.master.GlobalEngine.executeQuery(GlobalEngine.java:144)
              at org.apache.tajo.master.TajoMasterClientService$TajoMasterClientProtocolServiceHandler.submitQuery(TajoMasterClientService.java:161)
              at org.apache.tajo.ipc.TajoMasterClientProtocol$TajoMasterClientProtocolService$2.callBlockingMethod(TajoMasterClientProtocol.java:273)
              at org.apache.tajo.rpc.BlockingRpcServer$ServerHandler.messageReceived(BlockingRpcServer.java:91)
              at org.jboss.netty.channel.SimpleChannelUpstreamHandler.handleUpstream(SimpleChannelUpstreamHandler.java:70)
              at org.jboss.netty.channel.DefaultChannelPipeline.sendUpstream(DefaultChannelPipeline.java:564)
              at org.jboss.netty.channel.DefaultChannelPipeline$DefaultChannelHandlerContext.sendUpstream(DefaultChannelPipeline.java:791)
              at org.jboss.netty.channel.Channels.fireMessageReceived(Channels.java:296)
              at org.jboss.netty.handler.codec.oneone.OneToOneDecoder.handleUpstream(OneToOneDecoder.java:70)
              at org.jboss.netty.channel.DefaultChannelPipeline.sendUpstream(DefaultChannelPipeline.java:564)
              at org.jboss.netty.channel.DefaultChannelPipeline$DefaultChannelHandlerContext.sendUpstream(DefaultChannelPipeline.java:791)
              at org.jboss.netty.channel.Channels.fireMessageReceived(Channels.java:296)
              at org.jboss.netty.handler.codec.frame.FrameDecoder.unfoldAndFireMessageReceived(FrameDecoder.java:462)
              at org.jboss.netty.handler.codec.frame.FrameDecoder.callDecode(FrameDecoder.java:443)
              at org.jboss.netty.handler.codec.frame.FrameDecoder.messageReceived(FrameDecoder.java:303)
              at org.jboss.netty.channel.SimpleChannelUpstreamHandler.handleUpstream(SimpleChannelUpstreamHandler.java:70)
              at org.jboss.netty.channel.DefaultChannelPipeline.sendUpstream(DefaultChannelPipeline.java:564)
              at org.jboss.netty.channel.DefaultChannelPipeline.sendUpstream(DefaultChannelPipeline.java:559)
              at org.jboss.netty.channel.Channels.fireMessageReceived(Channels.java:268)
              at org.jboss.netty.channel.Channels.fireMessageReceived(Channels.java:255)
              at org.jboss.netty.channel.socket.nio.NioWorker.read(NioWorker.java:88)
              at org.jboss.netty.channel.socket.nio.AbstractNioWorker.process(AbstractNioWorker.java:109)
              at org.jboss.netty.channel.socket.nio.AbstractNioSelector.run(AbstractNioSelector.java:312)
              at org.jboss.netty.channel.socket.nio.AbstractNioWorker.run(AbstractNioWorker.java:90)
              at org.jboss.netty.channel.socket.nio.NioWorker.run(NioWorker.java:178)
              at org.jboss.netty.util.ThreadRenamingRunnable.run(ThreadRenamingRunnable.java:108)
              at org.jboss.netty.util.internal.DeadLockProofWorker$1.run(DeadLockProofWorker.java:42)
              at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1146)
              at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:615)
              at java.lang.Thread.run(Thread.java:679)
      

      Attachments

        Activity

          People

            Unassigned Unassigned
            jihoonson Jihoon Son
            Votes:
            0 Vote for this issue
            Watchers:
            1 Start watching this issue

            Dates

              Created:
              Updated:
              Resolved: