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

Full outer join query with empty intermediate data doesn't terminate.

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Resolved
    • Trivial
    • Resolution: Fixed
    • None
    • 0.9.0
    • None
    • None

    Description

      See title.
      I ran the following query. Left and right subquery's result is empty.

      select a.l_orderkey 
      from (select * from lineitem where l_orderkey < 0) a
      full outer join (select * from lineitem where l_orderkey < 0) b
      on a.l_orderkey = b.l_orderkey
      

      The next log is QueryMaster's log. QueryMaster assigned 1 task for JOIN execution block.

      2014-06-30 16:18:24,987 INFO: org.apache.tajo.master.querymaster.Repartitioner (scheduleFragmentsForJoinQuery(186)) - [Distributed Join Strategy] : Symmetric Repartition Join
      2014-06-30 16:18:24,988 INFO: org.apache.tajo.master.querymaster.Repartitioner (scheduleFragmentsForJoinQuery(258)) - Larger intermediate data is approximately 0 MB
      2014-06-30 16:18:24,988 INFO: org.apache.tajo.master.querymaster.Repartitioner (scheduleFragmentsForJoinQuery(261)) - The calculated number of tasks is 0
      2014-06-30 16:18:24,988 INFO: org.apache.tajo.master.querymaster.Repartitioner (scheduleFragmentsForJoinQuery(262)) - The number of total shuffle keys is 1
      2014-06-30 16:18:24,988 INFO: org.apache.tajo.master.querymaster.Repartitioner (scheduleFragmentsForJoinQuery(266)) - The determined number of join tasks is 0
      2014-06-30 16:18:24,989 INFO: org.apache.tajo.master.querymaster.SubQuery (transition(647)) - 1 objects are scheduled
      2014-06-30 16:18:24,989 INFO: org.apache.tajo.master.DefaultTaskScheduler (start(87)) - Start TaskScheduler
      2014-06-30 16:18:24,990 INFO: org.apache.tajo.worker.TajoResourceAllocator (calculateNumRequestContainers(100)) - CalculateNumberRequestContainer - Number of Tasks=0, Number of Cluster Slots=1
      2014-06-30 16:18:24,990 INFO: org.apache.tajo.master.querymaster.SubQuery (allocateContainers(888)) - Request Container for eb_1404112701831_0001_000003 containers=0
      2014-06-30 16:18:24,990 INFO: org.apache.tajo.master.querymaster.Query (executeNextBlock(609)) - Scheduling SubQuery:eb_1404112701831_0001_000003
      2014-06-30 16:18:24,991 INFO: org.apache.tajo.worker.TajoResourceAllocator (run(217)) - Start TajoWorkerAllocationThread
      2014-06-30 16:18:26,480 INFO: org.apache.tajo.master.querymaster.QueryInProgress (heartbeat(265)) - Received QueryMaster heartbeat:q_1404112701831_0001,state=QUERY_RUNNING,progress=0.6666667, queryMaster=babokim-MacBook-Pro.local
      2014-06-30 16:18:27,992 INFO: org.apache.tajo.worker.TajoResourceAllocator (run(261)) - No available worker resource for eb_1404112701831_0001_000003
      

      Attachments

        Activity

          People

            hjkim Hyoungjun Kim
            hjkim Hyoungjun Kim
            Votes:
            0 Vote for this issue
            Watchers:
            3 Start watching this issue

            Dates

              Created:
              Updated:
              Resolved: