Uploaded image for project: 'Apache Drill'
  1. Apache Drill
  2. DRILL-2859

Unexpected exception in the query with an interval data type

    XMLWordPrintableJSON

Details

    Description

      0: jdbc:drill:schema=dfs> select cast(cast(a1 as int) as interval day) from t1 where a1 = 1;
      Query failed: SYSTEM ERROR: Unexpected exception during fragment initialization: todo: implement syntax SPECIAL(Reinterpret(*(Reinterpret(CAST(CAST($0):INTEGER):DECIMAL(2, 0)), 86400000)))
      
      
      [5119315b-dd73-432f-ab93-49e76e9165f6 on atsqa4-134.qa.lab:31010]
      
        (org.apache.drill.exec.work.foreman.ForemanException) Unexpected exception during fragment initialization: todo: implement syntax SPECIAL(Reinterpret(*(Reinterpret(CAST(CAST($0):INTEGER):DECIMAL(2, 0)), 86400000)))
          org.apache.drill.exec.work.foreman.Foreman.run():212
          java.util.concurrent.ThreadPoolExecutor.runWorker():1145
          java.util.concurrent.ThreadPoolExecutor$Worker.run():615
          java.lang.Thread.run():745
        Caused By (java.lang.AssertionError) todo: implement syntax SPECIAL(Reinterpret(*(Reinterpret(CAST(CAST($0):INTEGER):DECIMAL(2, 0)), 86400000)))
          org.apache.drill.exec.planner.logical.DrillOptiq$RexToDrill.visitCall():182
          org.apache.drill.exec.planner.logical.DrillOptiq$RexToDrill.visitCall():73
          org.apache.calcite.rex.RexCall.accept():107
          org.apache.drill.exec.planner.logical.DrillOptiq.toDrill():70
          org.apache.drill.exec.planner.common.DrillProjectRelBase.getProjectExpressions():111
          org.apache.drill.exec.planner.physical.ProjectPrel.getPhysicalOperator():57
          org.apache.drill.exec.planner.physical.ScreenPrel.getPhysicalOperator():51
          org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler.convertToPop():376
          org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler.getPlan():157
          org.apache.drill.exec.planner.sql.DrillSqlWorker.getPlan():167
          org.apache.drill.exec.work.foreman.Foreman.runSQL():773
          org.apache.drill.exec.work.foreman.Foreman.run():203
          java.util.concurrent.ThreadPoolExecutor.runWorker():1145
          java.util.concurrent.ThreadPoolExecutor$Worker.run():615
          java.lang.Thread.run():745
      
      Error: exception while executing query: Failure while executing query. (state=,code=0)
      

      Attachments

        Activity

          People

            Unassigned Unassigned
            vicky Victoria Markman
            Votes:
            0 Vote for this issue
            Watchers:
            2 Start watching this issue

            Dates

              Created:
              Updated: