You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ambari.apache.org by on...@apache.org on 2014/07/16 18:09:21 UTC

[1/5] AMBARI-6507. Create mappers for models. (onechiporenko)

Repository: ambari
Updated Branches:
  refs/heads/trunk 8af0d0728 -> fca841856


http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/models/job.js
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/models/job.js b/contrib/views/jobs/src/main/resources/ui/app/scripts/models/job.js
deleted file mode 100644
index 39bfc3e..0000000
--- a/contrib/views/jobs/src/main/resources/ui/app/scripts/models/job.js
+++ /dev/null
@@ -1,69 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-App.Job = DS.Model.extend({
-
-  run: DS.belongsTo('App.Run'),
-
-  jobName: DS.attr('string'),
-
-  workflowEntityName: DS.attr('string'),
-
-  userName: DS.attr('string'),
-
-  confPath: DS.attr('string'),
-
-  submitTime: DS.attr('number'),
-
-  maps: DS.attr('number'),
-
-  reduces: DS.attr('number'),
-
-  status: DS.attr('string'),
-
-  input: DS.attr('number'),
-
-  output: DS.attr('number'),
-
-  elapsedTime: DS.attr('number'),
-
-  duration: function () {
-    return App.Helpers.date.timingFormat(parseInt(this.get('elapsedTime')));
-  }.property('elapsedTime'),
-
-  jobTimeLine: DS.attr('string'),
-
-  jobTaskView: DS.attr('string'),
-
-  /**
-   *  Sum of input bandwidth for all jobs with appropriate measure
-   */
-  inputFormatted: function () {
-    return App.Helpers.misc.formatBandwidth(this.get('input'));
-  }.property('input'),
-
-  /**
-   *  Sum of output bandwidth for all jobs with appropriate measure
-   */
-  outputFormatted: function () {
-    return App.Helpers.misc.formatBandwidth(this.get('output'));
-  }.property('output')
-
-});
-
-App.Job.FIXTURES = [];

http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/models/jobs/abstract_job.js
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/models/jobs/abstract_job.js b/contrib/views/jobs/src/main/resources/ui/app/scripts/models/jobs/abstract_job.js
index 94d02ca..ea74804 100644
--- a/contrib/views/jobs/src/main/resources/ui/app/scripts/models/jobs/abstract_job.js
+++ b/contrib/views/jobs/src/main/resources/ui/app/scripts/models/jobs/abstract_job.js
@@ -22,8 +22,6 @@
  */
 App.AbstractJob = DS.Model.extend({
 
-  id : DS.attr('string'),
-
   name : DS.attr('string'),
 
   user : DS.attr('string'),
@@ -52,9 +50,9 @@ App.AbstractJob = DS.Model.extend({
     var startTime = this.get('startTime');
     var endTime = this.get('endTime');
     if(endTime < startTime || endTime == undefined) {
-      endTime =  App.dateTime();
+      endTime =  new Date().getTime();
     }
-    return dateUtils.duration(startTime, endTime);
+    return App.Helpers.date.duration(startTime, endTime);
   }.property('startTime', 'endTime'),
 
   durationDisplay : function() {

http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/models/jobs/hive_job.js
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/models/jobs/hive_job.js b/contrib/views/jobs/src/main/resources/ui/app/scripts/models/jobs/hive_job.js
index 146b73a..a3784e8 100644
--- a/contrib/views/jobs/src/main/resources/ui/app/scripts/models/jobs/hive_job.js
+++ b/contrib/views/jobs/src/main/resources/ui/app/scripts/models/jobs/hive_job.js
@@ -25,7 +25,7 @@ App.HiveJob = App.AbstractJob.extend({
 
   hasTezDag: DS.attr('boolean'),
 
-  tezDag : DS.belongsTo('App.TezDag'),
+  tezDag : DS.belongsTo('tezDag', {async:true}),
 
   failed: DS.attr('boolean')
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/models/jobs/tez_dag.js
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/models/jobs/tez_dag.js b/contrib/views/jobs/src/main/resources/ui/app/scripts/models/jobs/tez_dag.js
index b8e13a3..71a42b6 100644
--- a/contrib/views/jobs/src/main/resources/ui/app/scripts/models/jobs/tez_dag.js
+++ b/contrib/views/jobs/src/main/resources/ui/app/scripts/models/jobs/tez_dag.js
@@ -17,8 +17,6 @@
 
 App.TezDag = DS.Model.extend({
 
-  id : DS.attr('string'),
-
   /**
    * When DAG is actually running on server, a unique ID is assigned.
    */
@@ -30,21 +28,19 @@ App.TezDag = DS.Model.extend({
 
   stage : DS.attr('string'),
 
-  vertices : DS.hasMany('App.TezDagVertex'),
+  vertices : DS.hasMany('tezDagVertex', {async:true}),
 
-  edges : DS.hasMany('App.TezDagEdge')
+  edges : DS.hasMany('tezDagEdge', {async:true})
 
 });
 
 App.TezDagEdge = DS.Model.extend({
 
-  id : DS.attr('string'),
-
   instanceId : DS.attr('string'),
 
-  fromVertex : DS.belongsTo('App.TezDagVertex'),
+  fromVertex : DS.belongsTo('tezDagVertex', {async:true}),
 
-  toVertex : DS.belongsTo('App.TezDagVertex'),
+  toVertex : DS.belongsTo('tezDagVertex', {async:true}),
 
   /**
    * Type of this edge connecting vertices. Should be one of constants defined
@@ -55,7 +51,6 @@ App.TezDagEdge = DS.Model.extend({
 
 App.TezDagVertex = DS.Model.extend({
 
-  id : DS.attr('string'),
   /**
    * When DAG vertex is actually running on server, a unique ID is assigned.
    */
@@ -78,12 +73,12 @@ App.TezDagVertex = DS.Model.extend({
   /**
    * A vertex can have multiple incoming edges.
    */
-  incomingEdges : DS.hasMany('App.TezDagEdge'),
+  incomingEdges : DS.hasMany('tezDagEdge', {async:true}),
 
   /**
    * This vertex can have multiple outgoing edges.
    */
-  outgoingEdges : DS.hasMany('App.TezDagEdge'),
+  outgoingEdges : DS.hasMany('tezDagEdge', {async:true}),
 
   startTime : DS.attr('number'),
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/models/run.js
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/models/run.js b/contrib/views/jobs/src/main/resources/ui/app/scripts/models/run.js
deleted file mode 100644
index a8422cb..0000000
--- a/contrib/views/jobs/src/main/resources/ui/app/scripts/models/run.js
+++ /dev/null
@@ -1,121 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-App.Run = DS.Model.extend({
-
-  appName: DS.attr('string'),
-
-  userName:DS.attr('string'),
-
-  numJobsTotal: DS.attr('number'),
-
-  numJobsCompleted: DS.attr('number'),
-
-  startTime:DS.attr('string'),
-
-  elapsedTime:DS.attr('string'),
-
-  workflowContext:DS.attr('string'),
-
-  input: DS.attr('number'),
-
-  output: DS.attr('number'),
-
-  loadAllJobs : false,
-
-  isStared: false,
-
-  isFiltered: false,
-
-  /**
-   * runId  short part
-   */
-  idFormatted: function() {
-    return this.get('id').substr(0, 20);
-  }.property('id'),
-
-  /**
-   * Jobs in the current run
-   */
-  jobs: function() {
-    return App.Job.find().filterProperty('run.id', this.get('id'));
-  }.property('loadAllJobs'),
-
-  /**
-   * Run duration
-   */
-  duration: function() {
-    return App.Helpers.date.timingFormat(parseInt(this.get('elapsedTime')));
-  }.property('elapsedTime'),
-
-  /**
-   * Status of running jobs
-   */
-  isRunning: function () {
-    return !this.get('numJobsTotal') == this.get('numJobsCompleted');
-  }.property('numJobsTotal', 'numJobsCompleted'),
-
-  /**
-   * Sum of input bandwidth for all jobs with appropriate measure
-   */
-  inputFormatted: function () {
-    var input = this.get('input');
-    input = App.Helpers.misc.formatBandwidth(input);
-    return input;
-  }.property('input'),
-
-  /**
-   *  Sum of output bandwidth for all jobs with appropriate measure
-   */
-  outputFormatted: function () {
-    var output = this.get('output');
-    output = App.Helpers.misc.formatBandwidth(output);
-    return output;
-  }.property('output'),
-
-  /**
-   *
-   */
-  lastUpdateTime: function() {
-    return parseInt(this.get('startTime')) + parseInt(this.get('elapsedTime'));
-  }.property('elapsedTime', 'startTime'),
-
-  /**
-   *
-   */
-  lastUpdateTimeFormatted: function() {
-    return App.Helpers.date.dateFormat(this.get('lastUpdateTime'));
-  }.property('lastUpdateTime'),
-
-  lastUpdateTimeFormattedShort: function(){
-    return App.Helpers.date.dateFormatShort(this.get('lastUpdateTime'));
-  }.property('lastUpdateTime'),
-
-  /**
-   * Type value based on first part of id
-   */
-  type: function() {
-    var id = this.get('id');
-    if(App.Helpers.string.startsWith(id, 'pig_')) return 'Pig';
-    if(App.Helpers.string.startsWith(id, 'hive_')) return 'Hive';
-    if(App.Helpers.string.startsWith(id, 'mr_')) return 'MapReduce';
-    return '';
-  }.property('id')
-});
-
-App.Run.FIXTURES = [];

http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/router.js
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/router.js b/contrib/views/jobs/src/main/resources/ui/app/scripts/router.js
index 15bd8dc..83df6bf 100644
--- a/contrib/views/jobs/src/main/resources/ui/app/scripts/router.js
+++ b/contrib/views/jobs/src/main/resources/ui/app/scripts/router.js
@@ -17,5 +17,6 @@
  */
 
 App.Router.map(function () {
-  // Add your routes here
+  this.resource("jobs", { path: "/" });
+  this.resource('job', { path: 'jobs/:job_id' });
 });

http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/routes/application_route.js
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/routes/application_route.js b/contrib/views/jobs/src/main/resources/ui/app/scripts/routes/application_route.js
index f6b9ec1..fa0e128 100644
--- a/contrib/views/jobs/src/main/resources/ui/app/scripts/routes/application_route.js
+++ b/contrib/views/jobs/src/main/resources/ui/app/scripts/routes/application_route.js
@@ -17,9 +17,29 @@
  */
 
 App.ApplicationRoute = Ember.Route.extend({
-  // admittedly, this should be in IndexRoute and not in the
-  // top level ApplicationRoute; we're in transition... :-)
+
   model: function () {
-    return ['red', 'yellow', 'blue'];
+    return this.modelFor('hiveJobs');
+  },
+
+  redirect: function () {
+    this.transitionTo('jobs');
   }
+
 });
+
+App.JobsRoute = Ember.Route.extend({
+
+  model: function () {
+    return this.store.all('hiveJob');
+  }
+
+});
+
+App.JobRoute = Ember.Route.extend({
+
+  model: function (params) {
+    return this.store.all('hiveJob', params.id);
+  }
+
+});
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/store.js
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/store.js b/contrib/views/jobs/src/main/resources/ui/app/scripts/store.js
index de7154b..6337e83 100644
--- a/contrib/views/jobs/src/main/resources/ui/app/scripts/store.js
+++ b/contrib/views/jobs/src/main/resources/ui/app/scripts/store.js
@@ -16,4 +16,4 @@
  * limitations under the License.
  */
 
-App.ApplicationAdapter = DS.FixtureAdapter;
+App.ApplicationAdapter = DS.FixtureAdapter.extend();


[2/5] AMBARI-6507. Create mappers for models. (onechiporenko)

Posted by on...@apache.org.
http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/hive-query-2.json
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/hive-query-2.json b/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/hive-query-2.json
new file mode 100644
index 0000000..90e6ccd
--- /dev/null
+++ b/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/hive-query-2.json
@@ -0,0 +1,8 @@
+{
+  "starttime": 1394569191001,
+  "otherinfo": {
+    "query": "{\"queryText\":\"select c_last_name, c_first_name, ca_city, bought_city,\\n                                 ss_ticket_number, amt, profit\\n                          from (select ss_ticket_number,\\n                                       ss_customer_sk,\\n                                       ca_city as bought_city,\\n                                       sum(ss_coupon_amt) as amt,\\n                                       sum(ss_net_profit) as profit\\n                                from store_sales, date_dim, store, household_demographics, customer_address\\n                                where store_sales.ss_sold_date_sk = date_dim.d_date_sk\\n                                  and store_sales.ss_store_sk = store.s_store_sk\\n                                  and store_sales.ss_hdemo_sk = household_demographics.hd_demo_sk\\n                                  and store_sales.ss_addr_sk = customer_address.ca_address_sk\\n                                  and (househo
 ld_demographics.hd_dep_count = 4\\n                                       or household_demographics.hd_vehicle_count= 3)\\n                                  and date_dim.d_dow in (6,0)\\n                                  and date_dim.d_year in (1999, 1999+1, 1999+2)\\n                                  and store.s_city in ('Fairview', 'Fairview', 'Fairview', 'Midway', 'Fairview')\\n                                group by ss_ticket_number, ss_customer_sk, ss_addr_sk, ca_city) dn,\\n                                customer, customer_address current_addr\\n                          where dn.ss_customer_sk = customer.c_customer_sk\\n                            and customer.c_current_addr_sk = current_addr.ca_address_sk\\n                            and current_addr.ca_city <> dn.bought_city\\n                          order by c_last_name, c_first_name, ca_city, bought_city, ss_ticket_number\\n                          limit 100\",\"queryPlan\":{\"STAGE PLANS\":{\"Stage-1\":{\"Tez\":{\"
 DagName:\":\"hrt_qa_20140311131919_1d932567-71c2-4341-9b50-6df1f58a9114:1\",\"Vertices:\":{\"Reducer 3\":{\"Reduce Operator Tree:\":{\"Group By Operator\":{\"mode:\":\"mergepartial\",\"aggregations:\":[\"sum(VALUE._col0)\",\"sum(VALUE._col1)\"],\"keys:\":\"KEY._col0 (type: int), KEY._col1 (type: int), KEY._col2 (type: int), KEY._col3 (type: string)\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\",\"_col3\",\"_col4\",\"_col5\"],\"children\":{\"Select Operator\":{\"expressions:\":\"_col0 (type: int), _col1 (type: int), _col3 (type: string), _col4 (type: decimal(17,2)), _col5 (type: decimal(17,2))\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\",\"_col3\",\"_col4\"],\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"_col1 (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"_col0 (type: int), _col1 (type: int), _col2 (type: string), _col3 (type: decimal(17,2)), _col4 (type: decimal(17,2))\",\"Statistics:\":\"Num rows: 16473 Data size: 21
 775806 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col1 (type: int)\"}},\"Statistics:\":\"Num rows: 16473 Data size: 21775806 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 16473 Data size: 21775806 Basic stats: COMPLETE Column stats: NONE\"}}},\"Map 1\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"filterExpr:\":\"((hd_dep_count = 4) or (hd_vehicle_count = 3)) (type: boolean)\",\"alias:\":\"household_demographics\",\"children\":{\"Filter Operator\":{\"predicate:\":\"((hd_dep_count = 4) or (hd_vehicle_count = 3)) (type: boolean)\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"hd_demo_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"hd_demo_sk (type: int), hd_dep_count (type: int), hd_vehicle_count (type: int)\",\"Statistics:\":\"Num rows: 7200 Data size: 770400 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"hd_demo_sk (type: int)\"}},\"St
 atistics:\":\"Num rows: 7200 Data size: 770400 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 7200 Data size: 770400 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 2\":{\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"store_sales\",\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"d_date_sk (type: int)\",\"0\":\"ss_sold_date_sk (type: int)\"},\"outputColumnNames:\":[\"_col0\",\"_col3\",\"_col5\",\"_col6\",\"_col8\",\"_col18\",\"_col21\",\"_col22\",\"_col25\",\"_col31\",\"_col32\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"UDFToDouble(s_store_sk) (type: double)\",\"0\":\"UDFToDouble(_col22) (type: double)\"},\"outputColumnNames:\":[\"_col0\",\"_col3\",\"_col5\",\"_col6\",\"_col8\",\"_col18\",\"_col21\",\"_col22\",\"_col25\",\"_col31\",\"_col32\",\"_col55\",\"_col77\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"hd_demo_sk (type: int)\",\"0\":\"_col5 (type: int)\"},\"outputColumnNames:\":[\"_col0\",\"_col22\",\"_col31
 \",\"_col34\",\"_col36\",\"_col37\",\"_col39\",\"_col49\",\"_col52\",\"_col53\",\"_col56\",\"_col62\",\"_col63\",\"_col86\",\"_col89\",\"_col90\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"ca_address_sk (type: int)\",\"0\":\"_col37 (type: int)\"},\"outputColumnNames:\":[\"_col0\",\"_col3\",\"_col4\",\"_col7\",\"_col29\",\"_col38\",\"_col41\",\"_col43\",\"_col44\",\"_col46\",\"_col56\",\"_col59\",\"_col60\",\"_col63\",\"_col69\",\"_col70\",\"_col93\",\"_col99\"],\"children\":{\"Filter Operator\":{\"predicate:\":\"((((((((_col38 = _col63) and (_col60 = _col7)) and (_col43 = _col0)) and (_col44 = _col93)) and ((_col3 = 4) or (_col4 = 3))) and (_col70) IN (6, 0)) and (_col69) IN (1999, (1999 + 1), (1999 + 2))) and (_col29) IN ('Fairview', 'Fairview', 'Fairview', 'Midway', 'Fairview')) (type: boolean)\",\"children\":{\"Select Operator\":{\"expressions:\":\"_col46 (type: int), _col41 (type: int), _col44 (type: int), _col99 (type: string), _col56 (type: decimal(7,2)), _col59 
 (type: decimal(7,2))\",\"outputColumnNames:\":[\"_col46\",\"_col41\",\"_col44\",\"_col99\",\"_col56\",\"_col59\"],\"children\":{\"Group By Operator\":{\"mode:\":\"hash\",\"aggregations:\":[\"sum(_col56)\",\"sum(_col59)\"],\"keys:\":\"_col46 (type: int), _col41 (type: int), _col44 (type: int), _col99 (type: string)\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\",\"_col3\",\"_col4\",\"_col5\"],\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"_col0 (type: int), _col1 (type: int), _col2 (type: int), _col3 (type: string)\",\"sort order:\":\"++++\",\"value expressions:\":\"_col4 (type: decimal(17,2)), _col5 (type: decimal(17,2))\",\"Statistics:\":\"Num rows: 32946 Data size: 43551613 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col0 (type: int), _col1 (type: int), _col2 (type: int), _col3 (type: string)\"}},\"Statistics:\":\"Num rows: 32946 Data size: 43551613 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows
 : 32946 Data size: 43551613 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 32946 Data size: 43551613 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 4217199 Data size: 5574753280 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{ca_address_sk} {ca_city}\",\"0\":\"{_col86} {_col89} {_col90} {_col0} {_col22} {_col31} {_col34} {_col36} {_col37} {_col39} {_col49} {_col52} {_col53} {_col56} {_col62} {_col63}\"}}},\"Statistics:\":\"Num rows: 3833817 Data size: 5067957248 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{hd_demo_sk} {hd_dep_count} {hd_vehicle_count}\",\"0\":\"{_col55} {_col77} {_col0} {_col3} {_col5} {_col6} {_col8} {_col18} {_col21} {_col22} {_col25} {_col31} {_col32}\"}}},\"Statistics:\":\"Num rows: 3485288 Data size: 4607233536 Basic stats: COMPLETE Column stats:
  NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{s_store_sk} {s_city}\",\"0\":\"{_col0} {_col3} {_col5} {_col6} {_col8} {_col18} {_col21} {_col22} {_col25} {_col31} {_col32}\"}}},\"Statistics:\":\"Num rows: 3168444 Data size: 4188394240 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{d_date_sk} {d_year} {d_dow}\",\"0\":\"{ss_sold_date_sk} {ss_customer_sk} {ss_hdemo_sk} {ss_addr_sk} {ss_ticket_number} {ss_coupon_amt} {ss_net_profit} {ss_store_sk}\"}}},\"Statistics:\":\"Num rows: 2880404 Data size: 3807631184 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 5\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"customer\",\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"c_customer_sk (type: int)\",\"0\":\"_col1 (type: int)\"},\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\",\"_col3\",\"_col4\",\"_col5\",\"
 _col9\",\"_col13\",\"_col14\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"ca_address_sk (type: int)\",\"0\":\"_col9 (type: int)\"},\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\",\"_col3\",\"_col4\",\"_col5\",\"_col9\",\"_col13\",\"_col14\",\"_col25\",\"_col31\"],\"children\":{\"Filter Operator\":{\"predicate:\":\"(((_col1 = _col5) and (_col9 = _col25)) and (_col31 <> _col2)) (type: boolean)\",\"children\":{\"Select Operator\":{\"expressions:\":\"_col14 (type: string), _col13 (type: string), _col31 (type: string), _col2 (type: string), _col0 (type: int), _col3 (type: decimal(17,2)), _col4 (type: decimal(17,2))\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\",\"_col3\",\"_col4\",\"_col5\",\"_col6\"],\"children\":{\"Reduce Output Operator\":{\"TopN Hash Memory Usage:\":\"0.04\",\"sort order:\":\"+++++\",\"value expressions:\":\"_col0 (type: string), _col1 (type: string), _col2 (type: string), _col3 (type: string), _col4 (type: int), _col5 (type: decimal(17,2)
 ), _col6 (type: decimal(17,2))\",\"Statistics:\":\"Num rows: 30250 Data size: 25902518 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col0 (type: string), _col1 (type: string), _col2 (type: string), _col3 (type: string), _col4 (type: int)\"}},\"Statistics:\":\"Num rows: 30250 Data size: 25902518 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 30250 Data size: 25902518 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 121000 Data size: 103610072 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{ca_address_sk} {ca_city}\",\"0\":\"{_col0} {_col1} {_col2} {_col3} {_col4} {_col5} {_col9} {_col13} {_col14}\"}}},\"Statistics:\":\"Num rows: 110000 Data size: 94190976 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{c_customer_sk} {c_current_addr_sk} {c_first_name} {
 c_last_name}\",\"0\":\"{_col0} {_col1} {_col2} {_col3} {_col4}\"}}},\"Statistics:\":\"Num rows: 100000 Data size: 85628164 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 4\":{\"Map Operator Tree:\":[{\"TableScan\":{\"filterExpr:\":\"((d_dow) IN (6, 0) and (d_year) IN (1999, (1999 + 1), (1999 + 2))) (type: boolean)\",\"alias:\":\"date_dim\",\"children\":{\"Filter Operator\":{\"predicate:\":\"((d_dow) IN (6, 0) and (d_year) IN (1999, (1999 + 1), (1999 + 2))) (type: boolean)\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"d_date_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"d_date_sk (type: int), d_year (type: int), d_dow (type: int)\",\"Statistics:\":\"Num rows: 18262 Data size: 20435178 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"d_date_sk (type: int)\"}},\"Statistics:\":\"Num rows: 18262 Data size: 20435178 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 73049 Data size: 81741831 B
 asic stats: COMPLETE Column stats: NONE\"}}]},\"Map 7\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"current_addr\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"ca_address_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"ca_address_sk (type: int), ca_city (type: string)\",\"Statistics:\":\"Num rows: 50000 Data size: 55975728 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"ca_address_sk (type: int)\"}},\"Statistics:\":\"Num rows: 50000 Data size: 55975728 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Reducer 6\":{\"Reduce Operator Tree:\":{\"Extract\":{\"children\":{\"Limit\":{\"children\":{\"File Output Operator\":{\"Statistics:\":\"Num rows: 100 Data size: 85600 Basic stats: COMPLETE Column stats: NONE\",\"compressed:\":\"false\",\"table:\":{\"serde:\":\"org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe\",\"input format:\":\"org.apache.hadoop.mapred.TextInputFormat\",\"
 output format:\":\"org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat\"}}},\"Statistics:\":\"Num rows: 100 Data size: 85600 Basic stats: COMPLETE Column stats: NONE\",\"Number of rows:\":\"100\"}},\"Statistics:\":\"Num rows: 30250 Data size: 25902518 Basic stats: COMPLETE Column stats: NONE\"}}},\"Map 9\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"filterExpr:\":\"(s_city) IN ('Fairview', 'Fairview', 'Fairview', 'Midway', 'Fairview') (type: boolean)\",\"alias:\":\"store\",\"children\":{\"Filter Operator\":{\"predicate:\":\"(s_city) IN ('Fairview', 'Fairview', 'Fairview', 'Midway', 'Fairview') (type: boolean)\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"UDFToDouble(s_store_sk) (type: double)\",\"sort order:\":\"+\",\"value expressions:\":\"s_store_sk (type: int), s_city (type: string)\",\"Statistics:\":\"Num rows: 6 Data size: 12816 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"UDFToDoubl
 e(s_store_sk) (type: double)\"}},\"Statistics:\":\"Num rows: 6 Data size: 12816 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 12 Data size: 25632 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 8\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"customer_address\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"ca_address_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"ca_address_sk (type: int), ca_city (type: string)\",\"Statistics:\":\"Num rows: 50000 Data size: 55975728 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"ca_address_sk (type: int)\"}},\"Statistics:\":\"Num rows: 50000 Data size: 55975728 Basic stats: COMPLETE Column stats: NONE\"}}]}},\"Edges:\":{\"Reducer 3\":{\"parent\":\"Map 2\",\"type\":\"SIMPLE_EDGE\"},\"Map 2\":[{\"parent\":\"Map 1\",\"type\":\"BROADCAST_EDGE\"},{\"parent\":\"Map 4\",\"type\":\"BROADCAST_EDGE\"},{\"parent\":\"M
 ap 8\",\"type\":\"BROADCAST_EDGE\"},{\"parent\":\"Map 9\",\"type\":\"BROADCAST_EDGE\"}],\"Map 5\":[{\"parent\":\"Reducer 3\",\"type\":\"BROADCAST_EDGE\"},{\"parent\":\"Map 7\",\"type\":\"BROADCAST_EDGE\"}],\"Reducer 6\":{\"parent\":\"Map 5\",\"type\":\"SIMPLE_EDGE\"}}}},\"Stage-0\":{\"Fetch Operator\":{\"limit:\":\"100\",\"Processor Tree:\":{\"ListSink\":{}}}}},\"STAGE DEPENDENCIES\":{\"Stage-1\":{\"ROOT STAGE\":\"TRUE\"},\"Stage-0\":{\"ROOT STAGE\":\"TRUE\"}}}}"
+  },
+  "entity": "hrt_qa_20140311131919_1d932567-71c2-4341-9b50-6df1f58a9114",
+  "entitytype": "HIVE_QUERY_ID"
+}

http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/tezDag-name-to-id.json
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/tezDag-name-to-id.json b/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/tezDag-name-to-id.json
new file mode 100644
index 0000000..c04d786
--- /dev/null
+++ b/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/tezDag-name-to-id.json
@@ -0,0 +1,552 @@
+{
+  "entities": [
+    {
+      "starttime": 1394569228227,
+      "events": [
+        {
+          "timestamp": 1394569303577,
+          "eventtype": "DAG_FINISHED",
+          "eventinfo": {}
+        },
+        {
+          "timestamp": 1394569229560,
+          "eventtype": "DAG_STARTED",
+          "eventinfo": {}
+        },
+        {
+          "timestamp": 1394569229460,
+          "eventtype": "DAG_INITIALIZED",
+          "eventinfo": {}
+        },
+        {
+          "timestamp": 1394569228227,
+          "eventtype": "DAG_SUBMITTED",
+          "eventinfo": {}
+        }
+      ],
+      "otherinfo": {
+        "startTime": 1394569229560,
+        "status": "FAILED",
+        "initTime": 1394569229460,
+        "timeTaken": 74017,
+        "dagPlan": {
+          "dagName": "hrt_qa_20140311131919_1d932567-71c2-4341-9b50-6df1f58a9114:1",
+          "version": 1,
+          "vertices": [
+            {
+              "vertexName": "Reducer 6",
+              "processorClass": "org.apache.hadoop.hive.ql.exec.tez.ReduceTezProcessor",
+              "inEdgeIds": [
+                "910557679"
+              ],
+              "additionalOutputs": [
+                {
+                  "name": "out_Reducer 6",
+                  "class": "org.apache.tez.mapreduce.output.MROutput"
+                }
+              ]
+            },
+            {
+              "vertexName": "Map 5",
+              "processorClass": "org.apache.hadoop.hive.ql.exec.tez.MapTezProcessor",
+              "inEdgeIds": [
+                "500242152",
+                "1208124175"
+              ],
+              "outEdgeIds": [
+                "910557679"
+              ],
+              "additionalInputs": [
+                {
+                  "name": "customer",
+                  "class": "org.apache.tez.mapreduce.input.MRInputLegacy",
+                  "initializer": "org.apache.tez.mapreduce.common.MRInputAMSplitGenerator"
+                }
+              ]
+            },
+            {
+              "vertexName": "Map 7",
+              "processorClass": "org.apache.hadoop.hive.ql.exec.tez.MapTezProcessor",
+              "outEdgeIds": [
+                "500242152"
+              ],
+              "additionalInputs": [
+                {
+                  "name": "current_addr",
+                  "class": "org.apache.tez.mapreduce.input.MRInputLegacy",
+                  "initializer": "org.apache.tez.mapreduce.common.MRInputAMSplitGenerator"
+                }
+              ]
+            },
+            {
+              "vertexName": "Reducer 3",
+              "processorClass": "org.apache.hadoop.hive.ql.exec.tez.ReduceTezProcessor",
+              "inEdgeIds": [
+                "654658809"
+              ],
+              "outEdgeIds": [
+                "1208124175"
+              ]
+            },
+            {
+              "vertexName": "Map 2",
+              "processorClass": "org.apache.hadoop.hive.ql.exec.tez.MapTezProcessor",
+              "inEdgeIds": [
+                "760294521",
+                "1982385791",
+                "813939446",
+                "1182578556"
+              ],
+              "outEdgeIds": [
+                "654658809"
+              ],
+              "additionalInputs": [
+                {
+                  "name": "store_sales",
+                  "class": "org.apache.tez.mapreduce.input.MRInputLegacy",
+                  "initializer": "org.apache.tez.mapreduce.common.MRInputAMSplitGenerator"
+                }
+              ]
+            },
+            {
+              "vertexName": "Map 9",
+              "processorClass": "org.apache.hadoop.hive.ql.exec.tez.MapTezProcessor",
+              "outEdgeIds": [
+                "760294521"
+              ],
+              "additionalInputs": [
+                {
+                  "name": "store",
+                  "class": "org.apache.tez.mapreduce.input.MRInputLegacy",
+                  "initializer": "org.apache.tez.mapreduce.common.MRInputAMSplitGenerator"
+                }
+              ]
+            },
+            {
+              "vertexName": "Map 8",
+              "processorClass": "org.apache.hadoop.hive.ql.exec.tez.MapTezProcessor",
+              "outEdgeIds": [
+                "1982385791"
+              ],
+              "additionalInputs": [
+                {
+                  "name": "customer_address",
+                  "class": "org.apache.tez.mapreduce.input.MRInputLegacy",
+                  "initializer": "org.apache.tez.mapreduce.common.MRInputAMSplitGenerator"
+                }
+              ]
+            },
+            {
+              "vertexName": "Map 4",
+              "processorClass": "org.apache.hadoop.hive.ql.exec.tez.MapTezProcessor",
+              "outEdgeIds": [
+                "813939446"
+              ],
+              "additionalInputs": [
+                {
+                  "name": "date_dim",
+                  "class": "org.apache.tez.mapreduce.input.MRInputLegacy",
+                  "initializer": "org.apache.tez.mapreduce.common.MRInputAMSplitGenerator"
+                }
+              ]
+            },
+            {
+              "vertexName": "Map 1",
+              "processorClass": "org.apache.hadoop.hive.ql.exec.tez.MapTezProcessor",
+              "outEdgeIds": [
+                "1182578556"
+              ],
+              "additionalInputs": [
+                {
+                  "name": "household_demographics",
+                  "class": "org.apache.tez.mapreduce.input.MRInputLegacy",
+                  "initializer": "org.apache.tez.mapreduce.common.MRInputAMSplitGenerator"
+                }
+              ]
+            }
+          ],
+          "edges": [
+            {
+              "edgeId": "760294521",
+              "inputVertexName": "Map 9",
+              "outputVertexName": "Map 2",
+              "dataMovementType": "BROADCAST",
+              "dataSourceType": "PERSISTED",
+              "schedulingType": "SEQUENTIAL",
+              "edgeSourceClass": "org.apache.tez.runtime.library.output.OnFileUnorderedKVOutput",
+              "edgeDestinationClass": "org.apache.tez.runtime.library.input.ShuffledUnorderedKVInput"
+            },
+            {
+              "edgeId": "1208124175",
+              "inputVertexName": "Reducer 3",
+              "outputVertexName": "Map 5",
+              "dataMovementType": "BROADCAST",
+              "dataSourceType": "PERSISTED",
+              "schedulingType": "SEQUENTIAL",
+              "edgeSourceClass": "org.apache.tez.runtime.library.output.OnFileUnorderedKVOutput",
+              "edgeDestinationClass": "org.apache.tez.runtime.library.input.ShuffledUnorderedKVInput"
+            },
+            {
+              "edgeId": "500242152",
+              "inputVertexName": "Map 7",
+              "outputVertexName": "Map 5",
+              "dataMovementType": "BROADCAST",
+              "dataSourceType": "PERSISTED",
+              "schedulingType": "SEQUENTIAL",
+              "edgeSourceClass": "org.apache.tez.runtime.library.output.OnFileUnorderedKVOutput",
+              "edgeDestinationClass": "org.apache.tez.runtime.library.input.ShuffledUnorderedKVInput"
+            },
+            {
+              "edgeId": "1182578556",
+              "inputVertexName": "Map 1",
+              "outputVertexName": "Map 2",
+              "dataMovementType": "BROADCAST",
+              "dataSourceType": "PERSISTED",
+              "schedulingType": "SEQUENTIAL",
+              "edgeSourceClass": "org.apache.tez.runtime.library.output.OnFileUnorderedKVOutput",
+              "edgeDestinationClass": "org.apache.tez.runtime.library.input.ShuffledUnorderedKVInput"
+            },
+            {
+              "edgeId": "910557679",
+              "inputVertexName": "Map 5",
+              "outputVertexName": "Reducer 6",
+              "dataMovementType": "SCATTER_GATHER",
+              "dataSourceType": "PERSISTED",
+              "schedulingType": "SEQUENTIAL",
+              "edgeSourceClass": "org.apache.tez.runtime.library.output.OnFileSortedOutput",
+              "edgeDestinationClass": "org.apache.tez.runtime.library.input.ShuffledMergedInputLegacy"
+            },
+            {
+              "edgeId": "813939446",
+              "inputVertexName": "Map 4",
+              "outputVertexName": "Map 2",
+              "dataMovementType": "BROADCAST",
+              "dataSourceType": "PERSISTED",
+              "schedulingType": "SEQUENTIAL",
+              "edgeSourceClass": "org.apache.tez.runtime.library.output.OnFileUnorderedKVOutput",
+              "edgeDestinationClass": "org.apache.tez.runtime.library.input.ShuffledUnorderedKVInput"
+            },
+            {
+              "edgeId": "654658809",
+              "inputVertexName": "Map 2",
+              "outputVertexName": "Reducer 3",
+              "dataMovementType": "SCATTER_GATHER",
+              "dataSourceType": "PERSISTED",
+              "schedulingType": "SEQUENTIAL",
+              "edgeSourceClass": "org.apache.tez.runtime.library.output.OnFileSortedOutput",
+              "edgeDestinationClass": "org.apache.tez.runtime.library.input.ShuffledMergedInputLegacy"
+            },
+            {
+              "edgeId": "1982385791",
+              "inputVertexName": "Map 8",
+              "outputVertexName": "Map 2",
+              "dataMovementType": "BROADCAST",
+              "dataSourceType": "PERSISTED",
+              "schedulingType": "SEQUENTIAL",
+              "edgeSourceClass": "org.apache.tez.runtime.library.output.OnFileUnorderedKVOutput",
+              "edgeDestinationClass": "org.apache.tez.runtime.library.input.ShuffledUnorderedKVInput"
+            }
+          ]
+        },
+        "endTime": 1394569303577,
+        "diagnostics": "Vertex re-running, vertexName=Map 7, vertexId=vertex_1394502141829_0425_1_02\nVertex re-running, vertexName=Map 2, vertexId=vertex_1394502141829_0425_1_04\nVertex re-running, vertexName=Map 9, vertexId=vertex_1394502141829_0425_1_05\nVertex re-running, vertexName=Map 1, vertexId=vertex_1394502141829_0425_1_08\nVertex re-running, vertexName=Map 4, vertexId=vertex_1394502141829_0425_1_07\nVertex re-running, vertexName=Map 8, vertexId=vertex_1394502141829_0425_1_06\nVertex re-running, vertexName=Reducer 3, vertexId=vertex_1394502141829_0425_1_03\nVertex failed, vertexName=Map 5, vertexId=vertex_1394502141829_0425_1_01, diagnostics=[Task failed, taskId=task_1394502141829_0425_1_01_000000, diagnostics=[AttemptID:attempt_1394502141829_0425_1_01_000000_0 Info:Error: java.lang.RuntimeException: org.apache.hadoop.hive.ql.metadata.HiveException: Hive Runtime Error while processing row \n\tat org.apache.hadoop.hive.ql.exec.tez.MapRecordProcessor.processRow(MapRecordProc
 essor.java:205)\n\tat org.apache.hadoop.hive.ql.exec.tez.MapRecordProcessor.run(MapRecordProcessor.java:171)\n\tat org.apache.hadoop.hive.ql.exec.tez.TezProcessor.run(TezProcessor.java:152)\n\tat org.apache.tez.runtime.LogicalIOProcessorRuntimeTask.run(LogicalIOProcessorRuntimeTask.java:306)\n\tat org.apache.hadoop.mapred.YarnTezDagChild$4.run(YarnTezDagChild.java:526)\n\tat java.security.AccessController.doPrivileged(Native Method)\n\tat javax.security.auth.Subject.doAs(Subject.java:415)\n\tat org.apache.hadoop.security.UserGroupInformation.doAs(UserGroupInformation.java:1548)\n\tat org.apache.hadoop.mapred.YarnTezDagChild.main(YarnTezDagChild.java:515)\nCaused by: org.apache.hadoop.hive.ql.metadata.HiveException: Hive Runtime Error while processing row \n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapOperator.process(VectorMapOperator.java:45)\n\tat org.apache.hadoop.hive.ql.exec.tez.MapRecordProcessor.processRow(MapRecordProcessor.java:193)\n\t... 8 more\nCaused by: java.lan
 g.ClassCastException: org.apache.hadoop.hive.ql.exec.vector.LongColumnVector cannot be cast to org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector\n\tat org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriterFactory$VectorExpressionWriterBytes.writeValue(VectorExpressionWriterFactory.java:268)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator.populatedCachedDistributionKeys(VectorReduceSinkOperator.java:335)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator.processOp(VectorReduceSinkOperator.java:237)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator.processOp(VectorSelectOperator.java:129)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorFilterOperator.processOp(VectorFilterOperator.java:102)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\
 n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.flushOutput(VectorMapJoinOperator.java:249)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.internalForward(VectorMapJoinOperator.java:244)\n\tat org.apache.hadoop.hive.ql.exec.CommonJoinOperator.genAllOneUniqueJoinObject(CommonJoinOperator.java:670)\n\tat org.apache.hadoop.hive.ql.exec.CommonJoinOperator.checkAndGenObject(CommonJoinOperator.java:754)\n\tat org.apache.hadoop.hive.ql.exec.MapJoinOperator.processOp(MapJoinOperator.java:215)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.processOp(VectorMapJoinOperator.java:292)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.flushOutput(VectorMapJoinOperator.java:249)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.internalForward(VectorMapJoinOperator.java:244)\n\tat org.apache.hadoop.hive.ql.exec.CommonJoinOperator.genAllOne
 UniqueJoinObject(CommonJoinOperator.java:670)\n\tat org.apache.hadoop.hive.ql.exec.CommonJoinOperator.checkAndGenObject(CommonJoinOperator.java:754)\n\tat org.apache.hadoop.hive.ql.exec.MapJoinOperator.processOp(MapJoinOperator.java:215)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.processOp(VectorMapJoinOperator.java:292)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.TableScanOperator.processOp(TableScanOperator.java:92)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapOperator.process(VectorMapOperator.java:43)\n\t... 9 more\n\nContainer released by application, AttemptID:attempt_1394502141829_0425_1_01_000000_1 Info:Error: java.lang.RuntimeException: org.apache.hadoop.hive.ql.metadata.HiveException: Hive Runtime Error while processing row \n\tat org.apache.hadoop.hive.ql.exec.tez.MapRecordProcessor.processRow(MapRecordPr
 ocessor.java:205)\n\tat org.apache.hadoop.hive.ql.exec.tez.MapRecordProcessor.run(MapRecordProcessor.java:171)\n\tat org.apache.hadoop.hive.ql.exec.tez.TezProcessor.run(TezProcessor.java:152)\n\tat org.apache.tez.runtime.LogicalIOProcessorRuntimeTask.run(LogicalIOProcessorRuntimeTask.java:306)\n\tat org.apache.hadoop.mapred.YarnTezDagChild$4.run(YarnTezDagChild.java:526)\n\tat java.security.AccessController.doPrivileged(Native Method)\n\tat javax.security.auth.Subject.doAs(Subject.java:415)\n\tat org.apache.hadoop.security.UserGroupInformation.doAs(UserGroupInformation.java:1548)\n\tat org.apache.hadoop.mapred.YarnTezDagChild.main(YarnTezDagChild.java:515)\nCaused by: org.apache.hadoop.hive.ql.metadata.HiveException: Hive Runtime Error while processing row \n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapOperator.process(VectorMapOperator.java:45)\n\tat org.apache.hadoop.hive.ql.exec.tez.MapRecordProcessor.processRow(MapRecordProcessor.java:193)\n\t... 8 more\nCaused by: java.l
 ang.ClassCastException: org.apache.hadoop.hive.ql.exec.vector.LongColumnVector cannot be cast to org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector\n\tat org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriterFactory$VectorExpressionWriterBytes.writeValue(VectorExpressionWriterFactory.java:268)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator.populatedCachedDistributionKeys(VectorReduceSinkOperator.java:335)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator.processOp(VectorReduceSinkOperator.java:237)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator.processOp(VectorSelectOperator.java:129)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorFilterOperator.processOp(VectorFilterOperator.java:102)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791
 )\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.flushOutput(VectorMapJoinOperator.java:249)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.internalForward(VectorMapJoinOperator.java:244)\n\tat org.apache.hadoop.hive.ql.exec.CommonJoinOperator.genAllOneUniqueJoinObject(CommonJoinOperator.java:670)\n\tat org.apache.hadoop.hive.ql.exec.CommonJoinOperator.checkAndGenObject(CommonJoinOperator.java:754)\n\tat org.apache.hadoop.hive.ql.exec.MapJoinOperator.processOp(MapJoinOperator.java:215)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.processOp(VectorMapJoinOperator.java:292)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.flushOutput(VectorMapJoinOperator.java:249)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.internalForward(VectorMapJoinOperator.java:244)\n\tat org.apache.hadoop.hive.ql.exec.CommonJoinOperator.genAllO
 neUniqueJoinObject(CommonJoinOperator.java:670)\n\tat org.apache.hadoop.hive.ql.exec.CommonJoinOperator.checkAndGenObject(CommonJoinOperator.java:754)\n\tat org.apache.hadoop.hive.ql.exec.MapJoinOperator.processOp(MapJoinOperator.java:215)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.processOp(VectorMapJoinOperator.java:292)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.TableScanOperator.processOp(TableScanOperator.java:92)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapOperator.process(VectorMapOperator.java:43)\n\t... 9 more\n\nContainer released by application, AttemptID:attempt_1394502141829_0425_1_01_000000_2 Info:Error: java.lang.RuntimeException: org.apache.hadoop.hive.ql.metadata.HiveException: Hive Runtime Error while processing row \n\tat org.apache.hadoop.hive.ql.exec.tez.MapRecordProcessor.processRow(MapRecord
 Processor.java:205)\n\tat org.apache.hadoop.hive.ql.exec.tez.MapRecordProcessor.run(MapRecordProcessor.java:171)\n\tat org.apache.hadoop.hive.ql.exec.tez.TezProcessor.run(TezProcessor.java:152)\n\tat org.apache.tez.runtime.LogicalIOProcessorRuntimeTask.run(LogicalIOProcessorRuntimeTask.java:306)\n\tat org.apache.hadoop.mapred.YarnTezDagChild$4.run(YarnTezDagChild.java:526)\n\tat java.security.AccessController.doPrivileged(Native Method)\n\tat javax.security.auth.Subject.doAs(Subject.java:415)\n\tat org.apache.hadoop.security.UserGroupInformation.doAs(UserGroupInformation.java:1548)\n\tat org.apache.hadoop.mapred.YarnTezDagChild.main(YarnTezDagChild.java:515)\nCaused by: org.apache.hadoop.hive.ql.metadata.HiveException: Hive Runtime Error while processing row \n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapOperator.process(VectorMapOperator.java:45)\n\tat org.apache.hadoop.hive.ql.exec.tez.MapRecordProcessor.processRow(MapRecordProcessor.java:193)\n\t... 8 more\nCaused by: java
 .lang.ClassCastException: org.apache.hadoop.hive.ql.exec.vector.LongColumnVector cannot be cast to org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector\n\tat org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriterFactory$VectorExpressionWriterBytes.writeValue(VectorExpressionWriterFactory.java:268)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator.populatedCachedDistributionKeys(VectorReduceSinkOperator.java:335)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator.processOp(VectorReduceSinkOperator.java:237)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator.processOp(VectorSelectOperator.java:129)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorFilterOperator.processOp(VectorFilterOperator.java:102)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:7
 91)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.flushOutput(VectorMapJoinOperator.java:249)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.internalForward(VectorMapJoinOperator.java:244)\n\tat org.apache.hadoop.hive.ql.exec.CommonJoinOperator.genAllOneUniqueJoinObject(CommonJoinOperator.java:670)\n\tat org.apache.hadoop.hive.ql.exec.CommonJoinOperator.checkAndGenObject(CommonJoinOperator.java:754)\n\tat org.apache.hadoop.hive.ql.exec.MapJoinOperator.processOp(MapJoinOperator.java:215)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.processOp(VectorMapJoinOperator.java:292)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.flushOutput(VectorMapJoinOperator.java:249)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.internalForward(VectorMapJoinOperator.java:244)\n\tat org.apache.hadoop.hive.ql.exec.CommonJoinOperator.genAl
 lOneUniqueJoinObject(CommonJoinOperator.java:670)\n\tat org.apache.hadoop.hive.ql.exec.CommonJoinOperator.checkAndGenObject(CommonJoinOperator.java:754)\n\tat org.apache.hadoop.hive.ql.exec.MapJoinOperator.processOp(MapJoinOperator.java:215)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.processOp(VectorMapJoinOperator.java:292)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.TableScanOperator.processOp(TableScanOperator.java:92)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapOperator.process(VectorMapOperator.java:43)\n\t... 9 more\n\nContainer released by application, AttemptID:attempt_1394502141829_0425_1_01_000000_3 Info:Error: java.lang.RuntimeException: org.apache.hadoop.hive.ql.metadata.HiveException: Hive Runtime Error while processing row \n\tat org.apache.hadoop.hive.ql.exec.tez.MapRecordProcessor.processRow(MapReco
 rdProcessor.java:205)\n\tat org.apache.hadoop.hive.ql.exec.tez.MapRecordProcessor.run(MapRecordProcessor.java:171)\n\tat org.apache.hadoop.hive.ql.exec.tez.TezProcessor.run(TezProcessor.java:152)\n\tat org.apache.tez.runtime.LogicalIOProcessorRuntimeTask.run(LogicalIOProcessorRuntimeTask.java:306)\n\tat org.apache.hadoop.mapred.YarnTezDagChild$4.run(YarnTezDagChild.java:526)\n\tat java.security.AccessController.doPrivileged(Native Method)\n\tat javax.security.auth.Subject.doAs(Subject.java:415)\n\tat org.apache.hadoop.security.UserGroupInformation.doAs(UserGroupInformation.java:1548)\n\tat org.apache.hadoop.mapred.YarnTezDagChild.main(YarnTezDagChild.java:515)\nCaused by: org.apache.hadoop.hive.ql.metadata.HiveException: Hive Runtime Error while processing row \n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapOperator.process(VectorMapOperator.java:45)\n\tat org.apache.hadoop.hive.ql.exec.tez.MapRecordProcessor.processRow(MapRecordProcessor.java:193)\n\t... 8 more\nCaused by: ja
 va.lang.ClassCastException: org.apache.hadoop.hive.ql.exec.vector.LongColumnVector cannot be cast to org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector\n\tat org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriterFactory$VectorExpressionWriterBytes.writeValue(VectorExpressionWriterFactory.java:268)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator.populatedCachedDistributionKeys(VectorReduceSinkOperator.java:335)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator.processOp(VectorReduceSinkOperator.java:237)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator.processOp(VectorSelectOperator.java:129)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorFilterOperator.processOp(VectorFilterOperator.java:102)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java
 :791)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.flushOutput(VectorMapJoinOperator.java:249)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.internalForward(VectorMapJoinOperator.java:244)\n\tat org.apache.hadoop.hive.ql.exec.CommonJoinOperator.genAllOneUniqueJoinObject(CommonJoinOperator.java:670)\n\tat org.apache.hadoop.hive.ql.exec.CommonJoinOperator.checkAndGenObject(CommonJoinOperator.java:754)\n\tat org.apache.hadoop.hive.ql.exec.MapJoinOperator.processOp(MapJoinOperator.java:215)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.processOp(VectorMapJoinOperator.java:292)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.flushOutput(VectorMapJoinOperator.java:249)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.internalForward(VectorMapJoinOperator.java:244)\n\tat org.apache.hadoop.hive.ql.exec.CommonJoinOperator.gen
 AllOneUniqueJoinObject(CommonJoinOperator.java:670)\n\tat org.apache.hadoop.hive.ql.exec.CommonJoinOperator.checkAndGenObject(CommonJoinOperator.java:754)\n\tat org.apache.hadoop.hive.ql.exec.MapJoinOperator.processOp(MapJoinOperator.java:215)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator.processOp(VectorMapJoinOperator.java:292)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.TableScanOperator.processOp(TableScanOperator.java:92)\n\tat org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:791)\n\tat org.apache.hadoop.hive.ql.exec.vector.VectorMapOperator.process(VectorMapOperator.java:43)\n\t... 9 more\n], Vertex failed as one or more tasks failed. failedTasks:1]\nVertex killed, vertexName=Reducer 6, vertexId=vertex_1394502141829_0425_1_00, diagnostics=[Vertex received Kill while in RUNNING state., Vertex killed as other vertex failed. failedTasks:0]\nVertex killed, vertexName=Map 2, vertexId=
 vertex_1394502141829_0425_1_04, diagnostics=[Vertex received Kill while in RUNNING state., Vertex killed as other vertex failed. failedTasks:0]\nDAG failed due to vertex failure. failedVertices:1 killedVertices:2",
+        "counters": {
+          "counterGroups": [
+            {
+              "counterGroupName": "org.apache.tez.common.counters.DAGCounter",
+              "counterGroupDisplayName": "org.apache.tez.common.counters.DAGCounter",
+              "counters": [
+                {
+                  "counterName": "NUM_FAILED_TASKS",
+                  "counterDisplayName": "NUM_FAILED_TASKS",
+                  "counterValue": 4
+                },
+                {
+                  "counterName": "NUM_KILLED_TASKS",
+                  "counterDisplayName": "NUM_KILLED_TASKS",
+                  "counterValue": 14
+                },
+                {
+                  "counterName": "TOTAL_LAUNCHED_TASKS",
+                  "counterDisplayName": "TOTAL_LAUNCHED_TASKS",
+                  "counterValue": 28
+                },
+                {
+                  "counterName": "DATA_LOCAL_TASKS",
+                  "counterDisplayName": "DATA_LOCAL_TASKS",
+                  "counterValue": 9
+                }
+              ]
+            },
+            {
+              "counterGroupName": "org.apache.tez.common.counters.FileSystemCounter",
+              "counterGroupDisplayName": "File System Counters",
+              "counters": [
+                {
+                  "counterName": "FILE_BYTES_READ",
+                  "counterDisplayName": "FILE: BYTES_READ",
+                  "counterValue": 503348
+                },
+                {
+                  "counterName": "FILE_BYTES_WRITTEN",
+                  "counterDisplayName": "FILE: BYTES_WRITTEN",
+                  "counterValue": 4315294
+                },
+                {
+                  "counterName": "FILE_READ_OPS",
+                  "counterDisplayName": "FILE: READ_OPS",
+                  "counterValue": 0
+                },
+                {
+                  "counterName": "FILE_LARGE_READ_OPS",
+                  "counterDisplayName": "FILE: LARGE_READ_OPS",
+                  "counterValue": 0
+                },
+                {
+                  "counterName": "FILE_WRITE_OPS",
+                  "counterDisplayName": "FILE: WRITE_OPS",
+                  "counterValue": 0
+                },
+                {
+                  "counterName": "HDFS_BYTES_READ",
+                  "counterDisplayName": "HDFS: BYTES_READ",
+                  "counterValue": 13041650
+                },
+                {
+                  "counterName": "HDFS_BYTES_WRITTEN",
+                  "counterDisplayName": "HDFS: BYTES_WRITTEN",
+                  "counterValue": 0
+                },
+                {
+                  "counterName": "HDFS_READ_OPS",
+                  "counterDisplayName": "HDFS: READ_OPS",
+                  "counterValue": 27
+                },
+                {
+                  "counterName": "HDFS_LARGE_READ_OPS",
+                  "counterDisplayName": "HDFS: LARGE_READ_OPS",
+                  "counterValue": 0
+                },
+                {
+                  "counterName": "HDFS_WRITE_OPS",
+                  "counterDisplayName": "HDFS: WRITE_OPS",
+                  "counterValue": 0
+                }
+              ]
+            },
+            {
+              "counterGroupName": "org.apache.tez.common.counters.TaskCounter",
+              "counterGroupDisplayName": "org.apache.tez.common.counters.TaskCounter",
+              "counters": [
+                {
+                  "counterName": "REDUCE_INPUT_GROUPS",
+                  "counterDisplayName": "REDUCE_INPUT_GROUPS",
+                  "counterValue": 10730
+                },
+                {
+                  "counterName": "REDUCE_INPUT_RECORDS",
+                  "counterDisplayName": "REDUCE_INPUT_RECORDS",
+                  "counterValue": 10731
+                },
+                {
+                  "counterName": "COMBINE_INPUT_RECORDS",
+                  "counterDisplayName": "COMBINE_INPUT_RECORDS",
+                  "counterValue": 0
+                },
+                {
+                  "counterName": "SPILLED_RECORDS",
+                  "counterDisplayName": "SPILLED_RECORDS",
+                  "counterValue": 17925
+                },
+                {
+                  "counterName": "NUM_SHUFFLED_INPUTS",
+                  "counterDisplayName": "NUM_SHUFFLED_INPUTS",
+                  "counterValue": 22
+                },
+                {
+                  "counterName": "NUM_FAILED_SHUFFLE_INPUTS",
+                  "counterDisplayName": "NUM_FAILED_SHUFFLE_INPUTS",
+                  "counterValue": 0
+                },
+                {
+                  "counterName": "MERGED_MAP_OUTPUTS",
+                  "counterDisplayName": "MERGED_MAP_OUTPUTS",
+                  "counterValue": 6
+                },
+                {
+                  "counterName": "GC_TIME_MILLIS",
+                  "counterDisplayName": "GC_TIME_MILLIS",
+                  "counterValue": 2402
+                },
+                {
+                  "counterName": "CPU_MILLISECONDS",
+                  "counterDisplayName": "CPU_MILLISECONDS",
+                  "counterValue": -33880
+                },
+                {
+                  "counterName": "PHYSICAL_MEMORY_BYTES",
+                  "counterDisplayName": "PHYSICAL_MEMORY_BYTES",
+                  "counterValue": 3241504768
+                },
+                {
+                  "counterName": "VIRTUAL_MEMORY_BYTES",
+                  "counterDisplayName": "VIRTUAL_MEMORY_BYTES",
+                  "counterValue": 17864921088
+                },
+                {
+                  "counterName": "COMMITTED_HEAP_BYTES",
+                  "counterDisplayName": "COMMITTED_HEAP_BYTES",
+                  "counterValue": 2839543808
+                },
+                {
+                  "counterName": "INPUT_RECORDS_PROCESSED",
+                  "counterDisplayName": "INPUT_RECORDS_PROCESSED",
+                  "counterValue": 2063651
+                },
+                {
+                  "counterName": "OUTPUT_RECORDS",
+                  "counterDisplayName": "OUTPUT_RECORDS",
+                  "counterValue": 120051
+                },
+                {
+                  "counterName": "OUTPUT_BYTES",
+                  "counterDisplayName": "OUTPUT_BYTES",
+                  "counterValue": 3571464
+                },
+                {
+                  "counterName": "OUTPUT_BYTES_WITH_OVERHEAD",
+                  "counterDisplayName": "OUTPUT_BYTES_WITH_OVERHEAD",
+                  "counterValue": 3811586
+                },
+                {
+                  "counterName": "OUTPUT_BYTES_PHYSICAL",
+                  "counterDisplayName": "OUTPUT_BYTES_PHYSICAL",
+                  "counterValue": 3811626
+                },
+                {
+                  "counterName": "ADDITIONAL_SPILLS_BYTES_WRITTEN",
+                  "counterDisplayName": "ADDITIONAL_SPILLS_BYTES_WRITTEN",
+                  "counterValue": 503348
+                },
+                {
+                  "counterName": "ADDITIONAL_SPILLS_BYTES_READ",
+                  "counterDisplayName": "ADDITIONAL_SPILLS_BYTES_READ",
+                  "counterValue": 503348
+                },
+                {
+                  "counterName": "ADDITIONAL_SPILL_COUNT",
+                  "counterDisplayName": "ADDITIONAL_SPILL_COUNT",
+                  "counterValue": 0
+                },
+                {
+                  "counterName": "SHUFFLE_BYTES",
+                  "counterDisplayName": "SHUFFLE_BYTES",
+                  "counterValue": 6627422
+                },
+                {
+                  "counterName": "SHUFFLE_BYTES_DECOMPRESSED",
+                  "counterDisplayName": "SHUFFLE_BYTES_DECOMPRESSED",
+                  "counterValue": 6627334
+                },
+                {
+                  "counterName": "SHUFFLE_BYTES_TO_MEM",
+                  "counterDisplayName": "SHUFFLE_BYTES_TO_MEM",
+                  "counterValue": 6627422
+                },
+                {
+                  "counterName": "SHUFFLE_BYTES_TO_DISK",
+                  "counterDisplayName": "SHUFFLE_BYTES_TO_DISK",
+                  "counterValue": 0
+                },
+                {
+                  "counterName": "NUM_MEM_TO_DISK_MERGES",
+                  "counterDisplayName": "NUM_MEM_TO_DISK_MERGES",
+                  "counterValue": 0
+                },
+                {
+                  "counterName": "NUM_DISK_TO_DISK_MERGES",
+                  "counterDisplayName": "NUM_DISK_TO_DISK_MERGES",
+                  "counterValue": 0
+                }
+              ]
+            },
+            {
+              "counterGroupName": "Shuffle Errors",
+              "counterGroupDisplayName": "Shuffle Errors",
+              "counters": [
+                {
+                  "counterName": "BAD_ID",
+                  "counterDisplayName": "BAD_ID",
+                  "counterValue": 0
+                },
+                {
+                  "counterName": "CONNECTION",
+                  "counterDisplayName": "CONNECTION",
+                  "counterValue": 0
+                },
+                {
+                  "counterName": "IO_ERROR",
+                  "counterDisplayName": "IO_ERROR",
+                  "counterValue": 0
+                },
+                {
+                  "counterName": "WRONG_LENGTH",
+                  "counterDisplayName": "WRONG_LENGTH",
+                  "counterValue": 0
+                },
+                {
+                  "counterName": "WRONG_MAP",
+                  "counterDisplayName": "WRONG_MAP",
+                  "counterValue": 0
+                },
+                {
+                  "counterName": "WRONG_REDUCE",
+                  "counterDisplayName": "WRONG_REDUCE",
+                  "counterValue": 0
+                }
+              ]
+            },
+            {
+              "counterGroupName": "org.apache.hadoop.hive.ql.exec.FilterOperator$Counter",
+              "counterGroupDisplayName": "org.apache.hadoop.hive.ql.exec.FilterOperator$Counter",
+              "counters": [
+                {
+                  "counterName": "FILTERED",
+                  "counterDisplayName": "FILTERED",
+                  "counterValue": 72735
+                },
+                {
+                  "counterName": "PASSED",
+                  "counterDisplayName": "PASSED",
+                  "counterValue": 96225
+                }
+              ]
+            },
+            {
+              "counterGroupName": "org.apache.hadoop.hive.ql.exec.MapOperator$Counter",
+              "counterGroupDisplayName": "org.apache.hadoop.hive.ql.exec.MapOperator$Counter",
+              "counters": [
+                {
+                  "counterName": "DESERIALIZE_ERRORS",
+                  "counterDisplayName": "DESERIALIZE_ERRORS",
+                  "counterValue": 0
+                }
+              ]
+            }
+          ]
+        }
+      },
+      "primaryfilters": {
+        "dagName": [
+          "hrt_qa_20140311131919_1d932567-71c2-4341-9b50-6df1f58a9114:1"
+        ],
+        "user": [
+          "hrt_qa"
+        ]
+      },
+      "entity": "dag_1394502141829_0425_1",
+      "entitytype": "TEZ_DAG_ID",
+      "relatedentities": {}
+    }
+  ]
+}

http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/tezDag.json
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/tezDag.json b/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/tezDag.json
new file mode 100644
index 0000000..dc60966
--- /dev/null
+++ b/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/tezDag.json
@@ -0,0 +1,21 @@
+{
+  "starttime": 1394569228227,
+  "entity": "dag_1394502141829_0425_1",
+  "entitytype": "TEZ_DAG_ID",
+  "relatedentities": {
+    "TEZ_VERTEX_ID": [
+      "vertex_1394502141829_0425_1_00",
+      "vertex_1394502141829_0425_1_01",
+      "vertex_1394502141829_0425_1_02",
+      "vertex_1394502141829_0425_1_03",
+      "vertex_1394502141829_0425_1_04",
+      "vertex_1394502141829_0425_1_05",
+      "vertex_1394502141829_0425_1_06",
+      "vertex_1394502141829_0425_1_07",
+      "vertex_1394502141829_0425_1_08"
+    ]
+  },
+  "otherinfo": {
+    "applicationId": "application_1395263571423_0014"
+  }
+}

http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/tezDagVertex.json
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/tezDagVertex.json b/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/tezDagVertex.json
new file mode 100644
index 0000000..9946238
--- /dev/null
+++ b/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/tezDagVertex.json
@@ -0,0 +1,221 @@
+{
+  "starttime": 1394569231815,
+  "otherinfo": {
+    "startTime": 1394569231819,
+    "status": "KILLED",
+    "numTasks": 6,
+    "initTime": 1394569231815,
+    "vertexName": "Map 2",
+    "timeTaken": 71735,
+    "processorClassName": "org.apache.hadoop.hive.ql.exec.tez.MapTezProcessor",
+    "endTime": 1394569303554,
+    "initRequestedTime": 1394569230142,
+    "counters": {
+      "counterGroups": [
+        {
+          "counterGroupName": "org.apache.tez.common.counters.DAGCounter",
+          "counterGroupDisplayName": "org.apache.tez.common.counters.DAGCounter",
+          "counters": [
+            {
+              "counterName": "DATA_LOCAL_TASKS",
+              "counterDisplayName": "DATA_LOCAL_TASKS",
+              "counterValue": 4
+            }
+          ]
+        },
+        {
+          "counterGroupName": "org.apache.tez.common.counters.FileSystemCounter",
+          "counterGroupDisplayName": "File System Counters",
+          "counters": [
+            {
+              "counterName": "FILE_BYTES_READ",
+              "counterDisplayName": "FILE: BYTES_READ",
+              "counterValue": 0
+            },
+            {
+              "counterName": "FILE_BYTES_WRITTEN",
+              "counterDisplayName": "FILE: BYTES_WRITTEN",
+              "counterValue": 337559
+            },
+            {
+              "counterName": "FILE_READ_OPS",
+              "counterDisplayName": "FILE: READ_OPS",
+              "counterValue": 0
+            },
+            {
+              "counterName": "FILE_LARGE_READ_OPS",
+              "counterDisplayName": "FILE: LARGE_READ_OPS",
+              "counterValue": 0
+            },
+            {
+              "counterName": "FILE_WRITE_OPS",
+              "counterDisplayName": "FILE: WRITE_OPS",
+              "counterValue": 0
+            },
+            {
+              "counterName": "HDFS_BYTES_READ",
+              "counterDisplayName": "HDFS: BYTES_READ",
+              "counterValue": 12854749
+            },
+            {
+              "counterName": "HDFS_BYTES_WRITTEN",
+              "counterDisplayName": "HDFS: BYTES_WRITTEN",
+              "counterValue": 0
+            },
+            {
+              "counterName": "HDFS_READ_OPS",
+              "counterDisplayName": "HDFS: READ_OPS",
+              "counterValue": 12
+            },
+            {
+              "counterName": "HDFS_LARGE_READ_OPS",
+              "counterDisplayName": "HDFS: LARGE_READ_OPS",
+              "counterValue": 0
+            },
+            {
+              "counterName": "HDFS_WRITE_OPS",
+              "counterDisplayName": "HDFS: WRITE_OPS",
+              "counterValue": 0
+            }
+          ]
+        },
+        {
+          "counterGroupName": "org.apache.tez.common.counters.TaskCounter",
+          "counterGroupDisplayName": "org.apache.tez.common.counters.TaskCounter",
+          "counters": [
+            {
+              "counterName": "SPILLED_RECORDS",
+              "counterDisplayName": "SPILLED_RECORDS",
+              "counterValue": 7194
+            },
+            {
+              "counterName": "NUM_SHUFFLED_INPUTS",
+              "counterDisplayName": "NUM_SHUFFLED_INPUTS",
+              "counterValue": 16
+            },
+            {
+              "counterName": "NUM_FAILED_SHUFFLE_INPUTS",
+              "counterDisplayName": "NUM_FAILED_SHUFFLE_INPUTS",
+              "counterValue": 0
+            },
+            {
+              "counterName": "GC_TIME_MILLIS",
+              "counterDisplayName": "GC_TIME_MILLIS",
+              "counterValue": 2047
+            },
+            {
+              "counterName": "CPU_MILLISECONDS",
+              "counterDisplayName": "CPU_MILLISECONDS",
+              "counterValue": -11970
+            },
+            {
+              "counterName": "PHYSICAL_MEMORY_BYTES",
+              "counterDisplayName": "PHYSICAL_MEMORY_BYTES",
+              "counterValue": 1791279104
+            },
+            {
+              "counterName": "VIRTUAL_MEMORY_BYTES",
+              "counterDisplayName": "VIRTUAL_MEMORY_BYTES",
+              "counterValue": 7152783360
+            },
+            {
+              "counterName": "COMMITTED_HEAP_BYTES",
+              "counterDisplayName": "COMMITTED_HEAP_BYTES",
+              "counterValue": 1588592640
+            },
+            {
+              "counterName": "INPUT_RECORDS_PROCESSED",
+              "counterDisplayName": "INPUT_RECORDS_PROCESSED",
+              "counterValue": 1990495
+            },
+            {
+              "counterName": "OUTPUT_RECORDS",
+              "counterDisplayName": "OUTPUT_RECORDS",
+              "counterValue": 7194
+            },
+            {
+              "counterName": "OUTPUT_BYTES",
+              "counterDisplayName": "OUTPUT_BYTES",
+              "counterValue": 323019
+            },
+            {
+              "counterName": "OUTPUT_BYTES_WITH_OVERHEAD",
+              "counterDisplayName": "OUTPUT_BYTES_WITH_OVERHEAD",
+              "counterValue": 337415
+            },
+            {
+              "counterName": "OUTPUT_BYTES_PHYSICAL",
+              "counterDisplayName": "OUTPUT_BYTES_PHYSICAL",
+              "counterValue": 337431
+            },
+            {
+              "counterName": "ADDITIONAL_SPILLS_BYTES_WRITTEN",
+              "counterDisplayName": "ADDITIONAL_SPILLS_BYTES_WRITTEN",
+              "counterValue": 0
+            },
+            {
+              "counterName": "ADDITIONAL_SPILLS_BYTES_READ",
+              "counterDisplayName": "ADDITIONAL_SPILLS_BYTES_READ",
+              "counterValue": 0
+            },
+            {
+              "counterName": "ADDITIONAL_SPILL_COUNT",
+              "counterDisplayName": "ADDITIONAL_SPILL_COUNT",
+              "counterValue": 0
+            },
+            {
+              "counterName": "SHUFFLE_BYTES",
+              "counterDisplayName": "SHUFFLE_BYTES",
+              "counterValue": 6124044
+            },
+            {
+              "counterName": "SHUFFLE_BYTES_DECOMPRESSED",
+              "counterDisplayName": "SHUFFLE_BYTES_DECOMPRESSED",
+              "counterValue": 6123980
+            },
+            {
+              "counterName": "SHUFFLE_BYTES_TO_MEM",
+              "counterDisplayName": "SHUFFLE_BYTES_TO_MEM",
+              "counterValue": 6124044
+            },
+            {
+              "counterName": "SHUFFLE_BYTES_TO_DISK",
+              "counterDisplayName": "SHUFFLE_BYTES_TO_DISK",
+              "counterValue": 0
+            }
+          ]
+        },
+        {
+          "counterGroupName": "org.apache.hadoop.hive.ql.exec.FilterOperator$Counter",
+          "counterGroupDisplayName": "org.apache.hadoop.hive.ql.exec.FilterOperator$Counter",
+          "counters": [
+            {
+              "counterName": "FILTERED",
+              "counterDisplayName": "FILTERED",
+              "counterValue": 0
+            },
+            {
+              "counterName": "PASSED",
+              "counterDisplayName": "PASSED",
+              "counterValue": 95911
+            }
+          ]
+        },
+        {
+          "counterGroupName": "org.apache.hadoop.hive.ql.exec.MapOperator$Counter",
+          "counterGroupDisplayName": "org.apache.hadoop.hive.ql.exec.MapOperator$Counter",
+          "counters": [
+            {
+              "counterName": "DESERIALIZE_ERRORS",
+              "counterDisplayName": "DESERIALIZE_ERRORS",
+              "counterValue": 0
+            }
+          ]
+        }
+      ]
+    },
+    "startRequestedTime": 1394569231792
+  },
+  "entity": "vertex_1394502141829_0425_1_04",
+  "entitytype": "TEZ_VERTEX_ID"
+}

http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/helpers/ajax.js
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/helpers/ajax.js b/contrib/views/jobs/src/main/resources/ui/app/scripts/helpers/ajax.js
new file mode 100644
index 0000000..42bae63
--- /dev/null
+++ b/contrib/views/jobs/src/main/resources/ui/app/scripts/helpers/ajax.js
@@ -0,0 +1,151 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+/**
+ * Config for each ajax-request
+ *
+ * Fields example:
+ *  mock - testMode url
+ *  real - real url (without API prefix)
+ *  type - request type (also may be defined in the format method)
+ *  format - function for processing ajax params after default formatRequest. May be called with one or two parameters (data, opt). Return ajax-params object
+ *  testInProduction - can this request be executed on production tests (used only in tests)
+ *
+ * @type {Object}
+ */
+var urls = {};
+/**
+ * Replace data-placeholders to its values
+ *
+ * @param {String} url
+ * @param {Object} data
+ * @return {String}
+ */
+var formatUrl = function (url, data) {
+  if (!url) return null;
+  var keys = url.match(/\{\w+\}/g);
+  keys = (keys === null) ? [] : keys;
+  if (keys) {
+    keys.forEach(function (key) {
+      var raw_key = key.substr(1, key.length - 2);
+      var replace;
+      if (!data || !data[raw_key]) {
+        replace = '';
+      }
+      else {
+        replace = data[raw_key];
+      }
+      url = url.replace(new RegExp(key, 'g'), replace);
+    });
+  }
+  return url;
+};
+
+/**
+ * this = object from config
+ * @return {Object}
+ */
+var formatRequest = function (data) {
+  var opt = {
+    type: this.type || 'GET',
+    dataType: 'json',
+    async: true,
+    headers: this.headers || {Accept: "application/json; charset=utf-8"}
+  };
+  if (App.get('testMode')) {
+    opt.url = formatUrl(this.mock ? this.mock : '', data);
+    opt.type = 'GET';
+  }
+  else {
+    var prefix = App.get('urlPrefix');
+    opt.url = prefix + formatUrl(this.real, data);
+  }
+
+  if (this.format) {
+    jQuery.extend(opt, this.format(data, opt));
+  }
+  return opt;
+};
+
+/**
+ * Wrapper for all ajax requests
+ *
+ * @type {Object}
+ */
+var ajax = Em.Object.extend({
+  /**
+   * Send ajax request
+   *
+   * @param {Object} config
+   * @return {$.ajax} jquery ajax object
+   *
+   * config fields:
+   *  name - url-key in the urls-object *required*
+   *  sender - object that send request (need for proper callback initialization) *required*
+   *  data - object with data for url-format
+   *  beforeSend - method-name for ajax beforeSend response callback
+   *  success - method-name for ajax success response callback
+   *  error - method-name for ajax error response callback
+   */
+  send: function (config) {
+
+    Ember.assert('Ajax sender should be defined!', config.sender);
+    Ember.assert('Invalid config.name provided - ' + config.name, urls[config.name]);
+
+    var opt = {},
+      params = {};
+
+    if (config.data) {
+      jQuery.extend(params, config.data);
+    }
+
+    opt = formatRequest.call(urls[config.name], params);
+    opt.context = this;
+
+    // object sender should be provided for processing beforeSend, success, error and complete responses
+    opt.beforeSend = function (xhr) {
+      if (config.beforeSend) {
+        config.sender[config.beforeSend](opt, xhr, params);
+      }
+    };
+
+    opt.success = function (data) {
+      console.log("TRACE: The url is: " + opt.url);
+      if (config.success) {
+        config.sender[config.success](data, opt, params);
+      }
+    };
+
+    opt.error = function (request, ajaxOptions, error) {
+      if (config.error) {
+        config.sender[config.error](request, ajaxOptions, error, opt, params);
+      }
+    };
+
+    opt.complete = function (xhr, status) {
+      if (config.complete) {
+        config.sender[config.complete](xhr, status);
+      }
+    };
+
+    return $.ajax(opt);
+  }
+
+});
+
+App.ajax = ajax.create({});

http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/helpers/date.js
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/helpers/date.js b/contrib/views/jobs/src/main/resources/ui/app/scripts/helpers/date.js
index 66a5fb1..b8bb058 100644
--- a/contrib/views/jobs/src/main/resources/ui/app/scripts/helpers/date.js
+++ b/contrib/views/jobs/src/main/resources/ui/app/scripts/helpers/date.js
@@ -138,7 +138,8 @@ App.Helpers.date = {
       return '' + this.timingFormat(endTimestamp - startTimestamp, 1); //lasted for xx secs
     } else {
       // still running, duration till now
-      var time = (App.dateTime() - startTimestamp) < 0 ? 0 : (App.dateTime() - startTimestamp);
+      var t = new Date().getTime(),
+        time = (t - startTimestamp) < 0 ? 0 : (t - startTimestamp);
       durationSummary = '' + this.timingFormat(time, 1);
     }
     return durationSummary;
@@ -207,7 +208,7 @@ App.Helpers.date = {
     var duration = 0;
     if (startTime && startTime > 0) {
       if (!endTime || endTime < 1) {
-        endTime = App.dateTime();
+        endTime = new Date().getTime();
       }
       duration = endTime - startTime;
     }

http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/mappers/jobs/hive_job_mapper.js
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/mappers/jobs/hive_job_mapper.js b/contrib/views/jobs/src/main/resources/ui/app/scripts/mappers/jobs/hive_job_mapper.js
new file mode 100644
index 0000000..ad65902
--- /dev/null
+++ b/contrib/views/jobs/src/main/resources/ui/app/scripts/mappers/jobs/hive_job_mapper.js
@@ -0,0 +1,217 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements. See the NOTICE file distributed with this
+ * work for additional information regarding copyright ownership. The ASF
+ * licenses this file to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT
+ * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the
+ * License for the specific language governing permissions and limitations under
+ * the License.
+ */
+
+/**
+ * Maps a Hive job response from server into an existing Hive Job.
+ *
+ * This will only update an existing Hive Job and not create a new one. It will
+ * populate all fields (stages, Tez DAG, etc.) except runtime information like
+ * <ul>
+ * <li>tezDag.id
+ * <li>tezDag.vertices.state
+ * <li>tezDag.vertices.startTime
+ * <li>tezDag.vertices.endTime
+ * <li>tezDag.vertices.tasksCount
+ * <li>tezDag.vertices.file*
+ * <li>tezDag.vertices.hdfs*
+ * <li>tezDag.vertices.recordReadCount
+ * <li>tezDag.vertices.recordWriteCount
+ * </ul>
+ */
+App.hiveJobMapper = App.QuickDataMapper.create({
+
+  model : App.HiveJob,
+  map : function(json) {
+    var model = this.get('model'),
+      hiveJob = {};
+    if (json && json.entity) {
+      hiveJob.id = json.entity;
+      hiveJob.name = hiveJob.id;
+      hiveJob.startTime = json.starttime;
+      if (typeof(json.endtime) == "undefined") {
+        var i = 0;
+        while (typeof(hiveJob.endTime) == "undefined" &&  json.events && json.events[i]) {
+          if (json.events[i].eventtype == 'QUERY_COMPLETED') {
+            hiveJob.endTime = json.events[i].timestamp;
+          }
+          i++;
+        }
+      }
+      else {
+        hiveJob.endTime = json.endtime;
+      }
+      json.otherinfo.query = $.parseJSON(json.otherinfo.query);
+      if (json.otherinfo.query && json.otherinfo.query.queryText) {
+        hiveJob.query_text = json.otherinfo.query.queryText;
+      }
+      hiveJob.stages = [];
+      var stagePlans = json.otherinfo.query.queryPlan["STAGE PLANS"];
+      for ( var stage in stagePlans) {
+        var stageValue = stagePlans[stage];
+        var stageItem = {};
+        stageItem.id = stage;
+        stageItem.description = '. ';
+        for (var item in stageValue) {
+          stageItem.description += item;
+        }
+        hiveJob.stages.push(stageItem);
+        if (stageValue.Tez != null && hiveJob.tezDag == null) {
+          var dagName = stageValue.Tez['DagName:'];
+          // Vertices
+          var vertices = [];
+          var vertexIds = [];
+          var vertexIdMap = {};
+          for ( var vertexName in stageValue.Tez["Vertices:"]) {
+            var vertex = stageValue.Tez["Vertices:"][vertexName];
+            var vertexObj = {
+              id : dagName + "/" + vertexName,
+              name : vertexName,
+              incoming_edges : [],
+              outgoing_edges : []
+            };
+            vertexIds.push(vertexObj.id);
+            var operatorExtractor = function(obj) {
+              var ops = [];
+              if ($.isArray(obj)) {
+                obj.forEach(function(o) {
+                  ops = ops.concat(operatorExtractor(o));
+                });
+              }
+              else {
+                for ( var key in obj) {
+                  ops.push(key);
+                  if (obj[key].children != null) {
+                    ops = ops.concat(operatorExtractor(obj[key].children));
+                  }
+                }
+              }
+              return ops;
+            };
+            if (vertex["Map Operator Tree:"] != null) {
+              vertexObj.type = App.TezDagVertexType.MAP;
+              vertexObj.operations = operatorExtractor(vertex["Map Operator Tree:"]);
+              vertexObj.operation_plan = JSON.stringify(vertex["Map Operator Tree:"], undefined, "  ");
+            }
+            else
+              if (vertex["Reduce Operator Tree:"] != null) {
+                vertexObj.type = App.TezDagVertexType.REDUCE;
+                vertexObj.operations = operatorExtractor(vertex["Reduce Operator Tree:"]);
+                vertexObj.operation_plan = JSON.stringify(vertex["Reduce Operator Tree:"], undefined, "  ");
+              }
+              else
+                if (vertex["Vertex:"] != null && vertexName==vertex['Vertex:']) {
+                  vertexObj.type = App.TezDagVertexType.UNION;
+                }
+            vertexIdMap[vertexObj.id] = vertexObj;
+            vertices.push(vertexObj);
+          }
+          // Edges
+          var edges = [];
+          var edgeIds = [];
+          for ( var childVertex in stageValue.Tez["Edges:"]) {
+            var childVertices = stageValue.Tez["Edges:"][childVertex];
+            if (!$.isArray(childVertices)) {
+              // Single edge given as object instead of array
+              childVertices = [ childVertices ];
+            }
+            childVertices.forEach(function(e) {
+              var parentVertex = e.parent;
+              if (e.type == 'CONTAINS') {
+                var parentVertexNode = vertexIdMap[dagName + "/" + parentVertex];
+                if (parentVertexNode != null && parentVertexNode.type == App.TezDagVertexType.UNION) {
+                  // We flip the edges for Union vertices
+                  var tmp = childVertex;
+                  childVertex = parentVertex;
+                  parentVertex = tmp;
+                }
+              }
+              var edgeObj = {
+                id : dagName + "/" + parentVertex + "-" + childVertex,
+                from_vertex_id : dagName + "/" + parentVertex,
+                to_vertex_id : dagName + "/" + childVertex
+              };
+              vertexIdMap[edgeObj.from_vertex_id].outgoing_edges.push(edgeObj.id);
+              vertexIdMap[edgeObj.to_vertex_id].incoming_edges.push(edgeObj.id);
+              edgeIds.push(edgeObj.id);
+              switch (e.type) {
+              case "BROADCAST_EDGE":
+                edgeObj.edge_type = App.TezDagEdgeType.BROADCAST;
+                break;
+              case "SIMPLE_EDGE":
+                edgeObj.edge_type = App.TezDagEdgeType.SCATTER_GATHER;
+                break;
+              case "CONTAINS":
+                edgeObj.edge_type = App.TezDagEdgeType.CONTAINS;
+                break;
+              default:
+                break;
+              }
+              edges.push(edgeObj);
+            });
+          }
+          // Create records
+          var tezDag = {
+            id : dagName,
+            name : dagName,
+            stage : stage,
+            vertices : vertexIds,
+            edges : edgeIds
+          };
+          // Once the DAG is loaded, we do not need to
+          // reload as the structure does not change. Reloading
+          // here causes missing data (got from other calls)
+          // to propagate into UI - causing flashing.
+          var newVertices = [];
+          var newEdges = [];
+          vertices.forEach(function(v) {
+            var vertexRecord = App.TezDagVertex.find(v.id);
+            if (!vertexRecord.get('isLoaded')) {
+              newVertices.push(v);
+            }
+          });
+          edges.forEach(function(e) {
+            var edgeRecord = App.TezDagEdge.find(e.id);
+            if (!edgeRecord.get('isLoaded')) {
+              newEdges.push(e);
+            }
+          });
+          App.store.loadMany(App.TezDagVertex, newVertices);
+          App.store.loadMany(App.TezDagEdge, newEdges);
+          var dagRecord = App.TezDag.find(tezDag.id);
+          if (!dagRecord.get('isLoaded')) {
+            App.store.load(App.TezDag, tezDag);
+          }
+          hiveJob.tezDag = tezDag.id;
+        }
+      }
+      if(App.HiveJob.find().get('content').length == 0){
+        App.store.load(model, hiveJob);
+      }
+      var hiveJobRecord = App.HiveJob.find(hiveJob.id);
+      if (hiveJobRecord != null) {
+        hiveJobRecord.set('stages', hiveJob.stages.sortProperty('id'));
+        hiveJobRecord.set('startTime', hiveJob.startTime);
+        hiveJobRecord.set('endTime', hiveJob.endTime);
+        if (hiveJob.tezDag != null) {
+          // Some hive queries dont use Tez
+          hiveJobRecord.set('tezDag', App.TezDag.find(hiveJob.tezDag));
+        }
+      }
+    }
+  },
+  config : {}
+});

http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/mappers/jobs/hive_jobs_mapper.js
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/mappers/jobs/hive_jobs_mapper.js b/contrib/views/jobs/src/main/resources/ui/app/scripts/mappers/jobs/hive_jobs_mapper.js
new file mode 100644
index 0000000..9a1fc07
--- /dev/null
+++ b/contrib/views/jobs/src/main/resources/ui/app/scripts/mappers/jobs/hive_jobs_mapper.js
@@ -0,0 +1,96 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements. See the NOTICE file distributed with this
+ * work for additional information regarding copyright ownership. The ASF
+ * licenses this file to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT
+ * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the
+ * License for the specific language governing permissions and limitations under
+ * the License.
+ */
+
+App.hiveJobsMapper = App.QuickDataMapper.create({
+
+  model: App.HiveJob,
+
+  map: function (json) {
+
+    var model = this.get('model'),
+      hiveJobs = [];
+    if (json) {
+      if (!json.entities) {
+        json.entities = [];
+        if (json.entity) {
+          json.entities = [json];
+        }
+      }
+      var currentEntityMap = {};
+      json.entities.forEach(function (entity) {
+        currentEntityMap[entity.entity] = entity.entity;
+        var hiveJob = {
+          id: entity.entity,
+          name: entity.entity,
+          user: entity.primaryfilters.user
+        };
+        hiveJob.has_tez_dag = false;
+        hiveJob.query_text = '';
+        if (entity.otherinfo && entity.otherinfo.query) {
+          // Explicit false match needed for when failure hook not set
+          hiveJob.failed = entity.otherinfo.status === false;
+          hiveJob.has_tez_dag = entity.otherinfo.query.match("\"Tez\".*\"DagName:\"");
+          var queryJson = $.parseJSON(entity.otherinfo.query);
+          if (queryJson && queryJson.queryText) {
+            hiveJob.query_text = queryJson.queryText;
+          }
+        }
+        if (entity.events != null) {
+          entity.events.forEach(function (event) {
+            switch (event.eventtype) {
+              case "QUERY_SUBMITTED":
+                hiveJob.start_time = event.timestamp;
+                break;
+              case "QUERY_COMPLETED":
+                hiveJob.end_time = event.timestamp;
+                break;
+              default:
+                break;
+            }
+          });
+        }
+        if (!hiveJob.start_time && entity.starttime > 0) {
+          hiveJob.start_time = entity.starttime;
+        }
+        if (!hiveJob.end_time && entity.endtime > 0) {
+          hiveJob.end_time = entity.endtime;
+        }
+        hiveJobs.push(hiveJob);
+        hiveJob = null;
+        entity = null;
+      });
+
+      /*if(hiveJobs.length > App.router.get('mainJobsController.filterObject.jobsLimit')) {
+       var lastJob = hiveJobs.pop();
+       if(App.router.get('mainJobsController.navIDs.nextID') != lastJob.id) {
+       App.router.set('mainJobsController.navIDs.nextID', lastJob.id);
+       }
+       currentEntityMap[lastJob.id] = null;
+       }*/
+
+      // Delete IDs not seen from server
+      /*var hiveJobsModel = model.find().toArray();
+       hiveJobsModel.forEach(function(job) {
+       if (job && !currentEntityMap[job.get('id')]) {
+       this.deleteRecord(job);
+       }
+       }, this);*/
+    }
+    App.HiveJob.store.pushMany('hiveJob', hiveJobs);
+  },
+  config: {}
+});

http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/mappers/server_data_mapper.js
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/mappers/server_data_mapper.js b/contrib/views/jobs/src/main/resources/ui/app/scripts/mappers/server_data_mapper.js
new file mode 100644
index 0000000..02f17ff
--- /dev/null
+++ b/contrib/views/jobs/src/main/resources/ui/app/scripts/mappers/server_data_mapper.js
@@ -0,0 +1,133 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+App.ServerDataMapper = Em.Object.extend({
+  jsonKey: false,
+  map: function (json) {
+    if (json) {
+      var model = this.get('model');
+      var jsonKey = this.get('jsonKey');
+
+      if (jsonKey && json[jsonKey]) {
+        json = json[jsonKey];
+      }
+
+      $.each(json, function (field, value) {
+        model.set(field, value);
+      })
+    }
+  }
+});
+
+
+App.QuickDataMapper = App.ServerDataMapper.extend({
+  config: {},
+  model: null,
+  map: Em.K,
+
+  parseIt: function (data, config) {
+    var result = {};
+    for ( var i in config) {
+      if (i.substr(0, 1) === '$') {
+        i = i.substr(1, i.length);
+        result[i] = config['$' + i];
+      } else {
+        var isSpecial = false;
+        if (i.substr(-5) == '_type') {
+          var prefix = i.substr(0, i.length - 5);
+          isSpecial = config[prefix + '_key'] != null;
+        } else if (i.substr(-4) == '_key') {
+          var prefix = i.substr(0, i.length - 4);
+          isSpecial = config[prefix + '_type'] != null;
+        }
+        if (!isSpecial && typeof config[i] == 'string') {
+          result[i] = this.getJsonProperty(data, config[i]);
+        } else if (typeof config[i] == 'object') {
+          result[i] = [];
+          var _data = this.getJsonProperty(data, config[i + '_key']);
+          var _type = config[i + '_type'];
+          var l = _data.length;
+          for ( var index = 0; index < l; index++) {
+            if (_type == 'array') {
+              result[i].push(this.getJsonProperty(_data[index], config[i].item));
+            } else {
+              result[i].push(this.parseIt(_data[index], config[i]));
+            }
+          }
+          if(_type == 'array'){
+            result[i] = result[i].sort();
+          }
+        }
+      }
+    }
+    return result;
+  },
+
+  getJsonProperty: function (json, path) {
+    var pathArr = path.split('.');
+    var current = json;
+    pathArr = this.filterDotted(pathArr);
+    while (pathArr.length && current) {
+      if (pathArr[0].substr(-1) == ']') {
+        var index = parseInt(pathArr[0].substr(-2, 1));
+        var attr = pathArr[0].substr(0, pathArr[0].length - 3);
+        if (attr in current) {
+          current = current[attr][index];
+        }
+      } else {
+        current = current[pathArr[0]];
+      }
+      pathArr.splice(0, 1);
+    }
+    return current;
+  },
+
+  filterDotted: function(arr) {
+    var buffer = [];
+    var dottedBuffer = [];
+    var dotted = false;
+    arr.forEach(function(item) {
+      if(/\['|\["/.test(item)) {
+        dottedBuffer.push(item.substr(2, item.length));
+        dotted = true;
+      } else if (dotted && !/\]'|"\]/.test(item)) {
+        dottedBuffer.push(item);
+      } else if (/']|"]/.test(item)) {
+        dottedBuffer.push(item.substr(0, item.length - 2));
+        buffer.push(dottedBuffer.join('.'));
+        dotted = false;
+        dottedBuffer = [];
+      } else {
+        buffer.push(item);
+      }
+    });
+
+    return buffer;
+  },
+
+  /**
+   * properly delete record from model
+   * @param item
+   */
+  deleteRecord: function (item) {
+    item.deleteRecord();
+    App.store.commit();
+    item.get('stateManager').transitionTo('loading');
+    console.log('Record with id:' + item.get('id') + ' was deleted from model');
+  }
+});


[5/5] git commit: Merge remote-tracking branch 'origin/trunk' into trunk

Posted by on...@apache.org.
Merge remote-tracking branch 'origin/trunk' into trunk


Project: http://git-wip-us.apache.org/repos/asf/ambari/repo
Commit: http://git-wip-us.apache.org/repos/asf/ambari/commit/fca84185
Tree: http://git-wip-us.apache.org/repos/asf/ambari/tree/fca84185
Diff: http://git-wip-us.apache.org/repos/asf/ambari/diff/fca84185

Branch: refs/heads/trunk
Commit: fca841856eb9adca0792ef13880653463e8b73a0
Parents: b76efd5 8af0d07
Author: Oleg Nechiporenko <on...@apache.org>
Authored: Wed Jul 16 19:09:03 2014 +0300
Committer: Oleg Nechiporenko <on...@apache.org>
Committed: Wed Jul 16 19:09:03 2014 +0300

----------------------------------------------------------------------
 .../libraries/functions/default.py              |    5 -
 .../ambari/server/agent/HeartbeatMonitor.java   |   59 +-
 .../server/api/AmbariCsrfProtectionFilter.java  |   58 +
 .../ambari/server/controller/AmbariServer.java  |    4 +-
 .../internal/ClusterResourceProvider.java       |    3 +-
 .../server/metadata/RoleCommandOrder.java       |   27 +-
 .../server/upgrade/AbstractUpgradeCatalog.java  |   51 +-
 .../custom_actions/ambari_hdfs_rebalancer.py    |    2 +-
 .../src/main/resources/role_command_order.json  |    6 +-
 .../1.3.2/hooks/after-INSTALL/scripts/params.py |   29 +-
 .../scripts/shared_initialization.py            |    2 +-
 .../after-INSTALL/templates/hadoop-env.sh.j2    |  142 --
 .../hooks/before-INSTALL/scripts/params.py      |   61 +-
 .../scripts/shared_initialization.py            |    6 -
 .../1.3.2/hooks/before-START/scripts/params.py  |   34 +-
 .../stacks/HDP/1.3.2/role_command_order.json    |    6 +-
 .../GANGLIA/configuration/ganglia-env.xml       |   70 +
 .../services/GANGLIA/configuration/global.xml   |   70 -
 .../HDP/1.3.2/services/GANGLIA/metainfo.xml     |    2 +-
 .../services/GANGLIA/package/scripts/params.py  |   20 +-
 .../GANGLIA/package/scripts/status_params.py    |    2 +-
 .../services/HBASE/configuration/global.xml     |   50 -
 .../services/HBASE/configuration/hbase-env.xml  |  122 +
 .../HDP/1.3.2/services/HBASE/metainfo.xml       |    2 +-
 .../services/HBASE/package/scripts/hbase.py     |    5 +-
 .../services/HBASE/package/scripts/params.py    |   35 +-
 .../HBASE/package/scripts/status_params.py      |    4 +-
 .../HBASE/package/templates/hbase-env.sh.j2     |  101 -
 .../services/HDFS/configuration/global.xml      |   87 -
 .../services/HDFS/configuration/hadoop-env.xml  |  211 ++
 .../stacks/HDP/1.3.2/services/HDFS/metainfo.xml |    2 +-
 .../services/HDFS/package/scripts/params.py     |   37 +-
 .../HDFS/package/scripts/status_params.py       |    4 +-
 .../services/HIVE/configuration/global.xml      |  100 -
 .../services/HIVE/configuration/hive-env.xml    |  139 ++
 .../stacks/HDP/1.3.2/services/HIVE/metainfo.xml |    4 +-
 .../1.3.2/services/HIVE/package/scripts/hive.py |    2 +-
 .../services/HIVE/package/scripts/params.py     |   37 +-
 .../HIVE/package/scripts/status_params.py       |    4 +-
 .../HIVE/package/templates/hive-env.sh.j2       |   78 -
 .../services/MAPREDUCE/configuration/global.xml |  150 --
 .../MAPREDUCE/configuration/mapred-env.xml      |  150 ++
 .../HDP/1.3.2/services/MAPREDUCE/metainfo.xml   |    2 +-
 .../MAPREDUCE/package/scripts/params.py         |   18 +-
 .../MAPREDUCE/package/scripts/status_params.py  |    4 +-
 .../services/NAGIOS/configuration/global.xml    |   51 -
 .../NAGIOS/configuration/nagios-env.xml         |   51 +
 .../HDP/1.3.2/services/NAGIOS/metainfo.xml      |    2 +-
 .../services/NAGIOS/package/scripts/params.py   |   20 +-
 .../services/OOZIE/configuration/global.xml     |   60 -
 .../services/OOZIE/configuration/oozie-env.xml  |  120 +
 .../HDP/1.3.2/services/OOZIE/metainfo.xml       |    2 +-
 .../services/OOZIE/package/scripts/oozie.py     |    7 +-
 .../services/OOZIE/package/scripts/params.py    |   27 +-
 .../OOZIE/package/scripts/status_params.py      |    2 +-
 .../OOZIE/package/templates/oozie-env.sh.j2     |   88 -
 .../services/PIG/configuration/pig-env.xml      |   34 +
 .../stacks/HDP/1.3.2/services/PIG/metainfo.xml  |    2 +-
 .../services/PIG/package/scripts/params.py      |   11 +-
 .../1.3.2/services/PIG/package/scripts/pig.py   |    9 +-
 .../PIG/package/templates/pig-env.sh.j2         |   36 -
 .../services/SQOOP/configuration/sqoop-env.xml  |   49 +
 .../HDP/1.3.2/services/SQOOP/metainfo.xml       |    3 +
 .../services/SQOOP/package/scripts/params.py    |   11 +-
 .../services/SQOOP/package/scripts/sqoop.py     |    6 +-
 .../SQOOP/package/templates/sqoop-env.sh.j2     |   36 -
 .../WEBHCAT/configuration/webhcat-env.xml       |   54 +
 .../WEBHCAT/configuration/webhcat-site.xml      |   30 +
 .../HDP/1.3.2/services/WEBHCAT/metainfo.xml     |    1 +
 .../services/WEBHCAT/package/scripts/params.py  |   22 +-
 .../WEBHCAT/package/scripts/status_params.py    |    2 +-
 .../services/WEBHCAT/package/scripts/webhcat.py |    2 +-
 .../WEBHCAT/package/templates/webhcat-env.sh.j2 |   63 -
 .../services/ZOOKEEPER/configuration/global.xml |   65 -
 .../ZOOKEEPER/configuration/zookeeper-env.xml   |   83 +
 .../HDP/1.3.2/services/ZOOKEEPER/metainfo.xml   |    2 +-
 .../ZOOKEEPER/package/scripts/params.py         |   27 +-
 .../ZOOKEEPER/package/scripts/status_params.py  |    2 +-
 .../ZOOKEEPER/package/scripts/zookeeper.py      |    8 +-
 .../package/templates/zookeeper-env.sh.j2       |   44 -
 .../stacks/HDP/1.3.3/role_command_order.json    |    6 +-
 .../stacks/HDP/1.3/role_command_order.json      |    6 +-
 .../HDP/2.0.6.GlusterFS/role_command_order.json |    6 +-
 .../2.0.6/hooks/after-INSTALL/scripts/params.py |   29 +-
 .../scripts/shared_initialization.py            |    2 +-
 .../after-INSTALL/templates/hadoop-env.sh.j2    |  146 --
 .../hooks/before-INSTALL/scripts/params.py      |   40 +-
 .../2.0.6/hooks/before-START/scripts/params.py  |   38 +-
 .../stacks/HDP/2.0.6/role_command_order.json    |    6 +-
 .../services/FLUME/configuration/flume-env.xml  |   34 +
 .../services/FLUME/configuration/global.xml     |   34 -
 .../HDP/2.0.6/services/FLUME/metainfo.xml       |    2 +-
 .../services/FLUME/package/scripts/params.py    |    4 +-
 .../GANGLIA/configuration/ganglia-env.xml       |   70 +
 .../services/GANGLIA/configuration/global.xml   |   70 -
 .../HDP/2.0.6/services/GANGLIA/metainfo.xml     |    2 +-
 .../services/GANGLIA/package/scripts/params.py  |   22 +-
 .../GANGLIA/package/scripts/status_params.py    |    2 +-
 .../services/HBASE/configuration/global.xml     |   50 -
 .../services/HBASE/configuration/hbase-env.xml  |  122 +
 .../HDP/2.0.6/services/HBASE/metainfo.xml       |    2 +-
 .../services/HBASE/package/scripts/hbase.py     |    7 +-
 .../services/HBASE/package/scripts/params.py    |   35 +-
 .../HBASE/package/scripts/status_params.py      |    4 +-
 .../HBASE/package/templates/hbase-env.sh.j2     |  100 -
 .../services/HDFS/configuration/global.xml      |   87 -
 .../services/HDFS/configuration/hadoop-env.xml  |  213 ++
 .../stacks/HDP/2.0.6/services/HDFS/metainfo.xml |    2 +-
 .../services/HDFS/package/scripts/namenode.py   |    1 +
 .../services/HDFS/package/scripts/params.py     |   34 +-
 .../HDFS/package/scripts/status_params.py       |    4 +-
 .../services/HIVE/configuration/global.xml      |   90 -
 .../services/HIVE/configuration/hive-env.xml    |  131 ++
 .../stacks/HDP/2.0.6/services/HIVE/metainfo.xml |    2 +-
 .../2.0.6/services/HIVE/package/scripts/hive.py |    2 +-
 .../services/HIVE/package/scripts/params.py     |   39 +-
 .../HIVE/package/scripts/status_params.py       |    4 +-
 .../HIVE/package/templates/hive-env.sh.j2       |   79 -
 .../services/NAGIOS/configuration/global.xml    |   51 -
 .../NAGIOS/configuration/nagios-env.xml         |   51 +
 .../HDP/2.0.6/services/NAGIOS/metainfo.xml      |    2 +-
 .../services/NAGIOS/package/scripts/params.py   |   22 +-
 .../services/OOZIE/configuration/global.xml     |   60 -
 .../services/OOZIE/configuration/oozie-env.xml  |  128 +
 .../HDP/2.0.6/services/OOZIE/metainfo.xml       |    3 +-
 .../services/OOZIE/package/scripts/oozie.py     |    5 +-
 .../services/OOZIE/package/scripts/params.py    |   26 +-
 .../OOZIE/package/scripts/status_params.py      |    2 +-
 .../OOZIE/package/templates/oozie-env.sh.j2     |   95 -
 .../services/PIG/configuration/pig-env.xml      |   38 +
 .../stacks/HDP/2.0.6/services/PIG/metainfo.xml  |    2 +-
 .../services/PIG/package/scripts/params.py      |   11 +-
 .../2.0.6/services/PIG/package/scripts/pig.py   |    5 +-
 .../PIG/package/templates/pig-env.sh.j2         |   39 -
 .../services/SQOOP/configuration/sqoop-env.xml  |   49 +
 .../HDP/2.0.6/services/SQOOP/metainfo.xml       |    3 +
 .../services/SQOOP/package/scripts/params.py    |   11 +-
 .../services/SQOOP/package/scripts/sqoop.py     |    7 +-
 .../SQOOP/package/templates/sqoop-env.sh.j2     |   54 -
 .../WEBHCAT/configuration/webhcat-env.xml       |   54 +
 .../HDP/2.0.6/services/WEBHCAT/metainfo.xml     |    1 +
 .../services/WEBHCAT/package/scripts/params.py  |   22 +-
 .../WEBHCAT/package/scripts/status_params.py    |    2 +-
 .../services/WEBHCAT/package/scripts/webhcat.py |    2 +-
 .../WEBHCAT/package/templates/webhcat-env.sh.j2 |   62 -
 .../YARN/configuration-mapred/global.xml        |   44 -
 .../YARN/configuration-mapred/mapred-env.xml    |   64 +
 .../services/YARN/configuration/global.xml      |   55 -
 .../services/YARN/configuration/yarn-env.xml    |  173 ++
 .../stacks/HDP/2.0.6/services/YARN/metainfo.xml |    4 +-
 .../services/YARN/package/scripts/params.py     |   34 +-
 .../YARN/package/scripts/status_params.py       |    8 +-
 .../2.0.6/services/YARN/package/scripts/yarn.py |    4 +-
 .../YARN/package/templates/mapred-env.sh.j2     |   27 -
 .../YARN/package/templates/yarn-env.sh.j2       |  146 --
 .../services/ZOOKEEPER/configuration/global.xml |   65 -
 .../ZOOKEEPER/configuration/zookeeper-env.xml   |   83 +
 .../HDP/2.0.6/services/ZOOKEEPER/metainfo.xml   |    2 +-
 .../ZOOKEEPER/package/scripts/params.py         |   27 +-
 .../ZOOKEEPER/package/scripts/status_params.py  |    2 +-
 .../ZOOKEEPER/package/scripts/zookeeper.py      |    8 +-
 .../package/templates/zookeeper-env.sh.j2       |   44 -
 .../stacks/HDP/2.0/role_command_order.json      |    6 +-
 .../HDP/2.1.GlusterFS/role_command_order.json   |    6 +-
 .../stacks/HDP/2.1/role_command_order.json      |    6 +-
 .../FALCON/configuration/falcon-env.xml         |  109 +
 .../services/FALCON/configuration/global.xml    |   63 -
 .../stacks/HDP/2.1/services/FALCON/metainfo.xml |    2 +-
 .../services/FALCON/package/scripts/falcon.py   |    2 +-
 .../services/FALCON/package/scripts/params.py   |   31 +-
 .../FALCON/package/scripts/status_params.py     |    2 +-
 .../FALCON/package/templates/falcon-env.sh.j2   |   73 -
 .../stacks/HDP/2.1/services/HIVE/metainfo.xml   |    2 +-
 .../HDP/2.1/services/HIVE/metainfo.xml.orig     |   51 +
 .../stacks/HDP/2.1/services/OOZIE/metainfo.xml  |    5 +-
 .../stacks/HDP/2.1/services/SQOOP/metainfo.xml  |    4 +
 .../2.1/services/STORM/configuration/global.xml |   39 -
 .../services/STORM/configuration/storm-env.xml  |   55 +
 .../stacks/HDP/2.1/services/STORM/metainfo.xml  |    2 +-
 .../services/STORM/package/scripts/params.py    |   13 +-
 .../STORM/package/scripts/status_params.py      |    2 +-
 .../2.1/services/STORM/package/scripts/storm.py |    7 +-
 .../STORM/package/templates/storm-env.sh.j2     |   45 -
 .../2.1/services/TEZ/configuration/global.xml   |   29 -
 .../2.1/services/TEZ/configuration/tez-env.xml  |   45 +
 .../stacks/HDP/2.1/services/TEZ/metainfo.xml    |    2 +-
 .../2.1/services/TEZ/package/scripts/params.py  |    5 +-
 .../HDP/2.1/services/TEZ/package/scripts/tez.py |    7 +-
 .../TEZ/package/templates/tez-env.sh.j2         |   23 -
 .../HDP/2.1/services/WEBHCAT/metainfo.xml       |    1 +
 .../2.1/services/YARN/configuration/global.xml  |   60 -
 .../services/YARN/configuration/yarn-env.xml    |  178 ++
 .../stacks/HDP/2.1/services/YARN/metainfo.xml   |    2 +-
 .../server/agent/TestHeartbeatMonitor.java      |    4 +-
 .../api/AmbariCsrfProtectionFilterTest.java     |   66 +
 .../internal/ClusterResourceProviderTest.java   |   26 +-
 .../server/metadata/RoleCommandOrderTest.java   |   64 +
 .../server/upgrade/UpgradeCatalogTest.java      |    2 +-
 .../stacks/1.3.2/HBASE/test_hbase_client.py     |    8 +-
 .../stacks/1.3.2/HBASE/test_hbase_master.py     |    8 +-
 .../1.3.2/HBASE/test_hbase_regionserver.py      |    8 +-
 .../stacks/1.3.2/HIVE/test_hive_client.py       |    4 +-
 .../stacks/1.3.2/HIVE/test_hive_metastore.py    |    4 +-
 .../stacks/1.3.2/HIVE/test_hive_server.py       |    4 +-
 .../stacks/1.3.2/OOZIE/test_oozie_client.py     |    6 +-
 .../stacks/1.3.2/OOZIE/test_oozie_server.py     |   12 +-
 .../python/stacks/1.3.2/PIG/test_pig_client.py  |    8 +-
 .../python/stacks/1.3.2/SQOOP/test_sqoop.py     |    4 +-
 .../stacks/1.3.2/WEBHCAT/test_webhcat_server.py |    4 +-
 .../1.3.2/ZOOKEEPER/test_zookeeper_client.py    |    4 +-
 .../1.3.2/ZOOKEEPER/test_zookeeper_server.py    |    4 +-
 .../1.3.2/configs/default.hbasedecom.json       |  187 +-
 .../python/stacks/1.3.2/configs/default.json    |  190 +-
 .../1.3.2/configs/default.non_gmetad_host.json  |  187 +-
 .../python/stacks/1.3.2/configs/secured.json    |  154 ++
 .../hooks/after-INSTALL/test_after_install.py   |    2 +-
 .../hooks/before-START/test_before_start.py     |    4 +-
 .../stacks/2.0.6/HBASE/test_hbase_client.py     |   14 +-
 .../stacks/2.0.6/HBASE/test_hbase_master.py     |    8 +-
 .../2.0.6/HBASE/test_hbase_regionserver.py      |    8 +-
 .../stacks/2.0.6/HIVE/test_hive_client.py       |    4 +-
 .../stacks/2.0.6/HIVE/test_hive_metastore.py    |    4 +-
 .../stacks/2.0.6/HIVE/test_hive_server.py       |    4 +-
 .../stacks/2.0.6/OOZIE/test_oozie_client.py     |   10 +-
 .../stacks/2.0.6/OOZIE/test_oozie_server.py     |    6 +-
 .../python/stacks/2.0.6/PIG/test_pig_client.py  |   10 +-
 .../python/stacks/2.0.6/SQOOP/test_sqoop.py     |    5 +-
 .../stacks/2.0.6/WEBHCAT/test_webhcat_server.py |    4 +-
 .../stacks/2.0.6/YARN/test_historyserver.py     |    8 +-
 .../stacks/2.0.6/YARN/test_mapreduce2_client.py |    8 +-
 .../stacks/2.0.6/YARN/test_nodemanager.py       |    8 +-
 .../stacks/2.0.6/YARN/test_resourcemanager.py   |    8 +-
 .../stacks/2.0.6/YARN/test_yarn_client.py       |   12 +-
 .../2.0.6/ZOOKEEPER/test_zookeeper_client.py    |   16 +-
 .../2.0.6/ZOOKEEPER/test_zookeeper_server.py    |   16 +-
 .../2.0.6/configs/default.hbasedecom.json       |  207 +-
 .../python/stacks/2.0.6/configs/default.json    |  213 +-
 .../2.0.6/configs/default.non_gmetad_host.json  |  202 +-
 .../python/stacks/2.0.6/configs/ha_default.json |  129 ++
 .../python/stacks/2.0.6/configs/ha_secured.json |  283 ++-
 .../python/stacks/2.0.6/configs/secured.json    |  337 +--
 .../hooks/after-INSTALL/test_after_install.py   |    4 +-
 .../stacks/2.1/FALCON/test_falcon_client.py     |    2 +-
 .../stacks/2.1/FALCON/test_falcon_server.py     |    2 +-
 .../stacks/2.1/HIVE/test_hive_metastore.py      |   20 +-
 .../stacks/2.1/STORM/test_storm_drpc_server.py  |    6 +-
 .../stacks/2.1/STORM/test_storm_nimbus.py       |    6 +-
 .../stacks/2.1/STORM/test_storm_nimbus_prod.py  |    8 +-
 .../2.1/STORM/test_storm_rest_api_service.py    |    6 +-
 .../stacks/2.1/STORM/test_storm_supervisor.py   |    6 +-
 .../2.1/STORM/test_storm_supervisor_prod.py     |    6 +-
 .../stacks/2.1/STORM/test_storm_ui_server.py    |    6 +-
 .../python/stacks/2.1/TEZ/test_tez_client.py    |    5 +-
 .../stacks/2.1/YARN/test_apptimelineserver.py   |    4 +-
 .../test/python/stacks/2.1/configs/default.json |  123 +-
 .../test/python/stacks/2.1/configs/secured.json |  168 ++
 .../stacks/HDP/2.0.6/role_command_order.json    |    6 +-
 .../stacks/HDP/2.0.7/role_command_order.json    |    6 +-
 .../stacks/HDP/2.0.8/role_command_order.json    |    6 +-
 .../stacks/HDP/2.1.1/role_command_order.json    |    6 +-
 .../controllers/global/cluster_controller.js    |    1 -
 .../global/configuration_controller.js          |   51 +-
 .../main/admin/highAvailability_controller.js   |   19 +-
 .../controllers/main/admin/misc_controller.js   |   24 +-
 .../app/controllers/main/admin/security.js      |   19 +-
 .../controllers/main/admin/security/disable.js  |    2 +-
 .../controllers/main/mirroring_controller.js    |    7 +-
 .../controllers/main/service/info/configs.js    |  363 ++-
 .../main/service/reassign_controller.js         |   26 +-
 .../app/controllers/wizard/step7_controller.js  |   74 +-
 .../app/controllers/wizard/step8_controller.js  |  228 +-
 ambari-web/app/data/HDP2/global_properties.js   | 1934 ----------------
 ambari-web/app/data/HDP2/ha_properties.js       |    2 +-
 ambari-web/app/data/HDP2/site_properties.js     | 2185 ++++++++++++++++++
 ambari-web/app/data/global_properties.js        | 1589 -------------
 ambari-web/app/data/service_configs.js          |   18 +-
 ambari-web/app/data/site_properties.js          | 1642 ++++++++++++-
 ambari-web/app/messages.js                      |    4 +
 ambari-web/app/models/quick_links.js            |    2 +-
 ambari-web/app/models/service.js                |    3 +-
 ambari-web/app/models/service_config.js         |    7 +-
 ambari-web/app/models/stack_service.js          |   49 +-
 .../highAvailability/resourceManager/step1.hbs  |    4 +
 ambari-web/app/utils/ajax/ajax.js               |    7 +-
 ambari-web/app/utils/config.js                  |  143 +-
 .../app/views/common/quick_view_link_view.js    |   12 +-
 ambari-web/app/views/main/admin/security.js     |    6 +-
 .../app/views/main/admin/security/add/step2.js  |    6 +-
 288 files changed, 9830 insertions(+), 8521 deletions(-)
----------------------------------------------------------------------



[3/5] AMBARI-6507. Create mappers for models. (onechiporenko)

Posted by on...@apache.org.
http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/hive-queries.json
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/hive-queries.json b/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/hive-queries.json
new file mode 100644
index 0000000..b601670
--- /dev/null
+++ b/contrib/views/jobs/src/main/resources/ui/app/scripts/assets/hive-queries.json
@@ -0,0 +1,232 @@
+{
+  "entities": [
+    {
+      "starttime": 1393443850756,
+      "events": [
+        {
+          "timestamp": 1393443875265,
+          "eventtype": "QUERY_COMPLETED",
+          "eventinfo": {}
+        },
+        {
+          "timestamp": 1393443850756,
+          "eventtype": "QUERY_SUBMITTED",
+          "eventinfo": {}
+        }
+      ],
+      "otherinfo": {
+        "status": false,
+        "query": "{\"queryText\":\"select state, count(id) as counts from school group by state sort by counts desc limit 10\",\"queryPlan\":{\"STAGE PLANS\":{\"Stage-1\":{\"Tez\":{\"DagName:\":\":1\",\"Vertices:\":{\"Reducer 2\":{\"Reduce Operator Tree:\":{\"Group By Operator\":{\"mode:\":\"mergepartial\",\"aggregations:\":[\"count(VALUE._col0)\"],\"keys:\":\"KEY._col0 (type: string)\",\"outputColumnNames:\":[\"_col0\",\"_col1\"],\"children\":{\"Select Operator\":{\"expressions:\":\"_col0 (type: string), _col1 (type: bigint)\",\"outputColumnNames:\":[\"_col0\",\"_col1\"],\"children\":{\"Reduce Output Operator\":{\"sort order:\":\"-\",\"value expressions:\":\"_col0 (type: string), _col1 (type: bigint)\",\"Statistics:\":\"Num rows: 125 Data size: 25082 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col1 (type: bigint)\"}},\"Statistics:\":\"Num rows: 125 Data size: 25082 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 125 Data size: 25082 B
 asic stats: COMPLETE Column stats: NONE\"}}},\"Reducer 3\":{\"Reduce Operator Tree:\":{\"Extract\":{\"children\":{\"Limit\":{\"children\":{\"Reduce Output Operator\":{\"sort order:\":\"-\",\"value expressions:\":\"_col0 (type: string), _col1 (type: bigint)\",\"Statistics:\":\"Num rows: 10 Data size: 2000 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col1 (type: bigint)\"}},\"Statistics:\":\"Num rows: 10 Data size: 2000 Basic stats: COMPLETE Column stats: NONE\",\"Number of rows:\":\"10\"}},\"Statistics:\":\"Num rows: 125 Data size: 25082 Basic stats: COMPLETE Column stats: NONE\"}}},\"Map 1\":{\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"school\",\"children\":{\"Select Operator\":{\"expressions:\":\"state (type: string), id (type: string)\",\"outputColumnNames:\":[\"state\",\"id\"],\"children\":{\"Group By Operator\":{\"mode:\":\"hash\",\"aggregations:\":[\"count(id)\"],\"keys:\":\"state (type: string)\",\"outputColumnNames:\":[\"_col0\",\"_col1\"],\"chi
 ldren\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"_col0 (type: string)\",\"sort order:\":\"+\",\"value expressions:\":\"_col1 (type: bigint)\",\"Statistics:\":\"Num rows: 251 Data size: 50365 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col0 (type: string)\"}},\"Statistics:\":\"Num rows: 251 Data size: 50365 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 251 Data size: 50365 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 251 Data size: 50365 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Reducer 4\":{\"Reduce Operator Tree:\":{\"Extract\":{\"children\":{\"Limit\":{\"children\":{\"File Output Operator\":{\"Statistics:\":\"Num rows: 10 Data size: 2000 Basic stats: COMPLETE Column stats: NONE\",\"compressed:\":\"false\",\"table:\":{\"serde:\":\"org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe\",\"input format:\":\"org.apache.hadoop.mapred.TextInputFormat\",\"output format:\":\"org.apach
 e.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat\"}}},\"Statistics:\":\"Num rows: 10 Data size: 2000 Basic stats: COMPLETE Column stats: NONE\",\"Number of rows:\":\"10\"}},\"Statistics:\":\"Num rows: 10 Data size: 2000 Basic stats: COMPLETE Column stats: NONE\"}}}},\"Edges:\":{\"Reducer 2\":{\"parent\":\"Map 1\",\"type\":\"SIMPLE_EDGE\"},\"Reducer 3\":{\"parent\":\"Reducer 2\",\"type\":\"SIMPLE_EDGE\"},\"Reducer 4\":{\"parent\":\"Reducer 3\",\"type\":\"SIMPLE_EDGE\"}}}},\"Stage-0\":{\"Fetch Operator\":{\"limit:\":\"10\",\"Processor Tree:\":{\"ListSink\":{}}}}},\"STAGE DEPENDENCIES\":{\"Stage-1\":{\"ROOT STAGE\":\"TRUE\"},\"Stage-0\":{\"ROOT STAGE\":\"TRUE\"}}}}"
+      },
+      "primaryfilters": {
+        "user": [
+          "hive"
+        ]
+      },
+      "entity": "hive_20140226144444_6301b51e-d52c-4618-995f-573e3f59006c",
+      "entitytype": "HIVE_QUERY_ID"
+    },
+    {
+      "starttime": 1394569191001,
+      "events": [
+        {
+          "timestamp": 1394569191001,
+          "eventtype": "QUERY_SUBMITTED",
+          "eventinfo": {}
+        }
+      ],
+      "otherinfo": {
+        "query": "{\"queryText\":\"select c_last_name, c_first_name, ca_city, bought_city,\\n                                 ss_ticket_number, amt, profit\\n                          from (select ss_ticket_number,\\n                                       ss_customer_sk,\\n                                       ca_city as bought_city,\\n                                       sum(ss_coupon_amt) as amt,\\n                                       sum(ss_net_profit) as profit\\n                                from store_sales, date_dim, store, household_demographics, customer_address\\n                                where store_sales.ss_sold_date_sk = date_dim.d_date_sk\\n                                  and store_sales.ss_store_sk = store.s_store_sk\\n                                  and store_sales.ss_hdemo_sk = household_demographics.hd_demo_sk\\n                                  and store_sales.ss_addr_sk = customer_address.ca_address_sk\\n                                  and (hou
 sehold_demographics.hd_dep_count = 4\\n                                       or household_demographics.hd_vehicle_count= 3)\\n                                  and date_dim.d_dow in (6,0)\\n                                  and date_dim.d_year in (1999, 1999+1, 1999+2)\\n                                  and store.s_city in ('Fairview', 'Fairview', 'Fairview', 'Midway', 'Fairview')\\n                                group by ss_ticket_number, ss_customer_sk, ss_addr_sk, ca_city) dn,\\n                                customer, customer_address current_addr\\n                          where dn.ss_customer_sk = customer.c_customer_sk\\n                            and customer.c_current_addr_sk = current_addr.ca_address_sk\\n                            and current_addr.ca_city <> dn.bought_city\\n                          order by c_last_name, c_first_name, ca_city, bought_city, ss_ticket_number\\n                          limit 100\",\"queryPlan\":{\"STAGE PLANS\":{\"Stage-1\":{\"Tez\"
 :{\"DagName:\":\"hrt_qa_20140311131919_1d932567-71c2-4341-9b50-6df1f58a9114:1\",\"Vertices:\":{\"Reducer 3\":{\"Reduce Operator Tree:\":{\"Group By Operator\":{\"mode:\":\"mergepartial\",\"aggregations:\":[\"sum(VALUE._col0)\",\"sum(VALUE._col1)\"],\"keys:\":\"KEY._col0 (type: int), KEY._col1 (type: int), KEY._col2 (type: int), KEY._col3 (type: string)\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\",\"_col3\",\"_col4\",\"_col5\"],\"children\":{\"Select Operator\":{\"expressions:\":\"_col0 (type: int), _col1 (type: int), _col3 (type: string), _col4 (type: decimal(17,2)), _col5 (type: decimal(17,2))\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\",\"_col3\",\"_col4\"],\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"_col1 (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"_col0 (type: int), _col1 (type: int), _col2 (type: string), _col3 (type: decimal(17,2)), _col4 (type: decimal(17,2))\",\"Statistics:\":\"Num rows: 16473 Data size
 : 21775806 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col1 (type: int)\"}},\"Statistics:\":\"Num rows: 16473 Data size: 21775806 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 16473 Data size: 21775806 Basic stats: COMPLETE Column stats: NONE\"}}},\"Map 1\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"filterExpr:\":\"((hd_dep_count = 4) or (hd_vehicle_count = 3)) (type: boolean)\",\"alias:\":\"household_demographics\",\"children\":{\"Filter Operator\":{\"predicate:\":\"((hd_dep_count = 4) or (hd_vehicle_count = 3)) (type: boolean)\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"hd_demo_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"hd_demo_sk (type: int), hd_dep_count (type: int), hd_vehicle_count (type: int)\",\"Statistics:\":\"Num rows: 7200 Data size: 770400 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"hd_demo_sk (type: int)\"}},
 \"Statistics:\":\"Num rows: 7200 Data size: 770400 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 7200 Data size: 770400 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 2\":{\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"store_sales\",\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"d_date_sk (type: int)\",\"0\":\"ss_sold_date_sk (type: int)\"},\"outputColumnNames:\":[\"_col0\",\"_col3\",\"_col5\",\"_col6\",\"_col8\",\"_col18\",\"_col21\",\"_col22\",\"_col25\",\"_col31\",\"_col32\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"UDFToDouble(s_store_sk) (type: double)\",\"0\":\"UDFToDouble(_col22) (type: double)\"},\"outputColumnNames:\":[\"_col0\",\"_col3\",\"_col5\",\"_col6\",\"_col8\",\"_col18\",\"_col21\",\"_col22\",\"_col25\",\"_col31\",\"_col32\",\"_col55\",\"_col77\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"hd_demo_sk (type: int)\",\"0\":\"_col5 (type: int)\"},\"outputColumnNames:\":[\"_col0\",\"_col22\",\"_c
 ol31\",\"_col34\",\"_col36\",\"_col37\",\"_col39\",\"_col49\",\"_col52\",\"_col53\",\"_col56\",\"_col62\",\"_col63\",\"_col86\",\"_col89\",\"_col90\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"ca_address_sk (type: int)\",\"0\":\"_col37 (type: int)\"},\"outputColumnNames:\":[\"_col0\",\"_col3\",\"_col4\",\"_col7\",\"_col29\",\"_col38\",\"_col41\",\"_col43\",\"_col44\",\"_col46\",\"_col56\",\"_col59\",\"_col60\",\"_col63\",\"_col69\",\"_col70\",\"_col93\",\"_col99\"],\"children\":{\"Filter Operator\":{\"predicate:\":\"((((((((_col38 = _col63) and (_col60 = _col7)) and (_col43 = _col0)) and (_col44 = _col93)) and ((_col3 = 4) or (_col4 = 3))) and (_col70) IN (6, 0)) and (_col69) IN (1999, (1999 + 1), (1999 + 2))) and (_col29) IN ('Fairview', 'Fairview', 'Fairview', 'Midway', 'Fairview')) (type: boolean)\",\"children\":{\"Select Operator\":{\"expressions:\":\"_col46 (type: int), _col41 (type: int), _col44 (type: int), _col99 (type: string), _col56 (type: decimal(7,2)), _co
 l59 (type: decimal(7,2))\",\"outputColumnNames:\":[\"_col46\",\"_col41\",\"_col44\",\"_col99\",\"_col56\",\"_col59\"],\"children\":{\"Group By Operator\":{\"mode:\":\"hash\",\"aggregations:\":[\"sum(_col56)\",\"sum(_col59)\"],\"keys:\":\"_col46 (type: int), _col41 (type: int), _col44 (type: int), _col99 (type: string)\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\",\"_col3\",\"_col4\",\"_col5\"],\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"_col0 (type: int), _col1 (type: int), _col2 (type: int), _col3 (type: string)\",\"sort order:\":\"++++\",\"value expressions:\":\"_col4 (type: decimal(17,2)), _col5 (type: decimal(17,2))\",\"Statistics:\":\"Num rows: 32946 Data size: 43551613 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col0 (type: int), _col1 (type: int), _col2 (type: int), _col3 (type: string)\"}},\"Statistics:\":\"Num rows: 32946 Data size: 43551613 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num 
 rows: 32946 Data size: 43551613 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 32946 Data size: 43551613 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 4217199 Data size: 5574753280 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{ca_address_sk} {ca_city}\",\"0\":\"{_col86} {_col89} {_col90} {_col0} {_col22} {_col31} {_col34} {_col36} {_col37} {_col39} {_col49} {_col52} {_col53} {_col56} {_col62} {_col63}\"}}},\"Statistics:\":\"Num rows: 3833817 Data size: 5067957248 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{hd_demo_sk} {hd_dep_count} {hd_vehicle_count}\",\"0\":\"{_col55} {_col77} {_col0} {_col3} {_col5} {_col6} {_col8} {_col18} {_col21} {_col22} {_col25} {_col31} {_col32}\"}}},\"Statistics:\":\"Num rows: 3485288 Data size: 4607233536 Basic stats: COMPLETE Column st
 ats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{s_store_sk} {s_city}\",\"0\":\"{_col0} {_col3} {_col5} {_col6} {_col8} {_col18} {_col21} {_col22} {_col25} {_col31} {_col32}\"}}},\"Statistics:\":\"Num rows: 3168444 Data size: 4188394240 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{d_date_sk} {d_year} {d_dow}\",\"0\":\"{ss_sold_date_sk} {ss_customer_sk} {ss_hdemo_sk} {ss_addr_sk} {ss_ticket_number} {ss_coupon_amt} {ss_net_profit} {ss_store_sk}\"}}},\"Statistics:\":\"Num rows: 2880404 Data size: 3807631184 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 5\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"customer\",\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"c_customer_sk (type: int)\",\"0\":\"_col1 (type: int)\"},\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\",\"_col3\",\"_col4\",\"_col5\
 ",\"_col9\",\"_col13\",\"_col14\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"ca_address_sk (type: int)\",\"0\":\"_col9 (type: int)\"},\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\",\"_col3\",\"_col4\",\"_col5\",\"_col9\",\"_col13\",\"_col14\",\"_col25\",\"_col31\"],\"children\":{\"Filter Operator\":{\"predicate:\":\"(((_col1 = _col5) and (_col9 = _col25)) and (_col31 <> _col2)) (type: boolean)\",\"children\":{\"Select Operator\":{\"expressions:\":\"_col14 (type: string), _col13 (type: string), _col31 (type: string), _col2 (type: string), _col0 (type: int), _col3 (type: decimal(17,2)), _col4 (type: decimal(17,2))\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\",\"_col3\",\"_col4\",\"_col5\",\"_col6\"],\"children\":{\"Reduce Output Operator\":{\"TopN Hash Memory Usage:\":\"0.04\",\"sort order:\":\"+++++\",\"value expressions:\":\"_col0 (type: string), _col1 (type: string), _col2 (type: string), _col3 (type: string), _col4 (type: int), _col5 (type: decimal(1
 7,2)), _col6 (type: decimal(17,2))\",\"Statistics:\":\"Num rows: 30250 Data size: 25902518 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col0 (type: string), _col1 (type: string), _col2 (type: string), _col3 (type: string), _col4 (type: int)\"}},\"Statistics:\":\"Num rows: 30250 Data size: 25902518 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 30250 Data size: 25902518 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 121000 Data size: 103610072 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{ca_address_sk} {ca_city}\",\"0\":\"{_col0} {_col1} {_col2} {_col3} {_col4} {_col5} {_col9} {_col13} {_col14}\"}}},\"Statistics:\":\"Num rows: 110000 Data size: 94190976 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{c_customer_sk} {c_current_addr_sk} {c_first_nam
 e} {c_last_name}\",\"0\":\"{_col0} {_col1} {_col2} {_col3} {_col4}\"}}},\"Statistics:\":\"Num rows: 100000 Data size: 85628164 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 4\":{\"Map Operator Tree:\":[{\"TableScan\":{\"filterExpr:\":\"((d_dow) IN (6, 0) and (d_year) IN (1999, (1999 + 1), (1999 + 2))) (type: boolean)\",\"alias:\":\"date_dim\",\"children\":{\"Filter Operator\":{\"predicate:\":\"((d_dow) IN (6, 0) and (d_year) IN (1999, (1999 + 1), (1999 + 2))) (type: boolean)\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"d_date_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"d_date_sk (type: int), d_year (type: int), d_dow (type: int)\",\"Statistics:\":\"Num rows: 18262 Data size: 20435178 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"d_date_sk (type: int)\"}},\"Statistics:\":\"Num rows: 18262 Data size: 20435178 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 73049 Data size: 817418
 31 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 7\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"current_addr\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"ca_address_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"ca_address_sk (type: int), ca_city (type: string)\",\"Statistics:\":\"Num rows: 50000 Data size: 55975728 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"ca_address_sk (type: int)\"}},\"Statistics:\":\"Num rows: 50000 Data size: 55975728 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Reducer 6\":{\"Reduce Operator Tree:\":{\"Extract\":{\"children\":{\"Limit\":{\"children\":{\"File Output Operator\":{\"Statistics:\":\"Num rows: 100 Data size: 85600 Basic stats: COMPLETE Column stats: NONE\",\"compressed:\":\"false\",\"table:\":{\"serde:\":\"org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe\",\"input format:\":\"org.apache.hadoop.mapred.TextInputFormat\
 ",\"output format:\":\"org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat\"}}},\"Statistics:\":\"Num rows: 100 Data size: 85600 Basic stats: COMPLETE Column stats: NONE\",\"Number of rows:\":\"100\"}},\"Statistics:\":\"Num rows: 30250 Data size: 25902518 Basic stats: COMPLETE Column stats: NONE\"}}},\"Map 9\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"filterExpr:\":\"(s_city) IN ('Fairview', 'Fairview', 'Fairview', 'Midway', 'Fairview') (type: boolean)\",\"alias:\":\"store\",\"children\":{\"Filter Operator\":{\"predicate:\":\"(s_city) IN ('Fairview', 'Fairview', 'Fairview', 'Midway', 'Fairview') (type: boolean)\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"UDFToDouble(s_store_sk) (type: double)\",\"sort order:\":\"+\",\"value expressions:\":\"s_store_sk (type: int), s_city (type: string)\",\"Statistics:\":\"Num rows: 6 Data size: 12816 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"UDFToD
 ouble(s_store_sk) (type: double)\"}},\"Statistics:\":\"Num rows: 6 Data size: 12816 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 12 Data size: 25632 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 8\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"customer_address\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"ca_address_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"ca_address_sk (type: int), ca_city (type: string)\",\"Statistics:\":\"Num rows: 50000 Data size: 55975728 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"ca_address_sk (type: int)\"}},\"Statistics:\":\"Num rows: 50000 Data size: 55975728 Basic stats: COMPLETE Column stats: NONE\"}}]}},\"Edges:\":{\"Reducer 3\":{\"parent\":\"Map 2\",\"type\":\"SIMPLE_EDGE\"},\"Map 2\":[{\"parent\":\"Map 1\",\"type\":\"BROADCAST_EDGE\"},{\"parent\":\"Map 4\",\"type\":\"BROADCAST_EDGE\"},{\"parent\"
 :\"Map 8\",\"type\":\"BROADCAST_EDGE\"},{\"parent\":\"Map 9\",\"type\":\"BROADCAST_EDGE\"}],\"Map 5\":[{\"parent\":\"Reducer 3\",\"type\":\"BROADCAST_EDGE\"},{\"parent\":\"Map 7\",\"type\":\"BROADCAST_EDGE\"}],\"Reducer 6\":{\"parent\":\"Map 5\",\"type\":\"SIMPLE_EDGE\"}}}},\"Stage-0\":{\"Fetch Operator\":{\"limit:\":\"100\",\"Processor Tree:\":{\"ListSink\":{}}}}},\"STAGE DEPENDENCIES\":{\"Stage-1\":{\"ROOT STAGE\":\"TRUE\"},\"Stage-0\":{\"ROOT STAGE\":\"TRUE\"}}}}"
+      },
+      "primaryfilters": {
+        "user": [
+          "hrt_qa"
+        ]
+      },
+      "entity": "hrt_qa_20140311131919_1d932567-71c2-4341-9b50-6df1f58a9114",
+      "entitytype": "HIVE_QUERY_ID"
+    },
+    {
+      "starttime": 1393439112167,
+      "events": [
+        {
+          "timestamp": 1393439112748,
+          "eventtype": "QUERY_COMPLETED",
+          "eventinfo": {}
+        },
+        {
+          "timestamp": 1393439112167,
+          "eventtype": "QUERY_SUBMITTED",
+          "eventinfo": {}
+        }
+      ],
+      "otherinfo": {
+        "status": false,
+        "query": "{\"queryText\":\"show tables\",\"queryPlan\":{\"STAGE PLANS\":{\"Stage-1\":{\"Fetch Operator\":{\"limit:\":\"-1\",\"Processor Tree:\":{\"ListSink\":{}}}},\"Stage-0\":{\"Show Table Operator:\":{\"Show Tables\":{\"database name:\":\"default\"}}}},\"STAGE DEPENDENCIES\":{\"Stage-1\":{\"ROOT STAGE\":\"TRUE\"},\"Stage-0\":{\"ROOT STAGE\":\"TRUE\"}}}}"
+      },
+      "primaryfilters": {
+        "user": [
+          "hive"
+        ]
+      },
+      "entity": "hive_20140226132525_780b8f71-bd4f-4daf-b0c3-4584920186d5",
+      "entitytype": "HIVE_QUERY_ID"
+    },
+    {
+      "starttime": 1393031638459,
+      "events": [
+        {
+          "timestamp": 1393032494585,
+          "eventtype": "QUERY_COMPLETED",
+          "eventinfo": {}
+        },
+        {
+          "timestamp": 1393031638459,
+          "eventtype": "QUERY_SUBMITTED",
+          "eventinfo": {}
+        }
+      ],
+      "otherinfo": {
+        "status": true,
+        "query": "{\"queryText\":\"\\nselect cs1.product_name ,cs1.store_name ,cs1.store_zip ,cs1.b_street_number ,cs1.b_streen_name ,cs1.b_city\\n     ,cs1.b_zip ,cs1.c_street_number ,cs1.c_street_name ,cs1.c_city ,cs1.c_zip ,cs1.syear ,cs1.cnt\\n     ,cs1.s1 ,cs1.s2 ,cs1.s3\\n     ,cs2.s1 ,cs2.s2 ,cs2.s3 ,cs2.syear ,cs2.cnt\\nfrom\\n(select i_product_name as product_name ,i_item_sk as item_sk ,s_store_name as store_name\\n     ,s_zip as store_zip ,ad1.ca_street_number as b_street_number ,ad1.ca_street_name as b_streen_name\\n     ,ad1.ca_city as b_city ,ad1.ca_zip as b_zip ,ad2.ca_street_number as c_street_number\\n     ,ad2.ca_street_name as c_street_name ,ad2.ca_city as c_city ,ad2.ca_zip as c_zip\\n     ,d1.d_year as syear ,d2.d_year as fsyear ,d3.d_year as s2year ,count(*) as cnt\\n     ,sum(ss_wholesale_cost) as s1 ,sum(ss_list_price) as s2 ,sum(ss_coupon_amt) as s3\\n  FROM   store_sales\\n        JOIN store_returns ON store_sales.ss_item_sk = store_returns.sr_item_sk and st
 ore_sales.ss_ticket_number = store_returns.sr_ticket_number\\n        JOIN customer ON store_sales.ss_customer_sk = customer.c_customer_sk\\n        JOIN date_dim d1 ON store_sales.ss_sold_date_sk = d1.d_date_sk\\n        JOIN date_dim d2 ON customer.c_first_sales_date_sk = d2.d_date_sk \\n        JOIN date_dim d3 ON customer.c_first_shipto_date_sk = d3.d_date_sk\\n        JOIN store ON store_sales.ss_store_sk = store.s_store_sk\\n        JOIN customer_demographics cd1 ON store_sales.ss_cdemo_sk= cd1.cd_demo_sk\\n        JOIN customer_demographics cd2 ON customer.c_current_cdemo_sk = cd2.cd_demo_sk\\n        JOIN promotion ON store_sales.ss_promo_sk = promotion.p_promo_sk\\n        JOIN household_demographics hd1 ON store_sales.ss_hdemo_sk = hd1.hd_demo_sk\\n        JOIN household_demographics hd2 ON customer.c_current_hdemo_sk = hd2.hd_demo_sk\\n        JOIN customer_address ad1 ON store_sales.ss_addr_sk = ad1.ca_address_sk\\n        JOIN customer_address ad2 ON customer.c_current_
 addr_sk = ad2.ca_address_sk\\n        JOIN income_band ib1 ON hd1.hd_income_band_sk = ib1.ib_income_band_sk\\n        JOIN income_band ib2 ON hd2.hd_income_band_sk = ib2.ib_income_band_sk\\n        JOIN item ON store_sales.ss_item_sk = item.i_item_sk\\n        JOIN\\n (select cs_item_sk\\n        ,sum(cs_ext_list_price) as sale,sum(cr_refunded_cash+cr_reversed_charge+cr_store_credit) as refund\\n  from catalog_sales JOIN catalog_returns\\n  ON catalog_sales.cs_item_sk = catalog_returns.cr_item_sk\\n    and catalog_sales.cs_order_number = catalog_returns.cr_order_number\\n  group by cs_item_sk\\n  having sum(cs_ext_list_price)>2*sum(cr_refunded_cash+cr_reversed_charge+cr_store_credit)) cs_ui\\nON store_sales.ss_item_sk = cs_ui.cs_item_sk\\n  WHERE  \\n         cd1.cd_marital_status <> cd2.cd_marital_status and\\n         i_color in ('maroon','burnished','dim','steel','navajo','chocolate') and\\n         i_current_price between 35 and 35 + 10 and\\n         i_current_price between 35 
 + 1 and 35 + 15\\ngroup by i_product_name ,i_item_sk ,s_store_name ,s_zip ,ad1.ca_street_number\\n       ,ad1.ca_street_name ,ad1.ca_city ,ad1.ca_zip ,ad2.ca_street_number\\n       ,ad2.ca_street_name ,ad2.ca_city ,ad2.ca_zip ,d1.d_year ,d2.d_year ,d3.d_year\\n) cs1\\nJOIN\\n(select i_product_name as product_name ,i_item_sk as item_sk ,s_store_name as store_name\\n     ,s_zip as store_zip ,ad1.ca_street_number as b_street_number ,ad1.ca_street_name as b_streen_name\\n     ,ad1.ca_city as b_city ,ad1.ca_zip as b_zip ,ad2.ca_street_number as c_street_number\\n     ,ad2.ca_street_name as c_street_name ,ad2.ca_city as c_city ,ad2.ca_zip as c_zip\\n     ,d1.d_year as syear ,d2.d_year as fsyear ,d3.d_year as s2year ,count(*) as cnt\\n     ,sum(ss_wholesale_cost) as s1 ,sum(ss_list_price) as s2 ,sum(ss_coupon_amt) as s3\\n  FROM   store_sales\\n        JOIN store_returns ON store_sales.ss_item_sk = store_returns.sr_item_sk and store_sales.ss_ticket_number = store_returns.sr_ticket_number\\
 n        JOIN customer ON store_sales.ss_customer_sk = customer.c_customer_sk\\n        JOIN date_dim d1 ON store_sales.ss_sold_date_sk = d1.d_date_sk\\n        JOIN date_dim d2 ON customer.c_first_sales_date_sk = d2.d_date_sk \\n        JOIN date_dim d3 ON customer.c_first_shipto_date_sk = d3.d_date_sk\\n        JOIN store ON store_sales.ss_store_sk = store.s_store_sk\\n        JOIN customer_demographics cd1 ON store_sales.ss_cdemo_sk= cd1.cd_demo_sk\\n        JOIN customer_demographics cd2 ON customer.c_current_cdemo_sk = cd2.cd_demo_sk\\n        JOIN promotion ON store_sales.ss_promo_sk = promotion.p_promo_sk\\n        JOIN household_demographics hd1 ON store_sales.ss_hdemo_sk = hd1.hd_demo_sk\\n        JOIN household_demographics hd2 ON customer.c_current_hdemo_sk = hd2.hd_demo_sk\\n        JOIN customer_address ad1 ON store_sales.ss_addr_sk = ad1.ca_address_sk\\n        JOIN customer_address ad2 ON customer.c_current_addr_sk = ad2.ca_address_sk\\n        JOIN income_band ib1 ON
  hd1.hd_income_band_sk = ib1.ib_income_band_sk\\n        JOIN income_band ib2 ON hd2.hd_income_band_sk = ib2.ib_income_band_sk\\n        JOIN item ON store_sales.ss_item_sk = item.i_item_sk\\n        JOIN\\n (select cs_item_sk\\n        ,sum(cs_ext_list_price) as sale,sum(cr_refunded_cash+cr_reversed_charge+cr_store_credit) as refund\\n  from catalog_sales JOIN catalog_returns\\n  ON catalog_sales.cs_item_sk = catalog_returns.cr_item_sk\\n    and catalog_sales.cs_order_number = catalog_returns.cr_order_number\\n  group by cs_item_sk\\n  having sum(cs_ext_list_price)>2*sum(cr_refunded_cash+cr_reversed_charge+cr_store_credit)) cs_ui\\nON store_sales.ss_item_sk = cs_ui.cs_item_sk\\n  WHERE  \\n         cd1.cd_marital_status <> cd2.cd_marital_status and\\n         i_color in ('maroon','burnished','dim','steel','navajo','chocolate') and\\n         i_current_price between 35 and 35 + 10 and\\n         i_current_price between 35 + 1 and 35 + 15\\ngroup by i_product_name ,i_item_sk ,s_store
 _name ,s_zip ,ad1.ca_street_number\\n       ,ad1.ca_street_name ,ad1.ca_city ,ad1.ca_zip ,ad2.ca_street_number\\n       ,ad2.ca_street_name ,ad2.ca_city ,ad2.ca_zip ,d1.d_year ,d2.d_year ,d3.d_year\\n) cs2\\nON cs1.item_sk=cs2.item_sk\\nwhere \\n     cs1.syear = 2000 and\\n     cs2.syear = 2000 + 1 and\\n     cs2.cnt <= cs1.cnt and\\n     cs1.store_name = cs2.store_name and\\n     cs1.store_zip = cs2.store_zip\\norder by cs1.product_name ,cs1.store_name ,cs2.cnt\",\"queryPlan\":{\"STAGE PLANS\":{\"Stage-1\":{\"Tez\":{\"DagName:\":\"root_20140221171313_94b85642-2225-4317-ac6e-f337f6b1eeed:1\",\"Vertices:\":{\"Reducer 13\":{\"Reduce Operator Tree:\":{\"Group By Operator\":{\"mode:\":\"mergepartial\",\"aggregations:\":[\"sum(VALUE._col0)\",\"sum(VALUE._col1)\"],\"keys:\":\"KEY._col0 (type: int)\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\"],\"children\":{\"Filter Operator\":{\"predicate:\":\"(_col1 > (2 * _col2)) (type: boolean)\",\"children\":{\"Select Operator\":{\"expressi
 ons:\":\"_col0 (type: int)\",\"outputColumnNames:\":[\"_col0\"],\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"_col0 (type: int)\",\"sort order:\":\"+\",\"Statistics:\":\"Num rows: 49506837 Data size: 4088301199 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col0 (type: int)\"}},\"Statistics:\":\"Num rows: 49506837 Data size: 4088301199 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 49506837 Data size: 4088301199 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 148520512 Data size: 12264903680 Basic stats: COMPLETE Column stats: NONE\"}}},\"Map 11\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"catalog_sales\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"cs_item_sk (type: int), cs_order_number (type: int)\",\"sort order:\":\"++\",\"value expressions:\":\"cs_item_sk (type: int), cs_ext_list_price (type: float)
 \",\"Statistics:\":\"Num rows: 270037278 Data size: 22299823475 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"cs_item_sk (type: int), cs_order_number (type: int)\"}},\"Statistics:\":\"Num rows: 270037278 Data size: 22299823475 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Reducer 14\":{\"Reduce Operator Tree:\":{\"Join Operator\":{\"outputColumnNames:\":[\"_col19\",\"_col39\",\"_col56\",\"_col57\",\"_col64\",\"_col73\",\"_col84\",\"_col141\",\"_col142\",\"_col145\",\"_col148\",\"_col179\",\"_col180\",\"_col183\",\"_col186\",\"_col203\",\"_col233\",\"_col263\",\"_col287\",\"_col292\",\"_col304\",\"_col308\"],\"children\":{\"Filter Operator\":{\"predicate:\":\"((((_col73 <> _col84) and (_col304) IN ('maroon', 'burnished', 'dim', 'steel', 'navajo', 'chocolate')) and _col292 BETWEEN 35 AND (35 + 10)) and _col292 BETWEEN (35 + 1) AND (35 + 15)) (type: boolean)\",\"children\":{\"Select Operator\":{\"expressions:\":\"_col308 (type: string), _col287 (type: int), _col1
 9 (type: string), _col39 (type: string), _col141 (type: string), _col142 (type: string), _col145 (type: string), _col148 (type: string), _col179 (type: string), _col180 (type: string), _col183 (type: string), _col186 (type: string), _col203 (type: int), _col233 (type: int), _col263 (type: int), _col56 (type: float), _col57 (type: float), _col64 (type: float)\",\"outputColumnNames:\":[\"_col308\",\"_col287\",\"_col19\",\"_col39\",\"_col141\",\"_col142\",\"_col145\",\"_col148\",\"_col179\",\"_col180\",\"_col183\",\"_col186\",\"_col203\",\"_col233\",\"_col263\",\"_col56\",\"_col57\",\"_col64\"],\"children\":{\"Group By Operator\":{\"mode:\":\"hash\",\"aggregations:\":[\"count()\",\"sum(_col56)\",\"sum(_col57)\",\"sum(_col64)\"],\"keys:\":\"_col308 (type: string), _col287 (type: int), _col19 (type: string), _col39 (type: string), _col141 (type: string), _col142 (type: string), _col145 (type: string), _col148 (type: string), _col179 (type: string), _col180 (type: string), _col183 (type: 
 string), _col186 (type: string), _col203 (type: int), _col233 (type: int), _col263 (type: int)\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\",\"_col3\",\"_col4\",\"_col5\",\"_col6\",\"_col7\",\"_col8\",\"_col9\",\"_col10\",\"_col11\",\"_col12\",\"_col13\",\"_col14\",\"_col15\",\"_col16\",\"_col17\",\"_col18\"],\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"_col0 (type: string), _col1 (type: int), _col2 (type: string), _col3 (type: string), _col4 (type: string), _col5 (type: string), _col6 (type: string), _col7 (type: string), _col8 (type: string), _col9 (type: string), _col10 (type: string), _col11 (type: string), _col12 (type: int), _col13 (type: int), _col14 (type: int)\",\"sort order:\":\"+++++++++++++++\",\"value expressions:\":\"_col15 (type: bigint), _col16 (type: double), _col17 (type: double), _col18 (type: double)\",\"Statistics:\":\"Num rows: 631896960 Data size: 32350201856 Basic stats: COMPLETE Column stats: NONE\",\"key expression
 s:\":\"_col0 (type: string), _col1 (type: int), _col2 (type: string), _col3 (type: string), _col4 (type: string), _col5 (type: string), _col6 (type: string), _col7 (type: string), _col8 (type: string), _col9 (type: string), _col10 (type: string), _col11 (type: string), _col12 (type: int), _col13 (type: int), _col14 (type: int)\"}},\"Statistics:\":\"Num rows: 631896960 Data size: 32350201856 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 631896960 Data size: 32350201856 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 631896960 Data size: 32350201856 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 5055175680 Data size: 258801614848 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"},{\"\":\"Inner Join 0 to 2\"}],\"condition expressions:\":{\"2\":\"\",\"1\":\"{VALUE._col0} {VALUE._col5} {VALUE._col17} {VALUE._col21}\",\"0\":\"{VALUE._col19} {VALUE._col39} {VALUE._col56} {
 VALUE._col57} {VALUE._col64} {VALUE._col73} {VALUE._col84} {VALUE._col141} {VALUE._col142} {VALUE._col145} {VALUE._col148} {VALUE._col184} {VALUE._col185} {VALUE._col188} {VALUE._col191} {VALUE._col203} {VALUE._col233} {VALUE._col263}\"}}}},\"Reducer 12\":{\"Reduce Operator Tree:\":{\"Join Operator\":{\"outputColumnNames:\":[\"_col15\",\"_col25\",\"_col60\",\"_col61\",\"_col62\"],\"children\":{\"Select Operator\":{\"expressions:\":\"_col15 (type: int), _col25 (type: float), _col60 (type: float), _col61 (type: float), _col62 (type: float)\",\"outputColumnNames:\":[\"_col15\",\"_col25\",\"_col60\",\"_col61\",\"_col62\"],\"children\":{\"Group By Operator\":{\"mode:\":\"hash\",\"aggregations:\":[\"sum(_col25)\",\"sum(((_col60 + _col61) + _col62))\"],\"keys:\":\"_col15 (type: int)\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\"],\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"_col0 (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"_col1 (t
 ype: double), _col2 (type: double)\",\"Statistics:\":\"Num rows: 297041024 Data size: 24529807360 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col0 (type: int)\"}},\"Statistics:\":\"Num rows: 297041024 Data size: 24529807360 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 297041024 Data size: 24529807360 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 297041024 Data size: 24529807360 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{VALUE._col23} {VALUE._col24} {VALUE._col25}\",\"0\":\"{VALUE._col15} {VALUE._col25}\"}}}},\"Map 10\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"ib1\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"ib_income_band_sk (type: int)\",\"sort order:\":\"+\",\"Statistics:\":\"Num rows: 20 Data size: 306 Basic stats: COMPLETE Column stats
 : NONE\",\"key expressions:\":\"ib_income_band_sk (type: int)\"}},\"Statistics:\":\"Num rows: 20 Data size: 306 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 19\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"customer\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"c_customer_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"c_current_cdemo_sk (type: int), c_current_hdemo_sk (type: int), c_current_addr_sk (type: int), c_first_shipto_date_sk (type: int), c_first_sales_date_sk (type: int)\",\"Statistics:\":\"Num rows: 1600000 Data size: 59241136 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"c_customer_sk (type: int)\"}},\"Statistics:\":\"Num rows: 1600000 Data size: 59241136 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 16\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"store_sales\",\"children\":{\"Reduce Output Operator
 \":{\"Map-reduce partition columns:\":\"ss_item_sk (type: int), ss_ticket_number (type: int)\",\"sort order:\":\"++\",\"value expressions:\":\"ss_sold_date_sk (type: int), ss_item_sk (type: int), ss_customer_sk (type: int), ss_cdemo_sk (type: int), ss_hdemo_sk (type: int), ss_addr_sk (type: int), ss_store_sk (type: int), ss_promo_sk (type: int), ss_wholesale_cost (type: float), ss_list_price (type: float), ss_coupon_amt (type: float)\",\"Statistics:\":\"Num rows: 550076554 Data size: 28161379051 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"ss_item_sk (type: int), ss_ticket_number (type: int)\"}},\"Statistics:\":\"Num rows: 550076554 Data size: 28161379051 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Reducer 17\":{\"Reduce Operator Tree:\":{\"Join Operator\":{\"outputColumnNames:\":[\"_col0\",\"_col2\",\"_col3\",\"_col4\",\"_col5\",\"_col6\",\"_col7\",\"_col8\",\"_col11\",\"_col12\",\"_col19\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"c_custome
 r_sk (type: int)\",\"0\":\"_col3 (type: int)\"},\"outputColumnNames:\":[\"_col0\",\"_col2\",\"_col4\",\"_col5\",\"_col6\",\"_col7\",\"_col8\",\"_col11\",\"_col12\",\"_col19\",\"_col51\",\"_col52\",\"_col53\",\"_col54\",\"_col55\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"d_date_sk (type: int)\",\"0\":\"_col0 (type: int)\"},\"outputColumnNames:\":[\"_col2\",\"_col4\",\"_col5\",\"_col6\",\"_col7\",\"_col8\",\"_col11\",\"_col12\",\"_col19\",\"_col28\",\"_col29\",\"_col30\",\"_col31\",\"_col32\",\"_col75\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"d_date_sk (type: int)\",\"0\":\"_col32 (type: int)\"},\"outputColumnNames:\":[\"_col6\",\"_col32\",\"_col34\",\"_col35\",\"_col36\",\"_col37\",\"_col38\",\"_col41\",\"_col42\",\"_col49\",\"_col58\",\"_col59\",\"_col60\",\"_col61\",\"_col105\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"d_date_sk (type: int)\",\"0\":\"_col61 (type: int)\"},\"outputColumnNames:\":[\"_col6\",\"_col36\",\"_col62\",\"_col6
 4\",\"_col65\",\"_col66\",\"_col67\",\"_col68\",\"_col71\",\"_col72\",\"_col79\",\"_col88\",\"_col89\",\"_col90\",\"_col135\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"s_store_sk (type: int)\",\"0\":\"_col67 (type: int)\"},\"outputColumnNames:\":[\"_col6\",\"_col36\",\"_col66\",\"_col92\",\"_col94\",\"_col95\",\"_col96\",\"_col98\",\"_col101\",\"_col102\",\"_col109\",\"_col118\",\"_col119\",\"_col120\",\"_col164\",\"_col184\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"cd_demo_sk (type: int)\",\"0\":\"_col94 (type: int)\"},\"outputColumnNames:\":[\"_col6\",\"_col36\",\"_col66\",\"_col95\",\"_col115\",\"_col123\",\"_col126\",\"_col127\",\"_col129\",\"_col132\",\"_col133\",\"_col140\",\"_col149\",\"_col150\",\"_col151\",\"_col192\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"cd_demo_sk (type: int)\",\"0\":\"_col149 (type: int)\"},\"outputColumnNames:\":[\"_col6\",\"_col36\",\"_col66\",\"_col95\",\"_col115\",\"_col123\",\"_col126\",\"_col127\",\
 "_col129\",\"_col132\",\"_col133\",\"_col140\",\"_col149\",\"_col161\",\"_col162\",\"_col203\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"p_promo_sk (type: int)\",\"0\":\"_col129 (type: int)\"},\"outputColumnNames:\":[\"_col6\",\"_col36\",\"_col66\",\"_col95\",\"_col115\",\"_col123\",\"_col126\",\"_col127\",\"_col132\",\"_col133\",\"_col140\",\"_col149\",\"_col160\",\"_col172\",\"_col173\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"hd_demo_sk (type: int)\",\"0\":\"_col126 (type: int)\"},\"outputColumnNames:\":[\"_col6\",\"_col36\",\"_col66\",\"_col95\",\"_col115\",\"_col123\",\"_col127\",\"_col132\",\"_col133\",\"_col140\",\"_col149\",\"_col160\",\"_col193\",\"_col194\",\"_col234\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"hd_demo_sk (type: int)\",\"0\":\"_col193 (type: int)\"},\"outputColumnNames:\":[\"_col6\",\"_col36\",\"_col66\",\"_col91\",\"_col102\",\"_col122\",\"_col130\",\"_col134\",\"_col139\",\"_col140\",\"_col147\",\"_col156\",\"
 _col167\",\"_col201\",\"_col241\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"ca_address_sk (type: int)\",\"0\":\"_col134 (type: int)\"},\"outputColumnNames:\":[\"_col1\",\"_col13\",\"_col43\",\"_col73\",\"_col98\",\"_col109\",\"_col129\",\"_col137\",\"_col146\",\"_col147\",\"_col154\",\"_col163\",\"_col174\",\"_col208\",\"_col249\",\"_col250\",\"_col253\",\"_col256\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"ca_address_sk (type: int)\",\"0\":\"_col208 (type: int)\"},\"outputColumnNames:\":[\"_col1\",\"_col8\",\"_col19\",\"_col39\",\"_col47\",\"_col56\",\"_col57\",\"_col64\",\"_col73\",\"_col84\",\"_col136\",\"_col137\",\"_col140\",\"_col143\",\"_col178\",\"_col208\",\"_col238\",\"_col264\",\"_col265\",\"_col268\",\"_col271\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"ib_income_band_sk (type: int)\",\"0\":\"_col8 (type: int)\"},\"outputColumnNames:\":[\"_col1\",\"_col19\",\"_col39\",\"_col47\",\"_col56\",\"_col57\",\"_col64\",\"_col73\",\"_c
 ol84\",\"_col136\",\"_col137\",\"_col140\",\"_col143\",\"_col174\",\"_col175\",\"_col178\",\"_col181\",\"_col193\",\"_col223\",\"_col253\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"ib_income_band_sk (type: int)\",\"0\":\"_col1 (type: int)\"},\"outputColumnNames:\":[\"_col19\",\"_col39\",\"_col47\",\"_col56\",\"_col57\",\"_col64\",\"_col73\",\"_col84\",\"_col136\",\"_col137\",\"_col140\",\"_col143\",\"_col179\",\"_col180\",\"_col183\",\"_col186\",\"_col198\",\"_col228\",\"_col258\"],\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"_col47 (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"_col19 (type: string), _col39 (type: string), _col56 (type: float), _col57 (type: float), _col64 (type: float), _col73 (type: string), _col84 (type: string), _col136 (type: string), _col137 (type: string), _col140 (type: string), _col143 (type: string), _col179 (type: string), _col180 (type: string), _col183 (type: string), _col186 (type: string),
  _col198 (type: int), _col228 (type: int), _col258 (type: int)\",\"Statistics:\":\"Num rows: 2297807104 Data size: 117637095424 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col47 (type: int)\"}},\"Statistics:\":\"Num rows: 2297807104 Data size: 117637095424 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"\",\"0\":\"{_col19} {_col39} {_col47} {_col56} {_col57} {_col64} {_col73} {_col84} {_col136} {_col137} {_col140} {_col143} {_col174} {_col175} {_col178} {_col181} {_col193} {_col223} {_col253}\"}}},\"Statistics:\":\"Num rows: 2088915456 Data size: 106942808064 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"\",\"0\":\"{_col1} {_col19} {_col39} {_col47} {_col56} {_col57} {_col64} {_col73} {_col84} {_col136} {_col137} {_col140} {_col143} {_col264} {_col265} {_col268} {_col271} {_col178} {_col208} {_col23
 8}\"}}},\"Statistics:\":\"Num rows: 1899014016 Data size: 97220730880 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{ca_street_number} {ca_street_name} {ca_city} {ca_zip}\",\"0\":\"{_col1} {_col98} {_col109} {_col129} {_col137} {_col146} {_col147} {_col154} {_col163} {_col174} {_col249} {_col250} {_col253} {_col256} {_col13} {_col43} {_col73}\"}}},\"Statistics:\":\"Num rows: 1726376320 Data size: 88382480384 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{ca_street_number} {ca_street_name} {ca_city} {ca_zip}\",\"0\":\"{_col241} {_col6} {_col36} {_col66} {_col91} {_col102} {_col122} {_col130} {_col139} {_col140} {_col147} {_col156} {_col167} {_col201}\"}}},\"Statistics:\":\"Num rows: 1569432960 Data size: 80347709440 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition e
 xpressions:\":{\"1\":\"{hd_income_band_sk}\",\"0\":\"{_col6} {_col36} {_col66} {_col234} {_col95} {_col115} {_col123} {_col127} {_col132} {_col133} {_col140} {_col149} {_col160} {_col194}\"}}},\"Statistics:\":\"Num rows: 1426757248 Data size: 73043369984 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{hd_income_band_sk}\",\"0\":\"{_col6} {_col36} {_col66} {_col95} {_col115} {_col123} {_col127} {_col132} {_col133} {_col140} {_col149} {_col160} {_col172} {_col173}\"}}},\"Statistics:\":\"Num rows: 1297052032 Data size: 66403065856 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"\",\"0\":\"{_col6} {_col36} {_col66} {_col95} {_col115} {_col123} {_col126} {_col127} {_col132} {_col133} {_col140} {_col149} {_col203} {_col161} {_col162}\"}}},\"Statistics:\":\"Num rows: 1179138176 Data size: 60366422016 Basic stats: COMPLETE Column 
 stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{cd_marital_status}\",\"0\":\"{_col6} {_col36} {_col66} {_col95} {_col115} {_col123} {_col126} {_col127} {_col129} {_col132} {_col133} {_col140} {_col192} {_col150} {_col151}\"}}},\"Statistics:\":\"Num rows: 1071943808 Data size: 54878564352 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{cd_marital_status}\",\"0\":\"{_col6} {_col36} {_col66} {_col164} {_col184} {_col92} {_col95} {_col96} {_col98} {_col101} {_col102} {_col109} {_col118} {_col119} {_col120}\"}}},\"Statistics:\":\"Num rows: 974494336 Data size: 49889603584 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{s_store_name} {s_zip}\",\"0\":\"{_col6} {_col36} {_col135} {_col62} {_col64} {_col65} {_col66} {_col68} {_col71} {_col72} {_col79} {_col88} {_col89} {_col90}\
 "}}},\"Statistics:\":\"Num rows: 885903936 Data size: 45354184704 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{d_year}\",\"0\":\"{_col6} {_col105} {_col32} {_col34} {_col35} {_col36} {_col37} {_col38} {_col41} {_col42} {_col49} {_col58} {_col59} {_col60}\"}}},\"Statistics:\":\"Num rows: 805367168 Data size: 41231077376 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{d_year}\",\"0\":\"{_col75} {_col2} {_col4} {_col5} {_col6} {_col7} {_col8} {_col11} {_col12} {_col19} {_col28} {_col29} {_col30} {_col31}\"}}},\"Statistics:\":\"Num rows: 732151936 Data size: 37482795008 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{d_year}\",\"0\":\"{_col2} {_col4} {_col5} {_col6} {_col7} {_col8} {_col11} {_col12} {_col19} {_col51} {_col52} {_col53} {_col54
 } {_col55}\"}}},\"Statistics:\":\"Num rows: 665592640 Data size: 34075269120 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{c_current_cdemo_sk} {c_current_hdemo_sk} {c_current_addr_sk} {c_first_shipto_date_sk} {c_first_sales_date_sk}\",\"0\":\"{_col0} {_col2} {_col4} {_col5} {_col6} {_col7} {_col8} {_col11} {_col12} {_col19}\"}}},\"Statistics:\":\"Num rows: 605084224 Data size: 30977517568 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"\",\"0\":\"{VALUE._col0} {VALUE._col2} {VALUE._col3} {VALUE._col4} {VALUE._col5} {VALUE._col6} {VALUE._col7} {VALUE._col8} {VALUE._col11} {VALUE._col12} {VALUE._col19}\"}}}},\"Map 18\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"cd1\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"cd_demo_sk (type: int)\",\"sort or
 der:\":\"+\",\"value expressions:\":\"cd_marital_status (type: string)\",\"Statistics:\":\"Num rows: 1920800 Data size: 31322 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"cd_demo_sk (type: int)\"}},\"Statistics:\":\"Num rows: 1920800 Data size: 31322 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Reducer 15\":{\"Reduce Operator Tree:\":{\"Group By Operator\":{\"mode:\":\"mergepartial\",\"aggregations:\":[\"count(VALUE._col0)\",\"sum(VALUE._col1)\",\"sum(VALUE._col2)\",\"sum(VALUE._col3)\"],\"keys:\":\"KEY._col0 (type: string), KEY._col1 (type: int), KEY._col2 (type: string), KEY._col3 (type: string), KEY._col4 (type: string), KEY._col5 (type: string), KEY._col6 (type: string), KEY._col7 (type: string), KEY._col8 (type: string), KEY._col9 (type: string), KEY._col10 (type: string), KEY._col11 (type: string), KEY._col12 (type: int), KEY._col13 (type: int), KEY._col14 (type: int)\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\",\"_col3\",\"_col4\",\"_col5\"
 ,\"_col6\",\"_col7\",\"_col8\",\"_col9\",\"_col10\",\"_col11\",\"_col12\",\"_col13\",\"_col14\",\"_col15\",\"_col16\",\"_col17\",\"_col18\"],\"children\":{\"Select Operator\":{\"expressions:\":\"_col0 (type: string), _col1 (type: int), _col10 (type: string), _col11 (type: string), _col12 (type: int), _col15 (type: bigint), _col16 (type: double), _col17 (type: double), _col18 (type: double), _col2 (type: string), _col3 (type: string), _col4 (type: string), _col5 (type: string), _col6 (type: string), _col7 (type: string), _col8 (type: string), _col9 (type: string)\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col10\",\"_col11\",\"_col12\",\"_col15\",\"_col16\",\"_col17\",\"_col18\",\"_col2\",\"_col3\",\"_col4\",\"_col5\",\"_col6\",\"_col7\",\"_col8\",\"_col9\"],\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"_col1 (type: int), _col2 (type: string), _col3 (type: string)\",\"sort order:\":\"+++\",\"value expressions:\":\"_col0 (type: string), _col2 (type
 : string), _col3 (type: string), _col4 (type: string), _col5 (type: string), _col6 (type: string), _col7 (type: string), _col8 (type: string), _col9 (type: string), _col10 (type: string), _col11 (type: string), _col12 (type: int), _col15 (type: bigint), _col16 (type: double), _col17 (type: double), _col18 (type: double)\",\"Statistics:\":\"Num rows: 315948480 Data size: 16175100928 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col1 (type: int), _col2 (type: string), _col3 (type: string)\"}},\"Statistics:\":\"Num rows: 315948480 Data size: 16175100928 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 315948480 Data size: 16175100928 Basic stats: COMPLETE Column stats: NONE\"}}},\"Map 25\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"catalog_returns\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"cr_item_sk (type: int), cr_order_number (type: int)\",\"sort order:\":\
 "++\",\"value expressions:\":\"cr_refunded_cash (type: float), cr_reversed_charge (type: float), cr_store_credit (type: float)\",\"Statistics:\":\"Num rows: 28798881 Data size: 1681267447 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"cr_item_sk (type: int), cr_order_number (type: int)\"}},\"Statistics:\":\"Num rows: 28798881 Data size: 1681267447 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 24\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"store_returns\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"sr_item_sk (type: int), sr_ticket_number (type: int)\",\"sort order:\":\"++\",\"Statistics:\":\"Num rows: 79762591 Data size: 2561677244 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"sr_item_sk (type: int), sr_ticket_number (type: int)\"}},\"Statistics:\":\"Num rows: 79762591 Data size: 2561677244 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 23\":{\"Map Ope
 rator Tree:\":[{\"TableScan\":{\"alias:\":\"item\",\"children\":{\"Filter Operator\":{\"predicate:\":\"(((i_color) IN ('maroon', 'burnished', 'dim', 'steel', 'navajo', 'chocolate') and i_current_price BETWEEN 35 AND (35 + 10)) and i_current_price BETWEEN (35 + 1) AND (35 + 15)) (type: boolean)\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"i_item_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"i_item_sk (type: int), i_current_price (type: float), i_color (type: string), i_product_name (type: string)\",\"Statistics:\":\"Num rows: 6000 Data size: 433429 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"i_item_sk (type: int)\"}},\"Statistics:\":\"Num rows: 6000 Data size: 433429 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 48000 Data size: 3467433 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 22\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"hd
 1\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"hd_demo_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"hd_income_band_sk (type: int)\",\"Statistics:\":\"Num rows: 7200 Data size: 713 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"hd_demo_sk (type: int)\"}},\"Statistics:\":\"Num rows: 7200 Data size: 713 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 21\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"hd2\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"hd_demo_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"hd_income_band_sk (type: int)\",\"Statistics:\":\"Num rows: 7200 Data size: 713 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"hd_demo_sk (type: int)\"}},\"Statistics:\":\"Num rows: 7200 Data size: 713 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 20\":{\"Execution mode:\":\"vectorized\",\"Ma
 p Operator Tree:\":[{\"TableScan\":{\"alias:\":\"cd2\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"cd_demo_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"cd_marital_status (type: string)\",\"Statistics:\":\"Num rows: 1920800 Data size: 31322 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"cd_demo_sk (type: int)\"}},\"Statistics:\":\"Num rows: 1920800 Data size: 31322 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 29\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"d3\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"d_date_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"d_year (type: int)\",\"Statistics:\":\"Num rows: 73049 Data size: 327991 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"d_date_sk (type: int)\"}},\"Statistics:\":\"Num rows: 73049 Data size: 327991 Basic stats: COMPLETE Column stats: NONE
 \"}}]},\"Reducer 27\":{\"Reduce Operator Tree:\":{\"Join Operator\":{\"outputColumnNames:\":[\"_col15\",\"_col25\",\"_col60\",\"_col61\",\"_col62\"],\"children\":{\"Select Operator\":{\"expressions:\":\"_col15 (type: int), _col25 (type: float), _col60 (type: float), _col61 (type: float), _col62 (type: float)\",\"outputColumnNames:\":[\"_col15\",\"_col25\",\"_col60\",\"_col61\",\"_col62\"],\"children\":{\"Group By Operator\":{\"mode:\":\"hash\",\"aggregations:\":[\"sum(_col25)\",\"sum(((_col60 + _col61) + _col62))\"],\"keys:\":\"_col15 (type: int)\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\"],\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"_col0 (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"_col1 (type: double), _col2 (type: double)\",\"Statistics:\":\"Num rows: 297041024 Data size: 24529807360 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col0 (type: int)\"}},\"Statistics:\":\"Num rows: 297041024 Data size:
  24529807360 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 297041024 Data size: 24529807360 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 297041024 Data size: 24529807360 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{VALUE._col23} {VALUE._col24} {VALUE._col25}\",\"0\":\"{VALUE._col15} {VALUE._col25}\"}}}},\"Reducer 28\":{\"Reduce Operator Tree:\":{\"Group By Operator\":{\"mode:\":\"mergepartial\",\"aggregations:\":[\"sum(VALUE._col0)\",\"sum(VALUE._col1)\"],\"keys:\":\"KEY._col0 (type: int)\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\"],\"children\":{\"Filter Operator\":{\"predicate:\":\"(_col1 > (2 * _col2)) (type: boolean)\",\"children\":{\"Select Operator\":{\"expressions:\":\"_col0 (type: int)\",\"outputColumnNames:\":[\"_col0\"],\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"_col0 (type: int)\",\"sort 
 order:\":\"+\",\"Statistics:\":\"Num rows: 49506837 Data size: 4088301199 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col0 (type: int)\"}},\"Statistics:\":\"Num rows: 49506837 Data size: 4088301199 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 49506837 Data size: 4088301199 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 148520512 Data size: 12264903680 Basic stats: COMPLETE Column stats: NONE\"}}},\"Map 26\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"catalog_sales\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"cs_item_sk (type: int), cs_order_number (type: int)\",\"sort order:\":\"++\",\"value expressions:\":\"cs_item_sk (type: int), cs_ext_list_price (type: float)\",\"Statistics:\":\"Num rows: 270037278 Data size: 22299823475 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"cs_item_sk (type: int), cs_order_number
  (type: int)\"}},\"Statistics:\":\"Num rows: 270037278 Data size: 22299823475 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 30\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"ad2\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"ca_address_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"ca_street_number (type: string), ca_street_name (type: string), ca_city (type: string), ca_zip (type: string)\",\"Statistics:\":\"Num rows: 800000 Data size: 9327264 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"ca_address_sk (type: int)\"}},\"Statistics:\":\"Num rows: 800000 Data size: 9327264 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 32\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"ad1\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"ca_address_sk (type: int)\",\"sort order:\":\"+\",\"value expressi
 ons:\":\"ca_street_number (type: string), ca_street_name (type: string), ca_city (type: string), ca_zip (type: string)\",\"Statistics:\":\"Num rows: 800000 Data size: 9327264 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"ca_address_sk (type: int)\"}},\"Statistics:\":\"Num rows: 800000 Data size: 9327264 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 31\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"customer\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"c_customer_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"c_current_cdemo_sk (type: int), c_current_hdemo_sk (type: int), c_current_addr_sk (type: int), c_first_shipto_date_sk (type: int), c_first_sales_date_sk (type: int)\",\"Statistics:\":\"Num rows: 1600000 Data size: 59241136 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"c_customer_sk (type: int)\"}},\"Statistics:\":\"Num rows: 1600000 Data s
 ize: 59241136 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 34\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"store\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"s_store_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"s_store_name (type: string), s_zip (type: string)\",\"Statistics:\":\"Num rows: 74 Data size: 15175 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"s_store_sk (type: int)\"}},\"Statistics:\":\"Num rows: 74 Data size: 15175 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 33\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"store_returns\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"sr_item_sk (type: int), sr_ticket_number (type: int)\",\"sort order:\":\"++\",\"Statistics:\":\"Num rows: 79762591 Data size: 2561677244 Basic stats: COMPLETE Column stats: NONE\",\"key expression
 s:\":\"sr_item_sk (type: int), sr_ticket_number (type: int)\"}},\"Statistics:\":\"Num rows: 79762591 Data size: 2561677244 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 1\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"hd1\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"hd_demo_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"hd_income_band_sk (type: int)\",\"Statistics:\":\"Num rows: 7200 Data size: 713 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"hd_demo_sk (type: int)\"}},\"Statistics:\":\"Num rows: 7200 Data size: 713 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 36\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"d2\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"d_date_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"d_year (type: int)\",\"Statistics:\":\"Num rows: 7
 3049 Data size: 327991 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"d_date_sk (type: int)\"}},\"Statistics:\":\"Num rows: 73049 Data size: 327991 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 2\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"hd2\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"hd_demo_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"hd_income_band_sk (type: int)\",\"Statistics:\":\"Num rows: 7200 Data size: 713 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"hd_demo_sk (type: int)\"}},\"Statistics:\":\"Num rows: 7200 Data size: 713 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 35\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"d1\",\"children\":{\"Filter Operator\":{\"predicate:\":\"(d_year = 2000) (type: boolean)\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition colu
 mns:\":\"d_date_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"d_year (type: int)\",\"Statistics:\":\"Num rows: 36524 Data size: 163993 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"d_date_sk (type: int)\"}},\"Statistics:\":\"Num rows: 36524 Data size: 163993 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 73049 Data size: 327991 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 3\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"promotion\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"p_promo_sk (type: int)\",\"sort order:\":\"+\",\"Statistics:\":\"Num rows: 450 Data size: 14450 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"p_promo_sk (type: int)\"}},\"Statistics:\":\"Num rows: 450 Data size: 14450 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 38\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableSca
 n\":{\"alias:\":\"catalog_returns\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"cr_item_sk (type: int), cr_order_number (type: int)\",\"sort order:\":\"++\",\"value expressions:\":\"cr_refunded_cash (type: float), cr_reversed_charge (type: float), cr_store_credit (type: float)\",\"Statistics:\":\"Num rows: 28798881 Data size: 1681267447 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"cr_item_sk (type: int), cr_order_number (type: int)\"}},\"Statistics:\":\"Num rows: 28798881 Data size: 1681267447 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Reducer 5\":{\"Reduce Operator Tree:\":{\"Join Operator\":{\"outputColumnNames:\":[\"_col0\",\"_col2\",\"_col3\",\"_col4\",\"_col5\",\"_col6\",\"_col7\",\"_col8\",\"_col11\",\"_col12\",\"_col19\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"c_customer_sk (type: int)\",\"0\":\"_col3 (type: int)\"},\"outputColumnNames:\":[\"_col0\",\"_col2\",\"_col4\",\"_col5\",\"_col6\",\"_col7\",
 \"_col8\",\"_col11\",\"_col12\",\"_col19\",\"_col51\",\"_col52\",\"_col53\",\"_col54\",\"_col55\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"d_date_sk (type: int)\",\"0\":\"_col0 (type: int)\"},\"outputColumnNames:\":[\"_col2\",\"_col4\",\"_col5\",\"_col6\",\"_col7\",\"_col8\",\"_col11\",\"_col12\",\"_col19\",\"_col28\",\"_col29\",\"_col30\",\"_col31\",\"_col32\",\"_col75\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"d_date_sk (type: int)\",\"0\":\"_col32 (type: int)\"},\"outputColumnNames:\":[\"_col6\",\"_col32\",\"_col34\",\"_col35\",\"_col36\",\"_col37\",\"_col38\",\"_col41\",\"_col42\",\"_col49\",\"_col58\",\"_col59\",\"_col60\",\"_col61\",\"_col105\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"d_date_sk (type: int)\",\"0\":\"_col61 (type: int)\"},\"outputColumnNames:\":[\"_col6\",\"_col36\",\"_col62\",\"_col64\",\"_col65\",\"_col66\",\"_col67\",\"_col68\",\"_col71\",\"_col72\",\"_col79\",\"_col88\",\"_col89\",\"_col90\",\"_col135\"],\"chi
 ldren\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"s_store_sk (type: int)\",\"0\":\"_col67 (type: int)\"},\"outputColumnNames:\":[\"_col6\",\"_col36\",\"_col66\",\"_col92\",\"_col94\",\"_col95\",\"_col96\",\"_col98\",\"_col101\",\"_col102\",\"_col109\",\"_col118\",\"_col119\",\"_col120\",\"_col164\",\"_col184\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"cd_demo_sk (type: int)\",\"0\":\"_col94 (type: int)\"},\"outputColumnNames:\":[\"_col6\",\"_col36\",\"_col66\",\"_col95\",\"_col115\",\"_col123\",\"_col126\",\"_col127\",\"_col129\",\"_col132\",\"_col133\",\"_col140\",\"_col149\",\"_col150\",\"_col151\",\"_col192\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"cd_demo_sk (type: int)\",\"0\":\"_col149 (type: int)\"},\"outputColumnNames:\":[\"_col6\",\"_col36\",\"_col66\",\"_col95\",\"_col115\",\"_col123\",\"_col126\",\"_col127\",\"_col129\",\"_col132\",\"_col133\",\"_col140\",\"_col149\",\"_col161\",\"_col162\",\"_col203\"],\"children\":{\"Map Join Operator\":
 {\"keys:\":{\"1\":\"p_promo_sk (type: int)\",\"0\":\"_col129 (type: int)\"},\"outputColumnNames:\":[\"_col6\",\"_col36\",\"_col66\",\"_col95\",\"_col115\",\"_col123\",\"_col126\",\"_col127\",\"_col132\",\"_col133\",\"_col140\",\"_col149\",\"_col160\",\"_col172\",\"_col173\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"hd_demo_sk (type: int)\",\"0\":\"_col126 (type: int)\"},\"outputColumnNames:\":[\"_col6\",\"_col36\",\"_col66\",\"_col95\",\"_col115\",\"_col123\",\"_col127\",\"_col132\",\"_col133\",\"_col140\",\"_col149\",\"_col160\",\"_col193\",\"_col194\",\"_col234\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"hd_demo_sk (type: int)\",\"0\":\"_col193 (type: int)\"},\"outputColumnNames:\":[\"_col6\",\"_col36\",\"_col66\",\"_col91\",\"_col102\",\"_col122\",\"_col130\",\"_col134\",\"_col139\",\"_col140\",\"_col147\",\"_col156\",\"_col167\",\"_col201\",\"_col241\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"ca_address_sk (type: int)\",\"0\":\"_col1
 34 (type: int)\"},\"outputColumnNames:\":[\"_col1\",\"_col13\",\"_col43\",\"_col73\",\"_col98\",\"_col109\",\"_col129\",\"_col137\",\"_col146\",\"_col147\",\"_col154\",\"_col163\",\"_col174\",\"_col208\",\"_col249\",\"_col250\",\"_col253\",\"_col256\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"ca_address_sk (type: int)\",\"0\":\"_col208 (type: int)\"},\"outputColumnNames:\":[\"_col1\",\"_col8\",\"_col19\",\"_col39\",\"_col47\",\"_col56\",\"_col57\",\"_col64\",\"_col73\",\"_col84\",\"_col136\",\"_col137\",\"_col140\",\"_col143\",\"_col178\",\"_col208\",\"_col238\",\"_col264\",\"_col265\",\"_col268\",\"_col271\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"ib_income_band_sk (type: int)\",\"0\":\"_col8 (type: int)\"},\"outputColumnNames:\":[\"_col1\",\"_col19\",\"_col39\",\"_col47\",\"_col56\",\"_col57\",\"_col64\",\"_col73\",\"_col84\",\"_col136\",\"_col137\",\"_col140\",\"_col143\",\"_col174\",\"_col175\",\"_col178\",\"_col181\",\"_col193\",\"_col223\",\"_co
 l253\"],\"children\":{\"Map Join Operator\":{\"keys:\":{\"1\":\"ib_income_band_sk (type: int)\",\"0\":\"_col1 (type: int)\"},\"outputColumnNames:\":[\"_col19\",\"_col39\",\"_col47\",\"_col56\",\"_col57\",\"_col64\",\"_col73\",\"_col84\",\"_col136\",\"_col137\",\"_col140\",\"_col143\",\"_col179\",\"_col180\",\"_col183\",\"_col186\",\"_col198\",\"_col228\",\"_col258\"],\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"_col47 (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"_col19 (type: string), _col39 (type: string), _col56 (type: float), _col57 (type: float), _col64 (type: float), _col73 (type: string), _col84 (type: string), _col136 (type: string), _col137 (type: string), _col140 (type: string), _col143 (type: string), _col179 (type: string), _col180 (type: string), _col183 (type: string), _col186 (type: string), _col198 (type: int), _col228 (type: int), _col258 (type: int)\",\"Statistics:\":\"Num rows: 2297807104 Data size: 117637095424 Basi
 c stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col47 (type: int)\"}},\"Statistics:\":\"Num rows: 2297807104 Data size: 117637095424 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"\",\"0\":\"{_col19} {_col39} {_col47} {_col56} {_col57} {_col64} {_col73} {_col84} {_col136} {_col137} {_col140} {_col143} {_col174} {_col175} {_col178} {_col181} {_col193} {_col223} {_col253}\"}}},\"Statistics:\":\"Num rows: 2088915456 Data size: 106942808064 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"\",\"0\":\"{_col1} {_col19} {_col39} {_col47} {_col56} {_col57} {_col64} {_col73} {_col84} {_col136} {_col137} {_col140} {_col143} {_col264} {_col265} {_col268} {_col271} {_col178} {_col208} {_col238}\"}}},\"Statistics:\":\"Num rows: 1899014016 Data size: 97220730880 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":
 [{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{ca_street_number} {ca_street_name} {ca_city} {ca_zip}\",\"0\":\"{_col1} {_col98} {_col109} {_col129} {_col137} {_col146} {_col147} {_col154} {_col163} {_col174} {_col249} {_col250} {_col253} {_col256} {_col13} {_col43} {_col73}\"}}},\"Statistics:\":\"Num rows: 1726376320 Data size: 88382480384 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{ca_street_number} {ca_street_name} {ca_city} {ca_zip}\",\"0\":\"{_col241} {_col6} {_col36} {_col66} {_col91} {_col102} {_col122} {_col130} {_col139} {_col140} {_col147} {_col156} {_col167} {_col201}\"}}},\"Statistics:\":\"Num rows: 1569432960 Data size: 80347709440 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{hd_income_band_sk}\",\"0\":\"{_col6} {_col36} {_col66} {_col234} {_col95} {_col115} {_col123} {_col127} {_co
 l132} {_col133} {_col140} {_col149} {_col160} {_col194}\"}}},\"Statistics:\":\"Num rows: 1426757248 Data size: 73043369984 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{hd_income_band_sk}\",\"0\":\"{_col6} {_col36} {_col66} {_col95} {_col115} {_col123} {_col127} {_col132} {_col133} {_col140} {_col149} {_col160} {_col172} {_col173}\"}}},\"Statistics:\":\"Num rows: 1297052032 Data size: 66403065856 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"\",\"0\":\"{_col6} {_col36} {_col66} {_col95} {_col115} {_col123} {_col126} {_col127} {_col132} {_col133} {_col140} {_col149} {_col203} {_col161} {_col162}\"}}},\"Statistics:\":\"Num rows: 1179138176 Data size: 60366422016 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{cd_marital_status}\",\"0\":\"{_
 col6} {_col36} {_col66} {_col95} {_col115} {_col123} {_col126} {_col127} {_col129} {_col132} {_col133} {_col140} {_col192} {_col150} {_col151}\"}}},\"Statistics:\":\"Num rows: 1071943808 Data size: 54878564352 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{cd_marital_status}\",\"0\":\"{_col6} {_col36} {_col66} {_col164} {_col184} {_col92} {_col95} {_col96} {_col98} {_col101} {_col102} {_col109} {_col118} {_col119} {_col120}\"}}},\"Statistics:\":\"Num rows: 974494336 Data size: 49889603584 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{s_store_name} {s_zip}\",\"0\":\"{_col6} {_col36} {_col135} {_col62} {_col64} {_col65} {_col66} {_col68} {_col71} {_col72} {_col79} {_col88} {_col89} {_col90}\"}}},\"Statistics:\":\"Num rows: 885903936 Data size: 45354184704 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"
 \":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{d_year}\",\"0\":\"{_col6} {_col105} {_col32} {_col34} {_col35} {_col36} {_col37} {_col38} {_col41} {_col42} {_col49} {_col58} {_col59} {_col60}\"}}},\"Statistics:\":\"Num rows: 805367168 Data size: 41231077376 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{d_year}\",\"0\":\"{_col75} {_col2} {_col4} {_col5} {_col6} {_col7} {_col8} {_col11} {_col12} {_col19} {_col28} {_col29} {_col30} {_col31}\"}}},\"Statistics:\":\"Num rows: 732151936 Data size: 37482795008 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{d_year}\",\"0\":\"{_col2} {_col4} {_col5} {_col6} {_col7} {_col8} {_col11} {_col12} {_col19} {_col51} {_col52} {_col53} {_col54} {_col55}\"}}},\"Statistics:\":\"Num rows: 665592640 Data size: 34075269120 Basic stats: COMPLETE Column stats: NONE\",\"condition 
 map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{c_current_cdemo_sk} {c_current_hdemo_sk} {c_current_addr_sk} {c_first_shipto_date_sk} {c_first_sales_date_sk}\",\"0\":\"{_col0} {_col2} {_col4} {_col5} {_col6} {_col7} {_col8} {_col11} {_col12} {_col19}\"}}},\"Statistics:\":\"Num rows: 605084224 Data size: 30977517568 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"\",\"0\":\"{VALUE._col0} {VALUE._col2} {VALUE._col3} {VALUE._col4} {VALUE._col5} {VALUE._col6} {VALUE._col7} {VALUE._col8} {VALUE._col11} {VALUE._col12} {VALUE._col19}\"}}}},\"Map 37\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"ib2\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"ib_income_band_sk (type: int)\",\"sort order:\":\"+\",\"Statistics:\":\"Num rows: 20 Data size: 306 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"
 ib_income_band_sk (type: int)\"}},\"Statistics:\":\"Num rows: 20 Data size: 306 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Reducer 7\":{\"Reduce Operator Tree:\":{\"Group By Operator\":{\"mode:\":\"mergepartial\",\"aggregations:\":[\"count(VALUE._col0)\",\"sum(VALUE._col1)\",\"sum(VALUE._col2)\",\"sum(VALUE._col3)\"],\"keys:\":\"KEY._col0 (type: string), KEY._col1 (type: int), KEY._col2 (type: string), KEY._col3 (type: string), KEY._col4 (type: string), KEY._col5 (type: string), KEY._col6 (type: string), KEY._col7 (type: string), KEY._col8 (type: string), KEY._col9 (type: string), KEY._col10 (type: string), KEY._col11 (type: string), KEY._col12 (type: int), KEY._col13 (type: int), KEY._col14 (type: int)\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\",\"_col3\",\"_col4\",\"_col5\",\"_col6\",\"_col7\",\"_col8\",\"_col9\",\"_col10\",\"_col11\",\"_col12\",\"_col13\",\"_col14\",\"_col15\",\"_col16\",\"_col17\",\"_col18\"],\"children\":{\"Select Operator\":{\"expressions:\":
 \"_col1 (type: int), _col12 (type: int), _col15 (type: bigint), _col16 (type: double), _col17 (type: double), _col18 (type: double), _col2 (type: string), _col3 (type: string)\",\"outputColumnNames:\":[\"_col1\",\"_col12\",\"_col15\",\"_col16\",\"_col17\",\"_col18\",\"_col2\",\"_col3\"],\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"_col1 (type: int), _col2 (type: string), _col3 (type: string)\",\"sort order:\":\"+++\",\"value expressions:\":\"_col2 (type: string), _col3 (type: string), _col12 (type: int), _col15 (type: bigint), _col16 (type: double), _col17 (type: double), _col18 (type: double)\",\"Statistics:\":\"Num rows: 315948480 Data size: 16175100928 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col1 (type: int), _col2 (type: string), _col3 (type: string)\"}},\"Statistics:\":\"Num rows: 315948480 Data size: 16175100928 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 315948480 Data size: 16175100928 B
 asic stats: COMPLETE Column stats: NONE\"}}},\"Map 39\":{\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"item\",\"children\":{\"Filter Operator\":{\"predicate:\":\"(((i_color) IN ('maroon', 'burnished', 'dim', 'steel', 'navajo', 'chocolate') and i_current_price BETWEEN 35 AND (35 + 10)) and i_current_price BETWEEN (35 + 1) AND (35 + 15)) (type: boolean)\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"i_item_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"i_item_sk (type: int), i_current_price (type: float), i_color (type: string), i_product_name (type: string)\",\"Statistics:\":\"Num rows: 6000 Data size: 433429 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"i_item_sk (type: int)\"}},\"Statistics:\":\"Num rows: 6000 Data size: 433429 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 48000 Data size: 3467433 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Reducer 6\":{\"Reduce Operator Tre
 e:\":{\"Join Operator\":{\"outputColumnNames:\":[\"_col19\",\"_col39\",\"_col56\",\"_col57\",\"_col64\",\"_col73\",\"_col84\",\"_col141\",\"_col142\",\"_col145\",\"_col148\",\"_col179\",\"_col180\",\"_col183\",\"_col186\",\"_col203\",\"_col233\",\"_col263\",\"_col287\",\"_col292\",\"_col304\",\"_col308\"],\"children\":{\"Filter Operator\":{\"predicate:\":\"((((_col73 <> _col84) and (_col304) IN ('maroon', 'burnished', 'dim', 'steel', 'navajo', 'chocolate')) and _col292 BETWEEN 35 AND (35 + 10)) and _col292 BETWEEN (35 + 1) AND (35 + 15)) (type: boolean)\",\"children\":{\"Select Operator\":{\"expressions:\":\"_col308 (type: string), _col287 (type: int), _col19 (type: string), _col39 (type: string), _col141 (type: string), _col142 (type: string), _col145 (type: string), _col148 (type: string), _col179 (type: string), _col180 (type: string), _col183 (type: string), _col186 (type: string), _col203 (type: int), _col233 (type: int), _col263 (type: int), _col56 (type: float), _col57 (type:
  float), _col64 (type: float)\",\"outputColumnNames:\":[\"_col308\",\"_col287\",\"_col19\",\"_col39\",\"_col141\",\"_col142\",\"_col145\",\"_col148\",\"_col179\",\"_col180\",\"_col183\",\"_col186\",\"_col203\",\"_col233\",\"_col263\",\"_col56\",\"_col57\",\"_col64\"],\"children\":{\"Group By Operator\":{\"mode:\":\"hash\",\"aggregations:\":[\"count()\",\"sum(_col56)\",\"sum(_col57)\",\"sum(_col64)\"],\"keys:\":\"_col308 (type: string), _col287 (type: int), _col19 (type: string), _col39 (type: string), _col141 (type: string), _col142 (type: string), _col145 (type: string), _col148 (type: string), _col179 (type: string), _col180 (type: string), _col183 (type: string), _col186 (type: string), _col203 (type: int), _col233 (type: int), _col263 (type: int)\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\",\"_col3\",\"_col4\",\"_col5\",\"_col6\",\"_col7\",\"_col8\",\"_col9\",\"_col10\",\"_col11\",\"_col12\",\"_col13\",\"_col14\",\"_col15\",\"_col16\",\"_col17\",\"_col18\"],\"children
 \":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"_col0 (type: string), _col1 (type: int), _col2 (type: string), _col3 (type: string), _col4 (type: string), _col5 (type: string), _col6 (type: string), _col7 (type: string), _col8 (type: string), _col9 (type: string), _col10 (type: string), _col11 (type: string), _col12 (type: int), _col13 (type: int), _col14 (type: int)\",\"sort order:\":\"+++++++++++++++\",\"value expressions:\":\"_col15 (type: bigint), _col16 (type: double), _col17 (type: double), _col18 (type: double)\",\"Statistics:\":\"Num rows: 631896960 Data size: 32350201856 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col0 (type: string), _col1 (type: int), _col2 (type: string), _col3 (type: string), _col4 (type: string), _col5 (type: string), _col6 (type: string), _col7 (type: string), _col8 (type: string), _col9 (type: string), _col10 (type: string), _col11 (type: string), _col12 (type: int), _col13 (type: int), _col14 (type: int)\"}
 },\"Statistics:\":\"Num rows: 631896960 Data size: 32350201856 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 631896960 Data size: 32350201856 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 631896960 Data size: 32350201856 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 5055175680 Data size: 258801614848 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"},{\"\":\"Inner Join 0 to 2\"}],\"condition expressions:\":{\"2\":\"\",\"1\":\"{VALUE._col0} {VALUE._col5} {VALUE._col17} {VALUE._col21}\",\"0\":\"{VALUE._col19} {VALUE._col39} {VALUE._col56} {VALUE._col57} {VALUE._col64} {VALUE._col73} {VALUE._col84} {VALUE._col141} {VALUE._col142} {VALUE._col145} {VALUE._col148} {VALUE._col184} {VALUE._col185} {VALUE._col188} {VALUE._col191} {VALUE._col203} {VALUE._col233} {VALUE._col263}\"}}}},\"Reducer 9\":{\"Reduce Operator Tree:\":{\"Extract\":{\"children\":{\"File Output Operato
 r\":{\"Statistics:\":\"Num rows: 7240486 Data size: 370679424 Basic stats: COMPLETE Column stats: NONE\",\"compressed:\":\"false\",\"table:\":{\"serde:\":\"org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe\",\"input format:\":\"org.apache.hadoop.mapred.TextInputFormat\",\"output format:\":\"org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat\"}}},\"Statistics:\":\"Num rows: 7240486 Data size: 370679424 Basic stats: COMPLETE Column stats: NONE\"}}},\"Reducer 8\":{\"Reduce Operator Tree:\":{\"Join Operator\":{\"outputColumnNames:\":[\"_col0\",\"_col2\",\"_col3\",\"_col4\",\"_col5\",\"_col6\",\"_col7\",\"_col8\",\"_col9\",\"_col10\",\"_col11\",\"_col12\",\"_col15\",\"_col16\",\"_col17\",\"_col18\",\"_col21\",\"_col22\",\"_col31\",\"_col34\",\"_col35\",\"_col36\",\"_col37\"],\"children\":{\"Filter Operator\":{\"predicate:\":\"(((((_col12 = 2000) and (_col31 = (2000 + 1))) and (_col34 <= _col15)) and (_col2 = _col21)) and (_col3 = _col22)) (type: boolean)\",\"children\":{\"Select
  Operator\":{\"expressions:\":\"_col0 (type: string), _col2 (type: string), _col3 (type: string), _col4 (type: string), _col5 (type: string), _col6 (type: string), _col7 (type: string), _col8 (type: string), _col9 (type: string), _col10 (type: string), _col11 (type: string), _col12 (type: int), _col15 (type: bigint), _col16 (type: double), _col17 (type: double), _col18 (type: double), _col35 (type: double), _col36 (type: double), _col37 (type: double), _col31 (type: int), _col34 (type: bigint)\",\"outputColumnNames:\":[\"_col0\",\"_col1\",\"_col2\",\"_col3\",\"_col4\",\"_col5\",\"_col6\",\"_col7\",\"_col8\",\"_col9\",\"_col10\",\"_col11\",\"_col12\",\"_col13\",\"_col14\",\"_col15\",\"_col16\",\"_col17\",\"_col18\",\"_col19\",\"_col20\"],\"children\":{\"Reduce Output Operator\":{\"sort order:\":\"+++\",\"value expressions:\":\"_col0 (type: string), _col1 (type: string), _col2 (type: string), _col3 (type: string), _col4 (type: string), _col5 (type: string), _col6 (type: string), _col7
  (type: string), _col8 (type: string), _col9 (type: string), _col10 (type: string), _col11 (type: int), _col12 (type: bigint), _col13 (type: double), _col14 (type: double), _col15 (type: double), _col16 (type: double), _col17 (type: double), _col18 (type: double), _col19 (type: int), _col20 (type: bigint)\",\"Statistics:\":\"Num rows: 7240486 Data size: 370679424 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"_col0 (type: string), _col1 (type: string), _col20 (type: bigint)\"}},\"Statistics:\":\"Num rows: 7240486 Data size: 370679424 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 7240486 Data size: 370679424 Basic stats: COMPLETE Column stats: NONE\"}},\"Statistics:\":\"Num rows: 347543328 Data size: 17792612352 Basic stats: COMPLETE Column stats: NONE\",\"condition map:\":[{\"\":\"Inner Join 0 to 1\"}],\"condition expressions:\":{\"1\":\"{VALUE._col2} {VALUE._col3} {VALUE._col12} {VALUE._col15} {VALUE._col16} {VALUE._col17} {VALUE._col18
 }\",\"0\":\"{VALUE._col0} {VALUE._col2} {VALUE._col3} {VALUE._col4} {VALUE._col5} {VALUE._col6} {VALUE._col7} {VALUE._col8} {VALUE._col9} {VALUE._col10} {VALUE._col11} {VALUE._col12} {VALUE._col15} {VALUE._col16} {VALUE._col17} {VALUE._col18}\"}}}},\"Map 4\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"store_sales\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"ss_item_sk (type: int), ss_ticket_number (type: int)\",\"sort order:\":\"++\",\"value expressions:\":\"ss_sold_date_sk (type: int), ss_item_sk (type: int), ss_customer_sk (type: int), ss_cdemo_sk (type: int), ss_hdemo_sk (type: int), ss_addr_sk (type: int), ss_store_sk (type: int), ss_promo_sk (type: int), ss_wholesale_cost (type: float), ss_list_price (type: float), ss_coupon_amt (type: float)\",\"Statistics:\":\"Num rows: 550076554 Data size: 28161379051 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"ss_item_sk (type: int), ss_tic
 ket_number (type: int)\"}},\"Statistics:\":\"Num rows: 550076554 Data size: 28161379051 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 43\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"cd2\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"cd_demo_sk (type: int)\",\"sort order:\":\"+\",\"value expressions:\":\"cd_marital_status (type: string)\",\"Statistics:\":\"Num rows: 1920800 Data size: 31322 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"cd_demo_sk (type: int)\"}},\"Statistics:\":\"Num rows: 1920800 Data size: 31322 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 42\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"ib2\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"ib_income_band_sk (type: int)\",\"sort order:\":\"+\",\"Statistics:\":\"Num rows: 20 Data size: 306 Basic stats: COMPLETE Column stats: NONE\
 ",\"key expressions:\":\"ib_income_band_sk (type: int)\"}},\"Statistics:\":\"Num rows: 20 Data size: 306 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 41\":{\"Execution mode:\":\"vectorized\",\"Map Operator Tree:\":[{\"TableScan\":{\"alias:\":\"ib1\",\"children\":{\"Reduce Output Operator\":{\"Map-reduce partition columns:\":\"ib_income_band_sk (type: int)\",\"sort order:\":\"+\",\"Statistics:\":\"Num rows: 20 Data size: 306 Basic stats: COMPLETE Column stats: NONE\",\"key expressions:\":\"ib_income_band_sk (type: int)\"}},\"Statistics:\":\"Num rows: 20 Data size: 306 Basic stats: COMPLETE Column stats: NONE\"}}]},\"Map 40\":{\"

<TRUNCATED>

[4/5] git commit: AMBARI-6507. Create mappers for models. (onechiporenko)

Posted by on...@apache.org.
AMBARI-6507. Create mappers for models. (onechiporenko)


Project: http://git-wip-us.apache.org/repos/asf/ambari/repo
Commit: http://git-wip-us.apache.org/repos/asf/ambari/commit/b76efd5b
Tree: http://git-wip-us.apache.org/repos/asf/ambari/tree/b76efd5b
Diff: http://git-wip-us.apache.org/repos/asf/ambari/diff/b76efd5b

Branch: refs/heads/trunk
Commit: b76efd5b63eedd6bafd7ab484bf2ec4a3c763b1d
Parents: 2636029
Author: Oleg Nechiporenko <on...@apache.org>
Authored: Wed Jul 16 18:42:35 2014 +0300
Committer: Oleg Nechiporenko <on...@apache.org>
Committed: Wed Jul 16 18:42:35 2014 +0300

----------------------------------------------------------------------
 .../jobs/src/main/resources/ui/Gruntfile.js     |   7 +-
 .../src/main/resources/ui/app/scripts/app.js    |  26 +-
 .../ui/app/scripts/assets/hive-queries.json     | 232 ++++++++
 .../ui/app/scripts/assets/hive-query-2.json     |   8 +
 .../app/scripts/assets/tezDag-name-to-id.json   | 552 +++++++++++++++++++
 .../resources/ui/app/scripts/assets/tezDag.json |  21 +
 .../ui/app/scripts/assets/tezDagVertex.json     | 221 ++++++++
 .../resources/ui/app/scripts/helpers/ajax.js    | 151 +++++
 .../resources/ui/app/scripts/helpers/date.js    |   5 +-
 .../app/scripts/mappers/jobs/hive_job_mapper.js | 217 ++++++++
 .../scripts/mappers/jobs/hive_jobs_mapper.js    |  96 ++++
 .../app/scripts/mappers/server_data_mapper.js   | 133 +++++
 .../main/resources/ui/app/scripts/models/job.js |  69 ---
 .../ui/app/scripts/models/jobs/abstract_job.js  |   6 +-
 .../ui/app/scripts/models/jobs/hive_job.js      |   2 +-
 .../ui/app/scripts/models/jobs/tez_dag.js       |  17 +-
 .../main/resources/ui/app/scripts/models/run.js | 121 ----
 .../src/main/resources/ui/app/scripts/router.js |   3 +-
 .../ui/app/scripts/routes/application_route.js  |  26 +-
 .../src/main/resources/ui/app/scripts/store.js  |   2 +-
 20 files changed, 1696 insertions(+), 219 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/Gruntfile.js
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/Gruntfile.js b/contrib/views/jobs/src/main/resources/ui/Gruntfile.js
index 5ebf75d..b5ce07b 100644
--- a/contrib/views/jobs/src/main/resources/ui/Gruntfile.js
+++ b/contrib/views/jobs/src/main/resources/ui/Gruntfile.js
@@ -255,10 +255,11 @@ module.exports = function (grunt) {
             cwd: '<%= yeoman.app %>',
             dest: '<%= yeoman.dist %>',
             src: [
-              '*.{ico,txt,php}',
+              '*.{ico,txt}',
               '.htaccess',
               'images/{,*/}*.{webp,gif}',
-              'styles/fonts/*'
+              'styles/fonts/*',
+              'scripts/assets/**/*'
             ]
           }
         ]
@@ -366,7 +367,7 @@ module.exports = function (grunt) {
     'concat',
     'cssmin',
     //'uglify',
-    'copy',
+    'copy:dist',
     //'rev',
     'usemin'
   ]);

http://git-wip-us.apache.org/repos/asf/ambari/blob/b76efd5b/contrib/views/jobs/src/main/resources/ui/app/scripts/app.js
----------------------------------------------------------------------
diff --git a/contrib/views/jobs/src/main/resources/ui/app/scripts/app.js b/contrib/views/jobs/src/main/resources/ui/app/scripts/app.js
index f4e1295..5622f4a 100644
--- a/contrib/views/jobs/src/main/resources/ui/app/scripts/app.js
+++ b/contrib/views/jobs/src/main/resources/ui/app/scripts/app.js
@@ -20,12 +20,32 @@ var App = window.App = Ember.Application.create();
 
 App.Helpers = Ember.Namespace.create();
 
+App.initializer({
+
+  name: "preload",
+
+  initialize: function(container, application) {
+
+    application.reopen({
+      /**
+       * Test mode is automatically enabled if running on localhost
+       * @type {bool}
+       */
+      testMode: (location.hostname == 'localhost')
+    });
+
+  }
+});
+
+
 /* Order and include as you please. */
-require('scripts/helpers/*');
-require('scripts/controllers/*');
+require('scripts/router');
 require('scripts/store');
+require('scripts/helpers/*');
 require('scripts/models/**/*');
+require('scripts/mappers/server_data_mapper.js');
+require('scripts/mappers/**/*');
+require('scripts/controllers/*');
 require('scripts/routes/*');
 require('scripts/components/*');
 require('scripts/views/*');
-require('scripts/router');